Index
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _
All Classes|All Packages
All Classes|All Packages
A
- abort(String, Exception) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
-
Abort this request, and store a
BulkItemResponse.Failure
response. - ABORTED - org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- ABORTED - org.elasticsearch.cluster.SnapshotsInProgress.State
- ABORTED - org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot aborted
- ABORTED_BY_USER_MSG - Static variable in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- AbortedSnapshotException - Exception in org.elasticsearch.snapshots
- AbortedSnapshotException() - Constructor for exception org.elasticsearch.snapshots.AbortedSnapshotException
- abortIfNotCompleted(String) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set whether or not version conflicts cause the action to abort.
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- abortRelocationHandoff() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Fails a relocation handoff attempt.
- absoluteTimeInMillis() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Returns the value of milliseconds since UNIX epoch.
- AbstractAggregationBuilder<AB extends AbstractAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations
-
Base implementation of a
AggregationBuilder
. - AbstractAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Constructs a new aggregation builder.
- AbstractAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Read from a stream.
- AbstractAggregationBuilder(AbstractAggregationBuilder<AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- AbstractAllocateAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Abstract base class for allocating an unassigned shard to a node
- AbstractAllocateAllocationCommand(String, int, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- AbstractAllocateAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Read from a stream.
- AbstractAllocateAllocationCommand.Builder<T extends AbstractAllocateAllocationCommand> - Class in org.elasticsearch.cluster.routing.allocation.command
-
Works around ObjectParser not supporting constructor arguments.
- AbstractAllocationDecision - Class in org.elasticsearch.cluster.routing.allocation
-
An abstract class for representing various types of allocation decisions.
- AbstractAllocationDecision(DiscoveryNode, List<NodeAllocationResult>) - Constructor for class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- AbstractAllocationDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- AbstractAsyncTask - Class in org.elasticsearch.common.util.concurrent
-
A base class for tasks that need to repeat.
- AbstractAsyncTask(Logger, ThreadPool, TimeValue, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- 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 is object remained the same.
- AbstractDiffable() - Constructor for class org.elasticsearch.cluster.AbstractDiffable
- AbstractDistanceScoreFunction(double, double, double, DecayFunction, MultiValueMode) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- AbstractGeometryFieldMapper<Parsed,Processed> - Class in org.elasticsearch.index.mapper
-
Base field mapper class for all spatial field types
- AbstractGeometryFieldMapper(String, FieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- AbstractGeometryFieldMapper.AbstractGeometryFieldType<Parsed,Processed> - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.AbstractGeometryFieldType.QueryProcessor - Interface in org.elasticsearch.index.mapper
-
interface representing a query builder that generates a query from the given geometry
- AbstractGeometryFieldMapper.Builder<T extends AbstractGeometryFieldMapper.Builder<T,FT>,FT extends AbstractGeometryFieldMapper.AbstractGeometryFieldType> - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.Indexer<Parsed,Processed> - Interface in org.elasticsearch.index.mapper
-
Interface representing an preprocessor in geometry indexing pipeline
- AbstractGeometryFieldMapper.Names - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.Parser<Parsed> - Interface in org.elasticsearch.index.mapper
-
interface representing parser in geometry indexing pipeline
- AbstractGeometryFieldMapper.TypeParser<T extends AbstractGeometryFieldMapper.Builder> - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldType(String, boolean, boolean, 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.use
AbstractGeometryQueryBuilder(String, String)
instead - AbstractGeometryQueryBuilder(String, Supplier<Geometry>, String, String) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- AbstractGeometryQueryBuilder(String, ShapeBuilder) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Deprecated.use
AbstractGeometryQueryBuilder(String, Geometry)
instead - AbstractGeometryQueryBuilder(String, Geometry) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Creates a new AbstractGeometryQueryBuilder whose Query will be against the given field name using the given Shape
- AbstractGeometryQueryBuilder(String, Geometry, String, String) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- AbstractGeometryQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Read from a stream.
- AbstractGeometryQueryBuilder.ParsedGeometryQueryParams - Class in org.elasticsearch.index.query
-
local class that encapsulates xcontent parsed shape parameters
- AbstractHighlighterBuilder<HB extends AbstractHighlighterBuilder<?>> - Class in org.elasticsearch.search.fetch.subphase.highlight
-
This abstract class holds parameters shared by
HighlightBuilder
andHighlightBuilder.Field
and provides the common setters, equality, hashCode calculation and common serialization - AbstractHighlighterBuilder() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- AbstractHighlighterBuilder(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Read from a stream.
- AbstractHighlighterBuilder(AbstractHighlighterBuilder<?>, QueryBuilder) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- 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, double, double, DocValueFormat, SearchContext, 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
- AbstractIndexAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Class in org.elasticsearch.index.analysis
- AbstractIndexAnalyzerProvider(IndexSettings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
-
Constructs a new analyzer component, with the index name and its settings and the analyzer name.
- AbstractIndexComponent - Class in org.elasticsearch.index
- AbstractIndexComponent(IndexSettings) - Constructor for class org.elasticsearch.index.AbstractIndexComponent
-
Constructs a new index component, with the index name and its settings.
- AbstractIndexFieldData<FD extends LeafFieldData> - Class in org.elasticsearch.index.fielddata.plain
- AbstractIndexFieldData(IndexSettings, String, ValuesSourceType, IndexFieldDataCache) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- AbstractIndexFieldData.PerValueEstimator - Interface in org.elasticsearch.index.fielddata.plain
-
A
PerValueEstimator
is a sub-class that can be used to estimate the memory overhead for loading the data. - AbstractIndexOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractIndexOrdinalsFieldData(IndexSettings, String, ValuesSourceType, IndexFieldDataCache, CircuitBreakerService, double, double, int) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- AbstractIndexShardComponent - Class in org.elasticsearch.index.shard
- AbstractIndexShardComponent(ShardId, IndexSettings) - Constructor for class org.elasticsearch.index.shard.AbstractIndexShardComponent
- AbstractInternalProfileTree<PB extends AbstractProfileBreakdown<?>,E> - Class in org.elasticsearch.search.profile
- AbstractInternalProfileTree() - Constructor for class org.elasticsearch.search.profile.AbstractInternalProfileTree
- 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. - 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<Parsed,Processed> - Class in org.elasticsearch.index.mapper
-
Base class for for spatial fields that only support indexing points
- AbstractPointGeometryFieldMapper(String, FieldType, MappedFieldType, FieldMapper.MultiFields, Explicit<Boolean>, Explicit<Boolean>, AbstractPointGeometryFieldMapper.ParsedPoint, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- AbstractPointGeometryFieldMapper.AbstractPointGeometryFieldType<Parsed,Processed> - Class in org.elasticsearch.index.mapper
- AbstractPointGeometryFieldMapper.Builder<T extends AbstractPointGeometryFieldMapper.Builder<T,FT>,FT extends AbstractPointGeometryFieldMapper.AbstractPointGeometryFieldType> - Class in org.elasticsearch.index.mapper
- AbstractPointGeometryFieldMapper.Names - Class in org.elasticsearch.index.mapper
- AbstractPointGeometryFieldMapper.ParsedPoint - Interface in org.elasticsearch.index.mapper
-
represents a Point that has been parsed by
AbstractPointGeometryFieldMapper.PointParser
- AbstractPointGeometryFieldMapper.PointParser<P extends AbstractPointGeometryFieldMapper.ParsedPoint> - Class in org.elasticsearch.index.mapper
-
A parser implementation that can parse the various point formats
- AbstractPointGeometryFieldMapper.TypeParser<T extends AbstractPointGeometryFieldMapper.Builder> - Class in org.elasticsearch.index.mapper
- AbstractPointGeometryFieldType(String, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.AbstractPointGeometryFieldType
- 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 java.lang.Enum<T>> - Class in org.elasticsearch.search.profile
-
A record of timings for the various operations that may happen during query execution.
- AbstractProfileBreakdown(Class<T>) - Constructor for class org.elasticsearch.search.profile.AbstractProfileBreakdown
-
Sole constructor.
- AbstractProfiler<PB extends AbstractProfileBreakdown<?>,E> - Class in org.elasticsearch.search.profile
- AbstractProfiler(AbstractInternalProfileTree<PB, E>) - Constructor for class org.elasticsearch.search.profile.AbstractProfiler
- AbstractQueryBuilder<QB extends AbstractQueryBuilder<QB>> - Class in org.elasticsearch.index.query
-
Base class for all classes producing lucene queries.
- AbstractQueryBuilder() - Constructor for class org.elasticsearch.index.query.AbstractQueryBuilder
- AbstractQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.AbstractQueryBuilder
- AbstractRangeAggregatorFactory<R extends RangeAggregator.Range> - Class in org.elasticsearch.search.aggregations.bucket.range
- AbstractRangeAggregatorFactory(String, String, ValuesSourceConfig, R[], boolean, InternalRange.Factory<?, ?>, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeAggregatorFactory
- AbstractRangeBuilder<AB extends AbstractRangeBuilder<AB,R>,R extends RangeAggregator.Range> - Class in org.elasticsearch.search.aggregations.bucket.range
- AbstractRangeBuilder(String, InternalRange.Factory<?, ?>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- AbstractRangeBuilder(StreamInput, InternalRange.Factory<?, ?>, Writeable.Reader<R>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
-
Read from a stream.
- AbstractRangeBuilder(AbstractRangeBuilder<AB, R>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- AbstractRareTermsAggregator - 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.
- AbstractShapeGeometryFieldMapper<Parsed,Processed> - Class in org.elasticsearch.index.mapper
-
Base class for
GeoShapeFieldMapper
andLegacyGeoShapeFieldMapper
- AbstractShapeGeometryFieldMapper(String, FieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Explicit<Boolean>, Explicit<ShapeBuilder.Orientation>, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- AbstractShapeGeometryFieldMapper.AbstractShapeGeometryFieldType<Parsed,Processed> - Class in org.elasticsearch.index.mapper
- AbstractShapeGeometryFieldMapper.Builder<T extends AbstractShapeGeometryFieldMapper.Builder<T,FT>,FT extends AbstractShapeGeometryFieldMapper.AbstractShapeGeometryFieldType> - Class in org.elasticsearch.index.mapper
- AbstractShapeGeometryFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- AbstractShapeGeometryFieldMapper.Names - Class in org.elasticsearch.index.mapper
- AbstractShapeGeometryFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- AbstractShapeGeometryFieldType(String, boolean, boolean, 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
- 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 - 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.ParametrizedFieldMapper.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_ORIGIN - Static variable in class org.elasticsearch.http.CorsHandler
- ACCESS_CONTROL_REQUEST_METHOD - Static variable in class org.elasticsearch.http.CorsHandler
- accessed(long) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- accessed(long) - Method in class org.elasticsearch.search.internal.SearchContext
- accessed(long) - Method in class org.elasticsearch.search.internal.SubSearchContext
- ACCOUNTING - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The accounting breaker tracks things held in memory that is independent of the request lifecycle.
- ACCOUNTING_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- ACCOUNTING_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- ACCOUNTING_CIRCUIT_BREAKER_TYPE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- accuracy() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- accuracy() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the accuracy setting.
- accuracy(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- accuracy(float) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets how similar the suggested terms at least need to be compared to the original suggest text tokens.
- accuracy(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
s how similar the suggested terms at least need to be compared to the original suggest text tokens.
- ACCURACY_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- AckClusterStatePublishResponseHandler - Class in org.elasticsearch.discovery
-
Allows to wait for all nodes to reply to the publish of a new cluster state and notifies the
ClusterStatePublisher.AckListener
so that the cluster state update can be acknowledged - AckClusterStatePublishResponseHandler(Set<DiscoveryNode>, ClusterStatePublisher.AckListener) - Constructor for class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
-
Creates a new AckClusterStatePublishResponseHandler
- AckedClusterStateTaskListener - Interface in org.elasticsearch.cluster
- AckedClusterStateUpdateTask<Response> - Class in org.elasticsearch.cluster
-
An extension interface to
ClusterStateUpdateTask
that allows to be notified when all the nodes have acknowledged a cluster state update request - AckedClusterStateUpdateTask(AckedRequest, ActionListener<Response>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedClusterStateUpdateTask(Priority, AckedRequest, ActionListener<Response>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedRequest - Interface in org.elasticsearch.cluster.ack
-
Identifies a cluster state update request with acknowledgement support
- acknowledged - Variable in class org.elasticsearch.action.support.master.AcknowledgedResponse
- acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutResponse
- acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.RemoveResponse
- AcknowledgedRequest<Request extends MasterNodeRequest<Request>> - Class in org.elasticsearch.action.support.master
-
Abstract class that allows to mark action requests that support acknowledgements.
- AcknowledgedRequest() - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequestBuilder<Request extends AcknowledgedRequest<Request>,Response extends AcknowledgedResponse,RequestBuilder extends AcknowledgedRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.master
-
Base request builder for master node operations that support acknowledgements
- AcknowledgedRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequestBuilder
- AcknowledgedResponse - Class in org.elasticsearch.action.support.master
-
A response that indicates that a request has been acknowledged
- AcknowledgedResponse(boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedResponse(StreamInput, boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- ackTimeout() - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
- ackTimeout() - Method in interface org.elasticsearch.cluster.ack.AckedRequest
-
Returns the acknowledgement timeout
- ackTimeout() - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Returns the maximum time interval to wait for acknowledgements
- ackTimeout() - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout(TimeValue) - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Sets the acknowledgement timeout
- acquire() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
- acquire(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Acquires a lock for the given key.
- acquireAllPrimaryOperationsPermits(ActionListener<Releasable>, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire all primary operation permits.
- acquireAllReplicaOperationsPermits(long, long, long, ActionListener<Releasable>, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire all replica operation permits whenever the shard is ready for indexing (see
IndexShard.acquireAllPrimaryOperationsPermits(ActionListener, TimeValue)
. - acquireCanMatchSearcher() - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a lightweight searcher which can be used to rewrite shard search requests.
- acquireFSLockForPaths(IndexSettings, Path...) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Acquires, then releases, all
write.lock
files in the given shard paths. - acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.Engine
-
Acquires a lock on the translog files and Lucene soft-deleted documents to prevent them from being trimmed
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquires a lock on the translog files and Lucene soft-deleted documents to prevent them from being trimmed
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Snapshots the most recent index and returns a handle to it.
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
Creates a new
IndexCommit
snapshot from the currently running engine. - acquirePrimaryOperationPermit(ActionListener<Releasable>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a primary operation permit whenever the shard is ready for indexing.
- acquirePrimaryOperationPermit(IndexShard, TransportVerifyShardBeforeCloseAction.ShardRequest, ActionListener<Releasable>) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- acquirePrimaryOperationPermit(IndexShard, 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
-
Returns a new searcher instance.
- acquireSearcher(String) - Method in class org.elasticsearch.index.shard.IndexShard
- acquireSearcher(String, Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.Engine
-
Returns a new searcher instance.
- acquireThrottle() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
- action - Variable in class org.elasticsearch.action.ActionRequestBuilder
- action() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- action() - Method in exception org.elasticsearch.transport.ActionNotFoundTransportException
- action() - Method in exception org.elasticsearch.transport.ActionTransportException
-
The action to invoke.
- action() - Method in class org.elasticsearch.transport.Transport.ResponseContext
- ACTION_NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- ACTION_NAME - Static variable in class org.elasticsearch.action.bulk.TransportShardBulkAction
- ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
- ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.UnicastZenPing
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.LocalAllocateDangledIndices
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Add
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- ACTION_NAME - Static variable in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
- ACTION_ORIGIN_TRANSIENT_NAME - Static variable in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Name for the
origin
attribute. - ACTION_SHARD_EXISTS - Static variable in class org.elasticsearch.indices.store.IndicesStore
- ActionFilter - Interface in org.elasticsearch.action.support
-
A filter allowing to filter transport actions
- ActionFilter.Simple - Class in org.elasticsearch.action.support
-
A simple base class for injectable action filters that spares the implementation from handling the filter chain.
- ActionFilterChain<Request extends ActionRequest,Response extends ActionResponse> - Interface in org.elasticsearch.action.support
-
A filter chain allowing to continue and process the transport action request
- ActionFilters - Class in org.elasticsearch.action.support
-
Holds the action filters injected through plugins, properly sorted by
ActionFilter.order()
- ActionFilters(Set<ActionFilter>) - Constructor for class org.elasticsearch.action.support.ActionFilters
- ActionFuture<T> - Interface in org.elasticsearch.action
-
An extension to
Future
allowing for simplified "get" operations. - actionGet() - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get()
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet() - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(long) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(long) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(long, TimeUnit) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(long, TimeUnit) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(String) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(String) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(TimeValue) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(TimeValue) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- ActionHandler(ActionType<Response>, Class<? extends TransportAction<Request, Response>>, Class<?>...) - Constructor for class org.elasticsearch.plugins.ActionPlugin.ActionHandler
-
Create a record of an action, the TransportAction that handles it, and any supporting TransportActions that are needed by that TransportAction.
- ActionListener<Response> - Interface in org.elasticsearch.action
-
A listener for action responses or failures.
- ActionListenerResponseHandler<Response extends TransportResponse> - Class in org.elasticsearch.action
-
A simple base class for action response listeners, defaulting to using the SAME executor (as its very common on response handlers).
- ActionListenerResponseHandler(ActionListener<? super Response>, Writeable.Reader<Response>) - Constructor for class org.elasticsearch.action.ActionListenerResponseHandler
- ActionListenerResponseHandler(ActionListener<? super Response>, Writeable.Reader<Response>, String) - Constructor for class org.elasticsearch.action.ActionListenerResponseHandler
- ActionModule - Class in org.elasticsearch.action
-
Builds and binds the generic action map, all
TransportAction
s, andActionFilters
. - ActionModule(boolean, Settings, IndexNameExpressionResolver, IndexScopedSettings, ClusterSettings, SettingsFilter, ThreadPool, List<ActionPlugin>, NodeClient, CircuitBreakerService, UsageService, ClusterService) - Constructor for class org.elasticsearch.action.ActionModule
- actionName - Variable in class org.elasticsearch.action.support.TransportAction
- ActionNotFoundTransportException - Exception in org.elasticsearch.transport
-
An exception indicating that a transport action was not found.
- ActionNotFoundTransportException(String) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
- ActionNotFoundTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
- ActionPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's scripting functionality. - ActionPlugin.ActionHandler<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.plugins
- ActionRequest - Class in org.elasticsearch.action
- ActionRequest() - Constructor for class org.elasticsearch.action.ActionRequest
- ActionRequest(StreamInput) - Constructor for class org.elasticsearch.action.ActionRequest
- ActionRequestBuilder<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action
- ActionRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.ActionRequestBuilder
- ActionRequestValidationException - Exception in org.elasticsearch.action
- ActionRequestValidationException() - Constructor for exception org.elasticsearch.action.ActionRequestValidationException
- ActionResponse - Class in org.elasticsearch.action
-
Base class for responses to action requests.
- ActionResponse() - Constructor for class org.elasticsearch.action.ActionResponse
- ActionResponse(StreamInput) - Constructor for class org.elasticsearch.action.ActionResponse
- ActionRunnable<Response> - Class in org.elasticsearch.action
-
Base class for
Runnable
s that need to callActionListener.onFailure(Exception)
in case an uncaught exception or error is thrown while the actual action is run. - ActionRunnable(ActionListener<Response>) - Constructor for class org.elasticsearch.action.ActionRunnable
- actions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
-
Returns the alias actions to be performed
- Actions() - Constructor for class org.elasticsearch.indices.recovery.PeerRecoverySourceService.Actions
- Actions() - Constructor for class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- ActionTransportException - Exception in org.elasticsearch.transport
-
An action invocation failure.
- ActionTransportException(String, TransportAddress, String, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- ActionTransportException(String, TransportAddress, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- ActionTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- actionType() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Type of the action to perform.
- ActionType<Response extends ActionResponse> - Class in org.elasticsearch.action
-
A generic action.
- ActionType(String, Writeable.Reader<Response>) - Constructor for class org.elasticsearch.action.ActionType
- activate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
Activate throttling, which switches the lock to be a real lock
- activate(Optional<DiscoveryNode>, ClusterState) - Method in class org.elasticsearch.cluster.coordination.DiscoveryUpgradeService
- activate(DiscoveryNodes) - Method in class org.elasticsearch.discovery.PeerFinder
- activatePrimaryMode(long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Initializes the global checkpoint tracker in primary mode (see
ReplicationTracker.primaryMode
. - activateThrottling() - Method in class org.elasticsearch.index.engine.Engine
-
Request that this engine throttle incoming indexing requests to one thread.
- activateThrottling() - Method in class org.elasticsearch.index.engine.InternalEngine
- activateThrottling() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- activateThrottling() - Method in class org.elasticsearch.index.shard.IndexShard
- activateThrottling(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
Asks this shard to throttle indexing to one thread
- activateWithPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Activates the global checkpoint tracker in primary mode (see
ReplicationTracker.primaryMode
. - activateWithPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.index.shard.IndexShard
-
Updates the known allocation IDs and the local checkpoints for the corresponding allocations from a primary relocation source.
- active() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- activeInitializingShardsIt(int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards.
- activeInitializingShardsRandomIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards.
- activeInitializingShardsRankedIt(ResponseCollectorService, Map<String, Long>) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards, ordered by the adaptive replica selection formula.
- activeOnly() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
True if activeOnly flag is set, false otherwise.
- activeOnly(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
Set value of the activeOnly flag.
- activePrimary(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns the active primary shard for the given shard id or
null
if no primary is found or the primary is not active. - activePrimaryShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the *active* primary shards for the provided indices grouped (each group is a single element, consisting of the primary shard).
- activeReplicaWithHighestVersion(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns one active replica shard for the given shard id or
null
if no active replica is found. - ActiveShardCount - Class in org.elasticsearch.action.support
-
A class whose instances represent a value for counting the number of active shard copies for a given shard in an index.
- activeShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of active shards - ActiveShardsObserver - Class in org.elasticsearch.action.support
-
This class provides primitives for waiting for a configured number of shards to become active before sending a response on an
ActionListener
. - ActiveShardsObserver(ClusterService, ThreadPool) - Constructor for class org.elasticsearch.action.support.ActiveShardsObserver
- activityTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- actualSizeToRead() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- adaptAutoExpandReplicas(ClusterState) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Checks if 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
- ADAPTIVE_SELECTION - 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.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.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(IndexableField) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- add(LeafReader) - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Register a
LeafReader
. - add(Term) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Add a single term at the next position in the phrase.
- add(Term[]) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Add multiple terms at the next position in the phrase.
- add(Term[], int) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Allows to specify the relative position of terms within the phrase.
- add(BytesRef) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Sugar to
add(key, key.hashCode()
. - add(BytesRef) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Add's the provided value to the set for tracking
- add(BytesRef, int) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Try to add
key
. - add(CommonStats) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- add(ShardStats) - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats.IndexStatsBuilder
- add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DeleteRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DocWriteRequest<?>) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds either a delete or an index request.
- add(DocWriteRequest<?>) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Add a request to the current BulkRequest.
- add(DocWriteRequest<?>...) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(MultiGetRequest.Item) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(MultiGetRequest.Item) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds an
IndexRequest
to the list of actions to execute. - add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds an
IndexRequest
to the list of actions to execute. - add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
IndexRequest
to the list of actions to execute. - add(IndexRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
IndexRequest
to the list of actions to execute. - add(SearchRequest) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Add a search request to execute.
- add(SearchRequest) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Add a search request to execute.
- add(SearchRequestBuilder) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Add a search request to execute.
- add(SearchRequestBuilder) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Add a search request to execute.
- add(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(TermVectorsRequest, XContentParser) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds an
UpdateRequest
to the list of actions to execute. - add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
UpdateRequest
to the list of actions to execute. - add(UpdateRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
UpdateRequest
to the list of actions to execute. - add(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
-
adds a disco node to the builder.
- add(RestoreInProgress.Entry) - Method in class org.elasticsearch.cluster.RestoreInProgress.Builder
- add(AllocationCommand...) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Adds allocation commands to be applied to the cluster.
- add(AllocationCommand...) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Adds allocation commands to be applied to the cluster.
- add(AllocationCommand...) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Adds a set of commands to this collection
- add(Decision) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
-
Add a decision to this
Decision.Multi
decision instance - add(RerouteExplanation) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
- add(IndexRoutingTable) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- add(IndexRoutingTable.Builder) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- add(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- add(DeleteResult) - Method in class org.elasticsearch.common.blobstore.DeleteResult
- add(BytesReference, long) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Add the given bytes to the translog with the specified sequence number; returns the location the bytes were written to.
- add(BytesReference, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(BytesReference, String, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.
- add(BytesReference, String, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds the data from the bytes to be processed by the bulk processor
- add(BytesReference, String, String, String, FetchSourceContext, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
- add(BytesReference, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds the data from the bytes to be processed by the bulk processor
- add(BytesReference, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.
- add(BytesReference, String, String, FetchSourceContext, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
- add(BytesReference, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(FieldMemoryStats) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Adds / merges the given field memory stats into this stats instance
- add(Module...) - Method in class org.elasticsearch.common.inject.ModulesBuilder
- add(QueryCacheStats) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- add(RequestCacheStats) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- add(SegmentsStats) - Method in class org.elasticsearch.index.engine.SegmentsStats
- add(FieldDataStats) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- add(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
- add(GetStats) - Method in class org.elasticsearch.index.get.GetStats
- add(Mapper) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- add(MergeStats) - Method in class org.elasticsearch.index.merge.MergeStats
- add(QueryBuilder) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
-
Add a sub-query to this disjunction.
- add(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- add(RefreshStats) - Method in class org.elasticsearch.index.refresh.RefreshStats
- add(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- add(SearchStats.Stats) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- add(DocsStats) - Method in class org.elasticsearch.index.shard.DocsStats
- add(IndexingStats) - Method in class org.elasticsearch.index.shard.IndexingStats
- add(IndexingStats.Stats) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- add(IndexingStats, boolean) - Method in class org.elasticsearch.index.shard.IndexingStats
- add(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(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 - org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource
-
to be overridden by subclasses
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- addAffixGroupUpdateConsumer(List<Setting.AffixSetting<?>>, BiConsumer<String, Settings>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a affix settings consumer that accepts the settings for a group of settings.
- addAffixMapUpdateConsumer(Setting.AffixSetting<T>, Consumer<Map<String, T>>, BiConsumer<String, T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer for affix settings.
- addAffixUpdateConsumer(Setting.AffixSetting<A>, Setting.AffixSetting<B>, BiConsumer<String, Tuple<A, B>>, BiConsumer<String, Tuple<A, B>>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a affix settings consumer that accepts the values for two settings.
- addAffixUpdateConsumer(Setting.AffixSetting<T>, BiConsumer<String, T>, BiConsumer<String, T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer for affix settings.
- addAggregation(AggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an aggregation to the search operation.
- addAggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an aggregation to the search operation.
- addAggregator(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- addAlias(String[], String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, boolean) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(Alias) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds an alias that will be associated with the index when it gets created
- addAlias(Alias) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds an alias that will be added when the index template gets created.
- addAliasAction(IndicesAliasesRequest.AliasActions) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
Add the action to this request and validate it.
- addAliasAction(IndicesAliasesRequest.AliasActions) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias action to the request.
- addAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- addAll(Collection<? extends T>) - Method in class org.elasticsearch.common.collect.EvictingQueue
-
Add the given elements to the queue, possibly forcing evictions from the head if
EvictingQueue.remainingCapacity()
is zero or becomes zero during the execution of this method. - addAll(List<? extends IndexableField>) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- addAppender(Logger, Appender) - Static method in class org.elasticsearch.common.logging.Loggers
- addAsFromCloseToOpen(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsFromDangling(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsFromOpenToClose(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsNew(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsNewRestore(IndexMetadata, RecoverySource.SnapshotRecoverySource, IntSet) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsRecovery(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsRestore(IndexMetadata, RecoverySource.SnapshotRecoverySource) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addBinding() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a binding builder used to add a new element in the set.
- addBinding() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- addBinding(K) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a binding builder used to add a new entry in the map.
- addBinding(K) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder
-
This creates two bindings.
- addBitsetMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- 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
- addCloseListener(ActionListener<Void>) - Method in interface org.elasticsearch.common.network.CloseableChannel
-
Adds a listener that will be executed when the channel is closed.
- addCloseListener(ActionListener<Void>) - Method in class org.elasticsearch.transport.CloseableConnection
- addCloseListener(ActionListener<Void>) - Method in interface org.elasticsearch.transport.Transport.Connection
-
The listener's
ActionListener.onResponse(Object)
method will be called when this connection is closed. - addConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
- addConnections(int, TransportRequestOptions.Type...) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Adds a number of connections for one or more types.
- addConnectListener(ActionListener<Void>) - Method in interface org.elasticsearch.transport.TcpChannel
-
Adds a listener that will be executed when the channel is connected.
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.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.segments.IndicesSegmentResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
Override in subclass to add custom fields following the common `_shards` field
- addDebugInfo(String, Object) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileBreakdown
-
Add extra debugging information about the aggregation.
- addDirectoryPath(Permissions, String, Path, String) - Static method in class org.elasticsearch.bootstrap.FilePermissionUtils
-
Add access to path (and all files underneath it); this also creates the directory if it does not exist.
- addDoc(int) - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Associates the given document id with the current ordinal.
- addDoc(ParseContext.Document) - Method in class org.elasticsearch.index.mapper.ParseContext
- addDoc(ParseContext.Document) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addDocValueField(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a docvalue based field to load and return.
- addDocValueField(String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load from doc values and return.
- addDocValueField(String, String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a docvalue based field to load and return.
- addDocValueField(String, String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load from the docvalue and return.
- addDocValuesFields(String, List<? extends GeoPoint>, List<IndexableField>, ParseContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- addDocValuesFields(String, Geometry, List, ParseContext) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- addDocValuesFields(String, Shape, List<IndexableField>, ParseContext) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper
-
Deprecated.
- addDocValuesFields(String, Processed, List<IndexableField>, ParseContext) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- addDocValuesMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addDynamicMapper(Mapper) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Add a new mapper dynamically created while parsing.
- addDynamicMapper(Mapper) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addDynamicMappingsUpdate(Mapping) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- added() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(String, Object...) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message which will be presented to the user at a later time.
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(String, Object...) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an error message for type
I
which will be presented to the user at a later time. - addError(Throwable) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(Throwable) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an exception, the full details of which will be logged, and the message of which will be presented to the user at a later time.
- addError(Throwable) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(Throwable) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an exception for type
I
, the full details of which will be logged, and the message of which will be presented to the user at a later time. - addError(Message) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(Message) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message to be presented to the user at a later time.
- addError(Message) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(Message) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an error message to be presented to the user at a later time.
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
-
Add a number of bytes, tripping the circuit breaker if the aggregated estimates are above the limit.
- addEstimateBytesAndMaybeBreak(long, String) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
-
add bytes to the breaker and maybe trip
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- addExposureBuilder(ExposureBuilder<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- addFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- addFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
- addField(ParseContext.Document, String, String, int, Map<String, Set<String>>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Adds a context-enabled field for all the defined mappings to
document
seeContextMappings.TypedContextField
- addFieldName(String) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Adds a field name
field
to the list of fields to load. - addFieldNames(List<String>) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Adds the field names
fieldNames
to the list of fields to load. - addFieldStringsFromParameter(TermVectorsRequest, String) - Static method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- addFileDetail(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addFileDetails(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- addFileSizes(ImmutableOpenMap<String, Long>) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addFilterSettingParams(RestRequest) - Method in class org.elasticsearch.common.settings.SettingsFilter
- addForClosingShard(SearchStats.Stats) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- addGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- addGlobalCheckpointListener(long, GlobalCheckpointListeners.GlobalCheckpointListener, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Add a global checkpoint listener.
- addGroup(TaskGroup.Builder) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup.Builder
- addHeader(String, String) - Method in 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.ParseContext
-
Add the given
field
to the set of ignored fields. - addIgnoredField(String) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addIgnoreShardForNode(ShardId, String) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- addIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- 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 - Class 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
- additionalSettings() - Method in class org.elasticsearch.plugins.Plugin
-
Additional node settings loaded by the plugin.
- ADDITIVE - org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
- addJoinVote(Join) - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- addLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.common.component.LifecycleComponent
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.repositories.FilterRepository
- addListener() - Method in enum org.elasticsearch.action.ThreadingModel
- addListener(Consumer<ClusterInfo>) - Method in interface org.elasticsearch.cluster.ClusterInfoService
-
Add a listener for new cluster information
- addListener(Consumer<ClusterInfo>) - Method in class org.elasticsearch.cluster.EmptyClusterInfoService
- addListener(Consumer<ClusterInfo>) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
- addListener(Listener) - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Registers new listener
- addListener(ActionListener<RecoveryResponse>) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- addListener(ActionListener<T>) - Method in interface org.elasticsearch.action.ListenableActionFuture
-
Add an action listener to be invoked when a response has received.
- addListener(ActionListener<T>) - Method in class org.elasticsearch.action.support.PlainListenableActionFuture
- addListener(ActionListener<V>, ExecutorService) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
-
Adds a listener to this future.
- addListener(ActionListener<V>, ExecutorService, ThreadContext) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
-
Adds a listener to this future.
- addListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Add a listener for updated cluster states
- addListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Add a listener for updated cluster states
- addListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- addListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- addListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.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
- 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(PluginInfo) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- addMultiField(Mapper.Builder<?>) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- addMultiFields(ParseContext, List<? extends GeoPoint>) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- addMultiFields(ParseContext, Geometry) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- addMultiFields(ParseContext, Shape) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper
-
Deprecated.
- addMultiFields(ParseContext, Processed) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- addNamedQuery(String, Query) - Method in class org.elasticsearch.index.query.QueryShardContext
- addNewHistoryCommit(Directory, Terminal, boolean) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- addNodeStatistics(String, int, long, long) - Method in class org.elasticsearch.node.ResponseCollectorService
- addNormsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addOne(long) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- addOneCandidate(DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- addOperation() - Method in enum org.elasticsearch.action.ThreadingModel
- addOption(O) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- addOption(PhraseSuggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- addOptions(List<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- addOrNotify(Translog.Location, Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Add a listener for refreshes, calling it immediately if the location is already visible.
- addPeerRecoveryRetentionLease(String, long, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Retention leases for peer recovery have source
ReplicationTracker.PEER_RECOVERY_RETENTION_LEASE_SOURCE
, a lease ID containing the persistent node ID calculated byReplicationTracker.getPeerRecoveryRetentionLeaseId(java.lang.String)
, and retain operations with sequence numbers strictly greater than the given global checkpoint. - addPeerRecoveryRetentionLease(String, long, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
- addPending(ClusterState) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
Add an incoming, not yet committed cluster state
- 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(PluginInfo) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- addPlugins(Collection<Class<? extends Plugin>>, Class<? extends Plugin>...) - Static method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- addPlugins(Collection<Class<? extends Plugin>>, Collection<Class<? extends Plugin>>) - Static method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- addPointsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addProcessedFile(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Increments number of processed files
- 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
-
Switch to a new profile.
- addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, String, String)
but the key will be automatically generated based onfrom
andto
. - addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but the key will be automatically generated. - addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, ZonedDateTime, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(ZonedDateTime, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, ZonedDateTime, ZonedDateTime)
but the key will be automatically generated based onfrom
andto
. - addRange(GeoDistanceAggregationBuilder.Range) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- addRange(IpRangeAggregationBuilder.Range) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new
IpRangeAggregationBuilder.Range
to this aggregation. - addRange(R) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- addReaderCloseListener(DirectoryReader, IndexReader.ClosedListener) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Adds the given listener to the provided directory reader.
- addRecoveredBytesToFile(String, long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addRecoveredBytesToFile(String, long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- addRefreshListener(Translog.Location, Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Add a listener for refreshes.
- addReleasable(Releasable, SearchContext.Lifetime) - Method in class org.elasticsearch.search.internal.SearchContext
-
Schedule the release of a resource.
- addReplica() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- addRepositories(String...) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Adds repositories to the list of repositories to get
- AddRequest(ShardId, String, long, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.AddRequest
- addRequestCircuitBreakerBytes(long) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Increment or decrement the number of bytes that have been allocated to service this request and potentially trigger a
CircuitBreakingException
. - addRescore(RescoreContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addRescore(RescoreContext) - Method in class org.elasticsearch.search.internal.SearchContext
- addRescore(RescoreContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- addRescorer(RescorerBuilder<?>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a new rescorer.
- addRescorer(RescorerBuilder<?>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- addRescorer(RescorerBuilder<?>, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a new rescorer.
- addResponseHeader(String, String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Add the
value
for the specifiedkey
Any duplicatevalue
is ignored. - addResponseHeader(String, String, Function<String, String>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Add the
value
for the specifiedkey
with the specifieduniqueValue
used for de-duplication. - address() - Method in class org.elasticsearch.common.transport.TransportAddress
-
Returns the enclosed
InetSocketAddress
- address() - Method in class org.elasticsearch.http.HttpInfo
- address() - Method in exception org.elasticsearch.transport.ActionTransportException
-
The target address to invoke the action on.
- address() - Method in class org.elasticsearch.transport.TransportInfo
- addressesFromString(String) - Method in class org.elasticsearch.transport.TcpTransport
- addressesFromString(String) - Method in interface org.elasticsearch.transport.Transport
-
Returns an address from its string representation.
- addressesFromString(String) - Method in class org.elasticsearch.transport.TransportService
- addRestHandler(BaseRestHandler) - Method in class org.elasticsearch.usage.UsageService
-
Add a REST handler to this service.
- addResultReader(String, Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Add a reader for the shard level results of the aggregation.
- addResultReader(String, Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Add a reader for the shard level results of the aggregation.
- addResultReader(Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Add a reader for the shard level results of the aggregation with SearchPlugin.SearchExtensionSpec.getName()'s
ParseField.getPreferredName()
as theNamedWriteable.getWriteableName()
. - addResultReader(Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Add a reader for the shard level results of the aggregation with SearchPlugin.SearchExtensionSpec.getName()'s
ParseField.getPreferredName()
as theNamedWriteable.getWriteableName()
. - addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Adds a new retention lease.
- addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Adds a new retention lease.
- addScriptField(String, Script) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a script based field to load and return.
- addScriptField(String, Script) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- addScriptParam(String, Object) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.search.internal.SearchContext
- addSearchOperationListener(SearchOperationListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
SearchOperationListener
for this index. - addSettingsUpdateConsumer(Consumer<Settings>, List<? extends Setting<?>>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer that is only executed if any setting in the supplied list of settings is changed.
- addSettingsUpdateConsumer(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, SnapshotState, Version, 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.
- addStoredFields(ParseContext, List<? extends GeoPoint>) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- addStoredFields(ParseContext, Geometry) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- addStoredFields(ParseContext, Shape) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper
-
Deprecated.
- addStoredFields(ParseContext, Processed) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- addStoredFieldsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addSuggestion(String, SuggestionBuilder<?>) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Adds an
SuggestionBuilder
instance under a user defined name. - addSuggestion(String, SuggestionSearchContext.SuggestionContext) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext
- addTargetThrottling(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addTask(String, String, Params, PersistentTasksCustomMetadata.Assignment) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
-
Adds a new task to the builder
- addTerm(T) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- addTermsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addTermVectorsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addThrottleTime(long) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- addTimeoutListener(TimeValue, TimeoutClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds a cluster state listener that is expected to be removed during a short period of time.
- addToFilter(SetBackedScalingCuckooFilter, B) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- addToFilter(SetBackedScalingCuckooFilter, LongRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
- addToFilter(SetBackedScalingCuckooFilter, StringRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
- addTokenFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- addTokenFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Add a name of token filter that will be used on top of a tokenizer provided.
- addTokenFilter(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- addTokenFilter(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Add token filter setting that will be used on top of a tokenizer provided.
- addTombstone(Index) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
-
Add a deleted index to the list of tombstones in the cluster state.
- addTombstones(Collection<Index>) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
-
Add a set of deleted indexes to the list of tombstones in the cluster state.
- addToSliceStatuses(BulkByScrollTask.StatusOrException) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- addTotals(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
- addTotals(GetStats) - Method in class org.elasticsearch.index.get.GetStats
- addTotals(MergeStats) - Method in class org.elasticsearch.index.merge.MergeStats
- addTotals(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- addTotals(RefreshStats) - Method in class org.elasticsearch.index.refresh.RefreshStats
- addTotals(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- addTotals(IndexingStats) - Method in class org.elasticsearch.index.shard.IndexingStats
- addTotalsForClosingShard(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- addTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Adds a transport address that will be used to connect to.
- addTransportAddresses(TransportAddress...) - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Adds a list of transport addresses that will be used to connect to.
- addTypes(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- addTypes(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, String)
but the key will be computed automatically. - addUnboundedFrom(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addUnboundedFrom(String, String)
but the key will be generated automatically. - addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but there will be no upper bound. - addUnboundedFrom(String, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, ZonedDateTime)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, String)
but the key will be computed automatically. - addUnboundedTo(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addUnboundedTo(String, String)
but the key will be generated automatically. - addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but there will be no lower bound. - addUnboundedTo(String, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, ZonedDateTime)
but the key will be computed automatically. - addValidationError(String) - Method in exception org.elasticsearch.common.ValidationException
-
Add a new validation error to the accumulating validation errors
- addValidationError(String) - 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
. - 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
- AddVotingConfigExclusionsResponse - Class in org.elasticsearch.action.admin.cluster.configuration
-
A response to
AddVotingConfigExclusionsRequest
indicating that voting config exclusions have been added for the requested nodes and these nodes have been removed from the voting configuration. - AddVotingConfigExclusionsResponse() - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsResponse
- AddVotingConfigExclusionsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsResponse
- addWithKey(Object, IndexableField) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
Add fields so that they can later be fetched using
ParseContext.Document.getByKey(Object)
. - addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
-
Add an exact number of bytes, not checking for tripping the circuit breaker.
- addWithoutBreaking(long) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
-
Adjust the circuit breaker without tripping
- addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- addZen1Attribute(boolean, Settings.Builder) - Static method in class org.elasticsearch.cluster.coordination.Coordinator
- adjacencyMatrix(String, String, Map<String, QueryBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
AdjacencyMatrix
aggregation with the given name and separator - adjacencyMatrix(String, Map<String, QueryBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
AdjacencyMatrix
aggregation with the given name. - AdjacencyMatrix - Interface in org.elasticsearch.search.aggregations.bucket.adjacency
-
A multi bucket aggregation where the buckets are defined by a set of filters (a bucket is produced per filter plus a bucket for each non-empty filter intersection so A, B and A&B).
- AdjacencyMatrix.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.adjacency
-
A bucket associated with a specific filter or pair (identified by its key)
- AdjacencyMatrixAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(String, String, Map<String, QueryBuilder>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(String, Map<String, QueryBuilder>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Read from a stream.
- AdjacencyMatrixAggregationBuilder(AdjacencyMatrixAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregator - Class in org.elasticsearch.search.aggregations.bucket.adjacency
-
Aggregation for adjacency matrices.
- AdjacencyMatrixAggregator(String, AggregatorFactories, String, String[], Weight[], SearchContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- AdjacencyMatrixAggregator.KeyedFilter - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregatorFactory(String, List<AdjacencyMatrixAggregator.KeyedFilter>, String, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregatorFactory
- ADJUST_PURE_NEGATIVE_DEFAULT - Static variable in class org.elasticsearch.index.query.BoolQueryBuilder
- adjustPureNegative() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- adjustPureNegative(boolean) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
If a boolean query contains only negative ("must not") clauses should the BooleanQuery be enhanced with a
MatchAllDocsQuery
in order to act as a pure exclude. - admin() - Method in interface org.elasticsearch.client.Client
-
The admin client that can be used to perform administrative operations.
- admin() - Method in class org.elasticsearch.client.support.AbstractClient
- AdminClient - Interface in org.elasticsearch.client
-
Administrative actions/operations against the cluster or the indices.
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- ADVANCE - org.elasticsearch.search.profile.query.QueryTimingType
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.DocValueBits
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.GeoPointValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.HistogramValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Advance the iterator to exactly
target
and return whethertarget
has a value. - advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
- advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
- advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
- 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.
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.engine.Engine
-
A replica shard receives a new max_seq_no_of_updates from its primary shard, then calls this method to advance this marker to at least the given sequence number.
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.shard.IndexShard
-
A replica calls this method to advance the max_seq_no_of_updates marker of its engine to at least the max_seq_no_of_updates value (piggybacked in a replication request) that it receives from its primary before executing that replication request.
- advanceMaxSeqNoOfUpdatesOrDeletesOnPrimary(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- affixKeySetting(String, String, 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(Priority) - Method in enum org.elasticsearch.common.Priority
- after(Version) - Method in class org.elasticsearch.Version
- AFTER_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- afterBulk(long, BulkRequest, Throwable) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback after a failed execution of bulk request.
- afterBulk(long, BulkRequest, BulkResponse) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback after a successful execution of bulk request.
- afterClose() - Method in class org.elasticsearch.common.component.LifecycleListener
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- afterIndexCreated(IndexService) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index has been created.
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index has been removed.
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in class org.elasticsearch.search.SearchService
- afterIndexShardClosed(ShardId, IndexShard, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been closed.
- afterIndexShardCreated(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been created.
- afterIndexShardDeleted(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been deleted from disk.
- afterIndexShardStarted(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been started.
- afterInjection(I) - Method in interface org.elasticsearch.common.inject.spi.InjectionListener
-
Invoked by Guice after it injects the fields and methods of instance.
- afterKey() - Method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
-
Returns the last key in this aggregation.
- afterKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- afterKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- afterLoad(TermsEnum, long) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData.PerValueEstimator
-
Possibly adjust a circuit breaker after field data has been loaded, now that the actual amount of memory used by the field data is known
- afterLoad(TermsEnum, long) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
-
Adjust the circuit breaker now that terms have been loaded, getting the actual used either from the parameter (if estimation worked for the entire set), or from the TermsEnum if it has been wrapped in a RamAccountingTermsEnum.
- 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
- 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(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 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.
- AggregationExecutionException - Exception in org.elasticsearch.search.aggregations
-
Thrown when failing to execute an aggregation
- AggregationExecutionException(String) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationInitializationException - Exception in org.elasticsearch.search.aggregations
-
Thrown when failing to execute an aggregation
- AggregationInitializationException(String) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInitializationException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInitializationException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInspectionHelper - Class in org.elasticsearch.search.aggregations.support
-
Provides a set of static helpers to determine if a particular type of InternalAggregation "has a value" or not.
- AggregationInspectionHelper() - Constructor for class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- AggregationPath - Class in org.elasticsearch.search.aggregations.support
-
A path that can be used to sort/order buckets (in some multi-bucket aggregations, e.g.
- AggregationPath(List<AggregationPath.PathElement>) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationPath
- AggregationPath.PathElement - Class in org.elasticsearch.search.aggregations.support
- AggregationPhase - Class in org.elasticsearch.search.aggregations
-
Aggregation phase of a search request, used to collect aggregations
- AggregationPhase() - Constructor for class org.elasticsearch.search.aggregations.AggregationPhase
- AggregationProfileBreakdown - Class in org.elasticsearch.search.profile.aggregation
-
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 - 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 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 in org.elasticsearch.search.aggregations
-
Aggregation mode for sub aggregations.
- AggregatorBase - Class in org.elasticsearch.search.aggregations
-
Base implementation for concrete aggregators.
- AggregatorBase(String, AggregatorFactories, SearchContext, Aggregator, 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, QueryShardContext, 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.
- AggregatorSupplier - Interface in org.elasticsearch.search.aggregations.support
-
AggregatorSupplier
serves as a marker for what theValuesSourceRegistry
holds to construct aggregator instances. - AGGS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- aggsUsedForSorting - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- alias(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Set the alias this action is operating on.
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds an alias that will be associated with the index when it gets created
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds an alias that will be added when the index gets created.
- Alias - Class in org.elasticsearch.action.admin.indices.alias
-
Represents an alias, to be associated with an index
- Alias(String) - Constructor for class org.elasticsearch.action.admin.indices.alias.Alias
- Alias(AliasMetadata, IndexMetadata) - Constructor for class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- Alias(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.Alias
- ALIAS - 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.NewAliasValidator - Interface in org.elasticsearch.cluster.metadata
-
Validate a new alias.
- AliasAction.Remove - Class in org.elasticsearch.cluster.metadata
-
Operation to remove an alias from an index.
- AliasAction.RemoveIndex - Class in org.elasticsearch.cluster.metadata
-
Operation to remove an index.
- AliasActions(IndicesAliasesRequest.AliasActions.Type) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- AliasActions(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Read from a stream.
- aliases() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- aliases() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- aliases() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- aliases() - Method in interface org.elasticsearch.action.AliasesRequest
-
Returns the array of aliases that the action relates to
- aliases() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- aliases() - 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 - org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- ALIASES - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- aliasesExist(GetAliasesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check to existence of index aliases.
- aliasesExist(GetAliasesRequest, ActionListener<AliasesExistResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check the existence of specified index aliases.
- AliasesExistAction - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistRequestBuilder - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistRequestBuilder(ElasticsearchClient, AliasesExistAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistRequestBuilder
- AliasesExistResponse - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistResponse(boolean) - Constructor for class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- AliasesNotFoundException - Exception in org.elasticsearch.rest.action.admin.indices
- AliasesNotFoundException(String...) - Constructor for exception org.elasticsearch.rest.action.admin.indices.AliasesNotFoundException
- AliasesNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.rest.action.admin.indices.AliasesNotFoundException
- AliasesRequest - Interface in org.elasticsearch.action
-
Needs to be implemented by all
ActionRequest
subclasses that relate to one or more indices and one or more aliases. - aliasesVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- aliasesVersion(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- aliasFilter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- aliasFilter() - Method in class org.elasticsearch.search.internal.SearchContext
- AliasFilter - Class in org.elasticsearch.search.internal
-
Represents a
QueryBuilder
and a list of alias names that filters the builder is composed of. - AliasFilter(StreamInput) - Constructor for class org.elasticsearch.search.internal.AliasFilter
- AliasFilter(QueryBuilder, String...) - Constructor for class org.elasticsearch.search.internal.AliasFilter
- AliasFilterParsingException - Exception in org.elasticsearch.indices
- AliasFilterParsingException(StreamInput) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
- AliasFilterParsingException(Index, String, String, Throwable) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
- AliasMetadata - Class in org.elasticsearch.cluster.metadata
- AliasMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetadata
- AliasMetadata.Builder - Class in org.elasticsearch.cluster.metadata
- AliasValidator - Class in org.elasticsearch.cluster.metadata
-
Validator for an alias, to be used before adding an alias to the index metadata and make sure the alias is valid
- AliasValidator() - Constructor for class org.elasticsearch.cluster.metadata.AliasValidator
- all() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Sets to return all the data.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Sets to return all the data.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- all() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Include all data
- all() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Sets all flags to return all stats.
- all() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Sets all flags to return all stats.
- all() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
Sets all flags to return all stats.
- ALL - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- ALL - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- ALL - org.elasticsearch.index.analysis.AnalysisMode
-
AnalysisMode representing analysis components that can be used both at index and search time
- ALL - org.elasticsearch.index.query.RegexpFlag
-
Enables all available option flags
- ALL - org.elasticsearch.index.query.SimpleQueryStringFlag
- ALL - org.elasticsearch.index.search.MatchQuery.ZeroTermsQuery
- ALL - org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- ALL - Static variable in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- ALL - Static variable in class org.elasticsearch.action.support.ActiveShardCount
- ALL - Static variable in enum org.elasticsearch.cluster.block.ClusterBlockLevel
- ALL - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- ALL_ACTIONS - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- ALL_CONTEXTS - Static variable in class org.elasticsearch.cluster.metadata.Metadata
-
Indicates that this custom metadata will be returned as part of an API call, stored as a part of a snapshot global state, and will be persisted between node restarts
- ALL_CORE - Static variable in enum org.elasticsearch.search.aggregations.support.CoreValuesSourceType
-
List containing all members of the enumeration.
- ALL_FIELD_NAMES - Static variable in class org.elasticsearch.index.engine.TranslogLeafReader
- ALL_NODES - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- ALL_SNAPSHOTS - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- allActiveShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
Return GroupShardsIterator where each active shard routing has it's own shard iterator.
- allAssignedShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
Return GroupShardsIterator where each assigned shard routing has it's own shard iterator.
- AllCircuitBreakerStats - Class in org.elasticsearch.indices.breaker
-
Stats class encapsulating all of the different circuit breaker stats
- AllCircuitBreakerStats(StreamInput) - Constructor for class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- AllCircuitBreakerStats(CircuitBreakerStats[]) - Constructor for class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- AllFieldMapper - Class in org.elasticsearch.index.mapper
-
Noop mapper that ensures that mappings created in 6x that explicitly disable the _all field can be restored in this version.
- AllFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- AllFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- AllFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- allMetrics() - Static method in enum 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 in org.elasticsearch.persistent
- allocatedProcessors(Settings) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Returns the number of allocated processors.
- AllocateEmptyPrimaryAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned empty primary shard to a specific node.
- AllocateEmptyPrimaryAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
-
Creates a new
AllocateEmptyPrimaryAllocationCommand
- AllocateEmptyPrimaryAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
-
Read from a stream.
- AllocateEmptyPrimaryAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- AllocateReplicaAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned replica shard to a specific node.
- AllocateReplicaAllocationCommand(String, int, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
-
Creates a new
AllocateReplicaAllocationCommand
- AllocateReplicaAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
-
Read from a stream.
- AllocateReplicaAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- AllocateStalePrimaryAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned stale primary shard to a specific node.
- AllocateStalePrimaryAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
-
Creates a new
AllocateStalePrimaryAllocationCommand
- AllocateStalePrimaryAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
-
Read from a stream.
- AllocateStalePrimaryAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- allocateUnassigned(ShardRouting, RoutingAllocation, ExistingShardsAllocator.UnassignedAllocationHandler) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Allocate any unassigned shards in the given
RoutingAllocation
for which thisExistingShardsAllocator
is responsible. - allocateUnassigned(ShardRouting, RoutingAllocation, ExistingShardsAllocator.UnassignedAllocationHandler) - Method in class org.elasticsearch.gateway.BaseGatewayShardAllocator
-
Allocate an unassigned shard to nodes (if any) where valid copies of the shard already exist.
- allocateUnassigned(ShardRouting, RoutingAllocation, ExistingShardsAllocator.UnassignedAllocationHandler) - Method in class org.elasticsearch.gateway.GatewayAllocator
- AllocateUnassignedDecision - Class in org.elasticsearch.cluster.routing.allocation
-
Represents the allocation decision by an allocator for an unassigned shard.
- AllocateUnassignedDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- ALLOCATION_DELAYED - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The allocation decision has been delayed waiting for a replica with a shard copy that left the cluster to rejoin.
- ALLOCATION_FAILED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of a failed allocation of the shard.
- 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 in org.elasticsearch.cluster.routing.allocation
-
An enum which represents the various decision types that can be taken by the allocators and deciders for allocating a shard to a node.
- allocationExplain(ClusterAllocationExplainRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- allocationExplain(ClusterAllocationExplainRequest, ActionListener<ClusterAllocationExplainResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- allocationId - Variable in class org.elasticsearch.index.engine.Engine
- allocationId - Variable in class org.elasticsearch.index.shard.ShardStateMetadata
- allocationId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
An id that uniquely identifies an allocation.
- allocationId() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- AllocationId - Class in org.elasticsearch.cluster.routing
-
Uniquely identifies an allocation.
- AllocationService - Class in org.elasticsearch.cluster.routing.allocation
-
This service manages the node allocation of a cluster.
- AllocationService(AllocationDeciders, ShardsAllocator, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService(AllocationDeciders, GatewayAllocator, ShardsAllocator, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService.CommandsResult - Class in org.elasticsearch.cluster.routing.allocation
-
this class is used to describe results of applying a set of
AllocationCommand
- 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 - org.elasticsearch.action.support.IndicesOptions.Option
- ALLOW_NONE - Static variable in class org.elasticsearch.script.ScriptService
- ALLOW_UNMAPPED - Static variable in class org.elasticsearch.index.IndexSettings
- allowAliasesToMultipleIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
- ALLOWED_CONTENT_FIELD_NAMES - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper
- ALLOWED_INTERVALS - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- allowedRequestHeaders() - Method in class org.elasticsearch.http.CorsHandler.Config
- allowedRequestMethods() - Method in class org.elasticsearch.http.CorsHandler.Config
- allowExpensiveQueries() - Method in class org.elasticsearch.index.query.QueryShardContext
- 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
- 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.
- 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
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel.EWMAModelBuilder
-
Alpha controls the smoothing of the data.
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
-
Alpha controls the smoothing of the data.
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
-
Alpha controls the smoothing of the data.
- alreadyClosed() - Method in class org.elasticsearch.search.internal.SearchContext
- ALTERNATIVE_NAME - Static variable in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- ALWAYS - org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Re-balancing is allowed once a shard replication group is active
- ALWAYS - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Suggest any matching suggest terms based on tokens in the suggest text.
- ALWAYS - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- alwaysEnforce() - Method in interface org.elasticsearch.bootstrap.BootstrapCheck
- ambiguousTypeConversion(String, Object, TypeLiteral<?>, MatcherAndConverter, MatcherAndConverter) - Method in class org.elasticsearch.common.inject.internal.Errors
- Analysis - Class in org.elasticsearch.index.analysis
- Analysis() - Constructor for class org.elasticsearch.index.analysis.Analysis
- analysisMode() - Method in class org.elasticsearch.index.analysis.AnalyzerComponents
- AnalysisMode - Enum in org.elasticsearch.index.analysis
-
Enum representing the mode in which token filters and analyzers are allowed to operate.
- AnalysisModule - Class in org.elasticsearch.indices.analysis
-
Sets up
AnalysisRegistry
. - AnalysisModule(Environment, List<AnalysisPlugin>) - Constructor for class org.elasticsearch.indices.analysis.AnalysisModule
- AnalysisModule.AnalysisProvider<T> - Interface in org.elasticsearch.indices.analysis
-
The basic factory interface for analysis components.
- AnalysisPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's analysis functionality. - analysisRegistry - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provide analyzer support
- AnalysisRegistry - Class in org.elasticsearch.index.analysis
-
An internal registry for tokenizer, token filter, char filter and analyzer.
- AnalysisRegistry(Environment, Map<String, AnalysisModule.AnalysisProvider<CharFilterFactory>>, Map<String, AnalysisModule.AnalysisProvider<TokenFilterFactory>>, Map<String, AnalysisModule.AnalysisProvider<TokenizerFactory>>, Map<String, AnalysisModule.AnalysisProvider<AnalyzerProvider<?>>>, Map<String, AnalysisModule.AnalysisProvider<AnalyzerProvider<?>>>, Map<String, PreConfiguredCharFilter>, Map<String, PreConfiguredTokenFilter>, Map<String, PreConfiguredTokenizer>, Map<String, PreBuiltAnalyzerProviderFactory>) - Constructor for class org.elasticsearch.index.analysis.AnalysisRegistry
- 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.Request - Class in org.elasticsearch.action.admin.indices.analyze
-
A request to analyze a text associated with a specific index.
- AnalyzeAction.Response - Class in org.elasticsearch.action.admin.indices.analyze
- analyzeGraph(TokenStream) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzer - Variable in class org.elasticsearch.index.search.MatchQuery
- analyzer - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- analyzer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- analyzer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- analyzer() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
The actual analyzer.
- analyzer() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- analyzer() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- analyzer() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- analyzer() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string.
- analyzer() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the analyzer to use for the query.
- analyzer() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the
SuggestionBuilder.analyzer()
parameter - analyzer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- analyzer(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
The analyzer that will be used to analyze the text.
- analyzer(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string.
- analyzer(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specify an analyzer to use for the query.
- analyzer(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Sets the analyzer to analyse to suggest text with.
- ANALYZER - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- ANALYZER - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- ANALYZER_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- ANALYZER_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- AnalyzerComponents - Class in org.elasticsearch.index.analysis
-
A class that groups analysis components necessary to produce a custom analyzer.
- AnalyzerComponentsProvider - Interface in org.elasticsearch.index.analysis
-
Analyzers that provide access to their token filters should implement this
- AnalyzeRequestBuilder - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeRequestBuilder(ElasticsearchClient, AnalyzeAction) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
- AnalyzeRequestBuilder(ElasticsearchClient, AnalyzeAction, String, String...) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
- AnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Interface in org.elasticsearch.index.analysis
- analyzers() - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
- AnalyzerScope - Enum in org.elasticsearch.index.analysis
- analyzeSynonyms(TokenStream, int, boolean) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzeTerm(TokenStream) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzeTerms(TokenStream) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzeText(String, int, boolean) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzeText(CachingTokenFilter, int, boolean) - Method in class org.elasticsearch.index.query.IntervalBuilder
- AnalyzeToken(String, int, int, int, int, String, Map<String, Object>) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- AnalyzeTokenList(String, AnalyzeAction.AnalyzeToken[]) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeTokenList
- analyzeWildcard() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- analyzeWildcard() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns whether wildcards should by analyzed.
- analyzeWildcard() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Returns whether to analyze wildcards.
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specifies whether wildcards should be analyzed.
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Specifies whether to analyze wildcards.
- analyzeWildcard(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set to
true
to enable analysis on wildcard and prefix queries. - and(Matcher<? super T>) - Method in class org.elasticsearch.common.inject.matcher.AbstractMatcher
- and(Matcher<? super T>) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
-
Returns a new matcher which returns
true
if both this and the given matcher returntrue
. - AND - org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
- AND - org.elasticsearch.index.query.Operator
- AND - org.elasticsearch.index.query.SimpleQueryStringFlag
- AnnotatedBindingBuilder<T> - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - AnnotatedConstantBindingBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - AnnotatedElementBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedConstantBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedElementBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- annotatedWith(Annotation) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
- annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedConstantBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedElementBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- annotatedWith(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
- annotatedWithInternal(Annotation) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
Sets the binding to a copy with the specified annotation on the bound key
- annotatedWithInternal(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
Sets the binding to a copy with the specified annotation on the bound key
- ANNOTATION_ALREADY_SPECIFIED - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- Annotations - Class in org.elasticsearch.common.inject.internal
-
Annotation utilities.
- Annotations() - Constructor for class org.elasticsearch.common.inject.internal.Annotations
- any() - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches any input.
- ANY_ORIGIN - Static variable in class org.elasticsearch.http.CorsHandler
- anySet() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- ANYSTRING - org.elasticsearch.index.query.RegexpFlag
-
Enables any string expression:
@
- API - org.elasticsearch.cluster.metadata.Metadata.XContentContext
- API_AND_GATEWAY - Static variable in class org.elasticsearch.cluster.metadata.Metadata
-
Indicates that this custom metadata will be returned as part of an API call and will be persisted between node restarts, but will not be a part of a snapshot global state
- API_AND_SNAPSHOT - Static variable in class org.elasticsearch.cluster.metadata.Metadata
-
Indicates that this custom metadata will be returned as part of an API call and stored as a part of a snapshot global state, but will not be persisted between node restarts
- API_ONLY - Static variable in class org.elasticsearch.cluster.metadata.Metadata
-
Indicates that this custom metadata will be returned as part of an API call but will not be persisted
- append(Path, Path, int) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Appends the path to the given base and strips N elements off the path if strip is > 0.
- appendElement(T[], T) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- appendFieldValue(String, Object) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendFieldValue(TemplateScript.Factory, ValueSource) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendThreadPoolExecutorDetails(StringBuilder) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
-
Append details about this thread pool to the specified
StringBuilder
. - appendThreadPoolExecutorDetails(StringBuilder) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- applicationMayFail() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- apply(double) - Method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- apply(long) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.GlobalOrdLookupFunction
- apply(String, ActionRequest, ActionListener<?>) - Method in class org.elasticsearch.action.support.ActionFilter.Simple
-
Applies this filter and returns
true
if the execution chain should proceed, orfalse
if it should be aborted since the filter already handled the request and called the given listener. - apply(DiffableStringMap) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- apply(Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
- apply(ImmutableOpenMap<K, T>) - Method in class org.elasticsearch.cluster.DiffableUtils.ImmutableOpenMapDiff
- apply(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Updates this updaters value if it has changed.
- apply(Task, String, Request, ActionListener<Response>, ActionFilterChain<Request, Response>) - Method in interface org.elasticsearch.action.support.ActionFilter
-
Enables filtering the execution of an action on the request side, either by sending a response through the
ActionListener
or by continuing the execution through the givenchain
- apply(Task, String, Request, ActionListener<Response>, ActionFilterChain<Request, Response>) - Method in class org.elasticsearch.action.support.ActionFilter.Simple
- apply(S, T, U) - Method in interface org.elasticsearch.common.TriConsumer
-
Applies this function to the given arguments.
- apply(S, T, U) - Method in interface org.elasticsearch.common.TriFunction
-
Applies this function to the given arguments.
- apply(T) - Method in interface org.elasticsearch.cluster.Diff
-
Applies difference to the specified part and returns the resulted part
- apply(T, Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Applies the given value to the updater.
- apply(T, U) - Method in interface org.elasticsearch.common.CheckedBiFunction
- apply(T, U, ActionListener<C>) - Method in interface org.elasticsearch.common.AsyncBiFunction
- 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.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
- 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 - org.elasticsearch.common.geo.GeoDistance
- arcDistance(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- arcDistance(double, double, double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Return the distance (in meters) between 2 lat,lon geo points using the haversine method implemented by lucene
- arcDistanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- ARCHIVED_SETTINGS_PREFIX - Static variable in class org.elasticsearch.common.settings.AbstractScopedSettings
- archiveUnknownOrInvalidSettings(Settings, Consumer<Map.Entry<String, String>>, BiConsumer<Map.Entry<String, String>, IllegalArgumentException>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Archives invalid or unknown settings.
- areAllConsistent() - Method in class org.elasticsearch.common.settings.ConsistentSettingsService
-
Verifies that the hashes of consistent secure settings in the latest
ClusterState
verify for the values of those same settings on the local node. - areValuesSourcesEmpty() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- array() - Method in class org.elasticsearch.common.bytes.BytesArray
- arrayAsArrayList(E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- arrayOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns an array type whose elements are all instances of
componentType
. - arrayToCommaDelimitedString(Object[]) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a String array as a CSV String.
- arrayToDelimitedString(Object[], String) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a String array as a delimited (e.g.
- arrayToDelimitedString(Object[], String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
- ArrayUtils - Class in org.elasticsearch.common.util
- 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 - org.elasticsearch.search.sort.SortOrder
-
Ascending order.
- asCopy() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns a copy of the current
IndexShardSnapshotStatus
. - asDistance() - Method in class org.elasticsearch.common.unit.Fuzziness
- asDistance(String) - Method in class org.elasticsearch.common.unit.Fuzziness
- asEagerSingleton() - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
Instructs the
Injector
to eagerly initialize this singleton-scoped binding upon creation. - asEagerSingleton() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- asFloat() - Method in class org.elasticsearch.common.unit.Fuzziness
- asJsonArray(Stream<String>) - Static method in class org.elasticsearch.common.logging.ESLogMessage
- asList() - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Returns the it as a non null list.
- asList() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
The list of
Aggregation
s. - asMap() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- asMap() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- asMap() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Returns the
Aggregation
s keyed by aggregation name. - asMap() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- 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.
- 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 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 org.elasticsearch.transport.Transports
- assertPrimaryCanOptimizeAddDocument(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- assertPrimaryIncomingSequenceNumber(Engine.Operation.Origin, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- assertRetentionLeasesPersisted() - Method in class org.elasticsearch.index.shard.IndexShard
- assertRetentionLeasesPersisted(Path) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
- assertShardStats(RoutingNodes) - Static method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Calculates RoutingNodes statistics by iterating over all
ShardRouting
s in the cluster to ensure the book-keeping is correct. - assertSnapshotOrGenericThread() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- assertTransportThread() - Static method in enum org.elasticsearch.transport.Transports
- assertZValue(boolean, double) - Static method in class org.elasticsearch.common.geo.GeoPoint
- assignedShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of assigned shards, including relocation targets - assignedShards(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns all shards that are not in the state UNASSIGNED with the same shard ID as the given shard.
- assignedToNode() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
iff this shard is assigned to a node ie. - Assignment(String, String) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Assignment
- ASSIGNMENT_PARSER - Static variable in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- AssignmentDecision - Class in org.elasticsearch.persistent.decider
-
AssignmentDecision
represents the decision made during the process of assigning a persistent task to a node of the cluster. - AssignmentDecision(AssignmentDecision.Type, String) - Constructor for class org.elasticsearch.persistent.decider.AssignmentDecision
- AssignmentDecision.Type - Enum in org.elasticsearch.persistent.decider
- Assisted - Annotation Type in org.elasticsearch.common.inject.assistedinject
-
Annotates an injected parameter or field whose value comes from an argument to a factory method.
- AssistedInject - Annotation Type in org.elasticsearch.common.inject.assistedinject
-
Deprecated.
FactoryProvider
now works better with the standard @Inject annotation. When using that annotation, parameters are matched by name and type rather than by position. In addition, values that use the standard @Inject constructor annotation are eligible for method interception. - associateIndexWithNewTranslog(String) - Method in class org.elasticsearch.index.store.Store
-
Force bakes the given translog generation as recovery information in the lucene index.
- asString() - Method in class org.elasticsearch.common.unit.Fuzziness
- asTuple() - Method in class org.elasticsearch.script.ScriptCache.CompilationRate
- ASYNC - org.elasticsearch.index.translog.Translog.Durability
-
Async durability - translogs are synced based on a time interval.
- AsyncAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- AsyncBiFunction<T,U,C> - Interface in org.elasticsearch.common
-
A
BiFunction
-like interface designed to be used with asynchronous executions. - AsyncBroadcastAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- AsyncIOProcessor<Item> - Class in org.elasticsearch.common.util.concurrent
-
This async IO processor allows to batch IO operations and have a single writer processing the write operations.
- AsyncIOProcessor(Logger, int, ThreadContext) - Constructor for class org.elasticsearch.common.util.concurrent.AsyncIOProcessor
- AsyncShardFetch<T extends BaseNodeResponse> - Class in org.elasticsearch.gateway
-
Allows to asynchronously fetch shard related data from other nodes for allocation, without blocking the cluster update thread.
- AsyncShardFetch(Logger, String, ShardId, 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
- 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.rest.action.admin.indices.RestAnalyzeAction.Fields
- AUTO - Static variable in class org.elasticsearch.common.unit.Fuzziness
- AUTO_CREATE_INDEX_SETTING - Static variable in class org.elasticsearch.action.support.AutoCreateIndex
- AUTO_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_INDEX_JTS_GEOMETRY - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- AUTO_RELEASE_INDEX_ENABLED_KEY - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- AUTO_SLICES - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AUTO_SLICES_VALUE - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AUTO_THROTTLE_SETTING - Static variable in class org.elasticsearch.index.MergeSchedulerConfig
- AUTO_VALIDATE_JTS_GEOMETRY - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- AutoCreateAction - Class in org.elasticsearch.action.admin.indices.create
-
Api that auto creates an index 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) - 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[], QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - 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.MatchQuery
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- AutoIdHandler(Supplier<DiscoveryNodes>) - Constructor for class org.elasticsearch.rest.action.document.RestIndexAction.AutoIdHandler
- 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.ByteBufferStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.StreamInput
- available() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
- availableCodecs() - Method in class org.elasticsearch.index.codec.CodecService
-
Returns all registered available codec names
- availableIndexFolders() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all folder names in ${data.paths}/nodes/{node.id}/indices folder
- availableIndexFolders(Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns folder names in ${data.paths}/nodes/{node.id}/indices folder that don't match the given predicate.
- availableIndexFoldersForPath(NodeEnvironment.NodePath) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return all directory names in the nodes/{node.id}/indices directory for the given node path.
- availableIndexFoldersForPath(NodeEnvironment.NodePath, Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return directory names in the nodes/{node.id}/indices directory for the given node path that don't match the given predicate.
- availableShardPaths(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all shard paths excluding custom shard path.
- availableShards() - Method in class org.elasticsearch.indices.IndexingMemoryController
- avg - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- avg - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- avg(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Avg
aggregation with the given name. - Avg - org.elasticsearch.search.rescore.QueryRescoreMode
- Avg - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes the average of the values in the current bucket.
- AVG - org.elasticsearch.common.lucene.search.function.CombineFunction
- AVG - org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- AVG - org.elasticsearch.search.MultiValueMode
-
Pick the average of all the values.
- AVG - org.elasticsearch.search.sort.SortMode
-
Use the average of all values as sort value.
- AvgAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- AvgAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- AvgAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
-
Read from a stream.
- AvgAggregationBuilder(AvgAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- avgBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- AvgBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- AvgBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
- AvgBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
-
Read from a stream.
- AvgBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- AvgBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregator
-
Read from a stream.
- avgShardsPerNode() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Returns the global average of shards per node
- avgShardsPerNode(String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Returns the average of shards per node for the given index
- awaitAllNodes(TimeValue) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Allows to wait for all non master nodes to reply to the publish event up to a timeout
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.indices.IndicesService
-
Wait for this
IndicesService
to be effectively closed. - awaitClose(long, TimeUnit) - Method in class org.elasticsearch.node.Node
-
Wait for this node to be effectively closed.
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.node.NodeService
-
Wait for the node to be effectively closed.
- AWAITING_INFO - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Waiting on getting shard data from all nodes before making a decision about where to allocate the shard.
- awaitShardSearchActive(Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Registers the given listener and invokes it once the shard is active again and all pending refresh translog location has been refreshed.
- awaitTermination() - Method in interface org.elasticsearch.index.IndexWarmer.TerminationHandle
-
Wait until execution of the warm-up action completes.
- awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.threadpool.ThreadPool
- awaitTermination(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in interface org.elasticsearch.threadpool.Scheduler
- AwarenessAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
controls shard allocation based onawareness
key-value pairs defined in the node configuration. - AwarenessAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
B
- BACKGROUND_IS_SUPERSET - Static variable in class org.elasticsearch.search.aggregations.bucket.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
- BAD_GATEWAY - org.elasticsearch.rest.RestStatus
-
The server, while acting as a gateway or proxy, received an invalid response from the upstream server it accessed in attempting to fulfill the request.
- BAD_REQUEST - org.elasticsearch.rest.RestStatus
-
The request could not be understood by the server due to malformed syntax.
- BALANCED_ALLOCATOR - Static variable in class org.elasticsearch.cluster.ClusterModule
- BalancedShardsAllocator - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
The
BalancedShardsAllocator
re-balances the nodes allocations within an cluster based on aBalancedShardsAllocator.WeightFunction
. - BalancedShardsAllocator(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator.Balancer - Class in org.elasticsearch.cluster.routing.allocation.allocator
- 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
- 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 - org.elasticsearch.common.time.FormatNames
- BASIC_DATE_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE - org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- BASIC_T_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_T_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- BASIC_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE - org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- basicDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a full date as four digit year, two digit month of year, and two digit day of month (yyyyMMdd).
- basicDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic date and time, separated by a 'T' (yyyyMMdd'T'HHmmss.SSSZ).
- basicDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic date and time without millis, separated by a 'T' (yyyyMMdd'T'HHmmssZ).
- BasicHit(String, String, String, long) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- basicOrdinalDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date, using a four digit year and three digit dayOfYear (yyyyDDD).
- basicOrdinalDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time, using a four digit year and three digit dayOfYear (yyyyDDD'T'HHmmss.SSSZ).
- basicOrdinalDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time without millis, using a four digit year and three digit dayOfYear (yyyyDDD'T'HHmmssZ).
- BasicReplicationRequest - Class in org.elasticsearch.action.support.replication
-
A replication request that has no more information than ReplicationRequest.
- BasicReplicationRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.BasicReplicationRequest
- BasicReplicationRequest(ShardId) - Constructor for class org.elasticsearch.action.support.replication.BasicReplicationRequest
-
Creates a new request with resolved shard id
- basicTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit millis, and time zone offset (HHmmss.SSSZ).
- basicTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset (HHmmssZ).
- basicTTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit millis, and time zone offset prefixed by 'T' ('T'HHmmss.SSSZ).
- basicTTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset prefixed by 'T' ('T'HHmmssZ).
- basicWeekDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a full date as four digit weekyear, two digit week of weekyear, and one digit day of week (xxxx'W'wwe).
- basicWeekDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic weekyear date and time, separated by a 'T' (xxxx'W'wwe'T'HHmmss.SSSZ).
- basicWeekDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic weekyear date and time without millis, separated by a 'T' (xxxx'W'wwe'T'HHmmssZ).
- BatchedRerouteService - Class in org.elasticsearch.cluster.routing
-
A
BatchedRerouteService
is aRerouteService
that batches together reroute requests to avoid unnecessary extra reroutes. - BatchedRerouteService(ClusterService, BiFunction<ClusterState, String, ClusterState>) - Constructor for class org.elasticsearch.cluster.routing.BatchedRerouteService
- BatchedTask(Priority, String, Object, Object) - Constructor for class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- BATCHES_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- batchingKey - Variable in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
-
the object that is used as batching key
- bdd - Variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- becomeMasterAndTrimConflictingNodes(ClusterState, List<JoinTaskExecutor.Task>) - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
- before(Version) - Method in class org.elasticsearch.Version
- 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
- beforeBuildingBuckets(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Hook to allow taking an action before building buckets.
- beforeBuildingBuckets(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- beforeBulk(long, BulkRequest) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback before the bulk is executed.
- beforeClose() - Method in class org.elasticsearch.common.component.LifecycleListener
- beforeExecute(Thread, Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- 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.
- beforeIndexRemoved(IndexService, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index get closed.
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets closed.
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.snapshots.SnapshotShardsService
- beforeIndexShardCreated(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets created.
- beforeIndexShardDeleted(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets deleted from disk Note: this method is only executed on the first attempt of deleting the shard.
- 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.AbstractIndexFieldData.PerValueEstimator
-
Execute any pre-loading estimations for the terms.
- beforeLoad(Terms) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
-
Determine whether the BlockTreeTermsReader.FieldReader can be used for estimating the field data, adding the estimate to the circuit breaker if it can, otherwise wrapping the terms in a RamAccountingTermsEnum to be estimated on a per-term basis.
- 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.
- beforeStart() - Method in class org.elasticsearch.common.component.LifecycleListener
- beforeStop() - Method in class org.elasticsearch.common.component.LifecycleListener
- BEST_COMPRESSION_CODEC - Static variable in class org.elasticsearch.index.codec.CodecService
- BEST_FIELDS - org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the best matching boolean field as main score and uses a tie-breaker to adjust the score based on remaining field matches
- BestBucketsDeferringCollector - Class in org.elasticsearch.search.aggregations.bucket
-
A specialization of
DeferringBucketCollector
that collects all matches and then is able to replay a given subset of buckets which represent the survivors from a pruning process performed by the aggregator that owns this collector. - BestBucketsDeferringCollector(SearchContext, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Sole constructor.
- BestDocsDeferringCollector - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
A specialization of
DeferringBucketCollector
that collects all matches and then replays only the top scoring documents to child aggregations. - beta(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
-
Equivalent to
alpha
, but controls the smoothing of the trend instead of the data - beta(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
-
Equivalent to
alpha
, but controls the smoothing of the trend instead of the data - 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.search.sort.BucketedSort
- bigArrays() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Return the
BigArrays
instance for this node. - bigArrays() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- bigArrays() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- bigArrays() - Method in class org.elasticsearch.search.internal.SearchContext
- BigArrays - Class in org.elasticsearch.common.util
-
Utility class to work with arrays.
- BigArrays(PageCacheRecycler, CircuitBreakerService, String) - Constructor for class org.elasticsearch.common.util.BigArrays
- BigArrays(PageCacheRecycler, CircuitBreakerService, String, boolean) - Constructor for class org.elasticsearch.common.util.BigArrays
- BigArrays.DoubleBinarySearcher - Class in org.elasticsearch.common.util
- bigQuery() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- bigQuery() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- BINARY - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BINARY - Static variable in interface org.elasticsearch.search.DocValueFormat
- BinaryDocValuesRangeQuery - Class in org.apache.lucene.queries
- BinaryDocValuesRangeQuery(String, BinaryDocValuesRangeQuery.QueryType, RangeType.LengthType, BytesRef, BytesRef, Object, Object) - Constructor for class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- BinaryDocValuesRangeQuery.QueryType - Enum in org.apache.lucene.queries
- 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.IdOnlyFieldVisitor
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- 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
- BinaryFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- BinaryFieldType(String) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- BinaryFieldType(String, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- BinaryIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- BinaryIndexFieldData(Index, 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, SearchContext, 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, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- binarySearch(double[], double, double) - Static method in class org.elasticsearch.common.util.ArrayUtils
-
Return the index of
value
inarray
, or-1
if there is no such index. - 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 Type in org.elasticsearch.common.inject
-
Annotates annotations which are used for binding.
- BindingBuilder<T> - Class in org.elasticsearch.common.inject.internal
-
Bind a non-constant key.
- BindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.BindingBuilder
- BindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- BindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.BindingImpl
- BindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.BindingImpl
- BindingScopingVisitor<V> - Interface in org.elasticsearch.common.inject.spi
-
Visits each of the strategies used to scope an injection.
- BindingTargetVisitor<T,V> - Interface in org.elasticsearch.common.inject.spi
-
Visits each of the strategies used to find an instance to satisfy an injection.
- bindingToProvider() - Method in class org.elasticsearch.common.inject.internal.Errors
- bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in class org.elasticsearch.common.inject.AbstractModule
- bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in interface org.elasticsearch.common.inject.Binder
-
Registers a listener for injectable types.
- bindProperties(Binder, Map<String, String>) - Static method in class org.elasticsearch.common.inject.name.Names
-
Creates a constant binding to
@Named(key)
for each entry inproperties
. - bindProperties(Binder, Properties) - Static method in class org.elasticsearch.common.inject.name.Names
-
Creates a constant binding to
@Named(key)
for each property. - bindScope(Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.common.inject.AbstractModule
- bindScope(Class<? extends Annotation>, Scope) - Method in interface org.elasticsearch.common.inject.Binder
-
Binds a scope to an annotation.
- bindServer() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- bindServer(TcpTransport.ProfileSettings) - Method in class org.elasticsearch.transport.TcpTransport
- BindTransportException - Exception in org.elasticsearch.transport
- BindTransportException(String) - Constructor for exception org.elasticsearch.transport.BindTransportException
- BindTransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.BindTransportException
- BindTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.BindTransportException
- binFile() - Method in class org.elasticsearch.env.Environment
- BitArray - Class in org.elasticsearch.common.util
- BitArray(int, BigArrays) - Constructor for class org.elasticsearch.common.util.BitArray
-
Create the BitArray.
- bitsetFilter(Query) - Method in class org.elasticsearch.index.query.QueryShardContext
- bitsetFilterCache() - Method in class org.elasticsearch.index.cache.IndexCache
-
Return the
BitsetFilterCache
for this index. - bitsetFilterCache() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- bitsetFilterCache() - Method in class org.elasticsearch.search.internal.SearchContext
- BitsetFilterCache - Class in org.elasticsearch.index.cache.bitset
-
This is a cache for
BitDocIdSet
based filters and is unbounded by size or time. - BitsetFilterCache(IndexSettings, BitsetFilterCache.Listener) - Constructor for class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- BitsetFilterCache.Listener - Interface in org.elasticsearch.index.cache.bitset
-
A listener interface that is executed for each onCache / onRemoval event
- BitsetFilterCache.Value - Class in org.elasticsearch.index.cache.bitset
- bitsetFromQuery(Query, LeafReaderContext) - Static method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- blend(TermStates[], int, IndexReader) - Method in class org.apache.lucene.queries.BlendedTermQuery
- BlendedTermQuery - Class in org.apache.lucene.queries
-
BlendedTermQuery can be used to unify term statistics across one or more fields in the index.
- BlendedTermQuery(Term[], float[]) - Constructor for class org.apache.lucene.queries.BlendedTermQuery
- blobContainer() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
maintains single lazy instance of
BlobContainer
- blobContainer(BlobPath) - Method in interface org.elasticsearch.common.blobstore.BlobStore
-
Get a blob container instance for storing blobs at the given
BlobPath
. - blobContainer(BlobPath) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- BlobContainer - Interface in org.elasticsearch.common.blobstore
-
An interface for managing a repository of blob entries, where each blob entry is just a named group of bytes.
- 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.
- BlobPath() - Constructor for class org.elasticsearch.common.blobstore.BlobPath
- blobs() - Method in class org.elasticsearch.repositories.RepositoryCleanupResult
- blobsDeleted() - Method in class org.elasticsearch.common.blobstore.DeleteResult
- blobStore - Variable in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- blobStore() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Maintains single lazy instance of
BlobStore
. - BlobStore - Interface in org.elasticsearch.common.blobstore
-
An interface for storing blobs.
- BlobStoreException - Exception in org.elasticsearch.common.blobstore
- BlobStoreException(String) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreException(String, Throwable) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreException(StreamInput) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreIndexShardSnapshot - Class in org.elasticsearch.index.snapshots.blobstore
-
Shard snapshot metadata
- BlobStoreIndexShardSnapshot(String, long, List<BlobStoreIndexShardSnapshot.FileInfo>, long, long, int, long) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Constructs new shard snapshot metadata from snapshot metadata
- BlobStoreIndexShardSnapshot.FileInfo - Class in org.elasticsearch.index.snapshots.blobstore
-
Information about snapshotted file
- BlobStoreIndexShardSnapshots - Class in org.elasticsearch.index.snapshots.blobstore
-
Contains information about all snapshots for the given shard in repository
- BlobStoreIndexShardSnapshots(List<SnapshotFiles>) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
- BlobStoreRepository - Class in org.elasticsearch.repositories.blobstore
-
BlobStore - based implementation of Snapshot Repository
- BlobStoreRepository(RepositoryMetadata, boolean, NamedXContentRegistry, ClusterService, RecoverySettings) - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Constructs new BlobStoreRepository
- blockingAllowed() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- BlockingClusterStatePublishResponseHandler - Class in org.elasticsearch.discovery
-
Handles responses obtained when publishing a new cluster state from master to all non master nodes.
- BlockingClusterStatePublishResponseHandler(Set<DiscoveryNode>) - Constructor for class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Creates a new BlockingClusterStatePublishResponseHandler
- blockOnFutures(List<ActionFuture<Void>>) - Static method in interface org.elasticsearch.common.network.CloseableChannel
- blocks() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- blocks() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- blocks() - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- blocks() - Method in class org.elasticsearch.cluster.ClusterState
- blocks(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- blocks(ClusterBlocks) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- blocks(ClusterBlocks) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- blocks(ClusterBlocks.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- BLOCKS - org.elasticsearch.cluster.ClusterState.Metric
- blocksChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the cluster level blocks have changed between cluster states. - BOOL_PREFIX - org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the sum of the matching boolean fields to score the query
- BOOLEAN - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- BOOLEAN - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BOOLEAN - org.elasticsearch.index.search.MatchQuery.Type
-
The text is analyzed and terms are added to a boolean query.
- BOOLEAN - org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- BOOLEAN - org.elasticsearch.search.aggregations.support.ValueType
- BOOLEAN - Static variable in interface org.elasticsearch.search.DocValueFormat
- BOOLEAN_PREFIX - org.elasticsearch.index.search.MatchQuery.Type
-
The text is analyzed, terms are added to a boolean query with the last term acting as a prefix.
- BooleanFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper for boolean fields.
- BooleanFieldMapper(String, MappedFieldType, 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.TypeParser - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.Values - Class in org.elasticsearch.index.mapper
- BooleanFieldType(String) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- BooleanFieldType(String, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- Booleans(SortedNumericDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- boolParam(String, boolean, Function<FieldMapper, Boolean>, boolean) - Static method in class org.elasticsearch.index.mapper.ParametrizedFieldMapper.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.mapper.FieldMapper.Builder
- boost - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- boost - Variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- boost - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- boost() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- boost() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Returns the boost for this query.
- boost() - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Returns the boost for this query.
- boost() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- boost(float) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- boost(float) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Sets the boost for this query.
- boost(float) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Sets the boost for this query.
- boost(float) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- BOOST_FIELD - Static variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- BOOST_MODE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- boostingQuery(QueryBuilder, QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
The BoostingQuery class can be used to effectively demote results that match a given query.
- BoostingQueryBuilder - Class in org.elasticsearch.index.query
-
The BoostingQuery class can be used to effectively demote results that match a given query.
- BoostingQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.BoostingQueryBuilder
-
Read from a stream.
- BoostingQueryBuilder(QueryBuilder, QueryBuilder) - Constructor for class org.elasticsearch.index.query.BoostingQueryBuilder
-
Create a new
BoostingQueryBuilder
- boostMode() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the boost mode, meaning how the combined result of score functions will influence the final score together with the sub query score.
- boostMode(CombineFunction) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Boost mode defines how the combined result of score functions will influence the final score together with the sub query score.
- boostTerms() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- boostTerms(float) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the boost factor to use when boosting terms.
- BootstrapCheck - Interface in org.elasticsearch.bootstrap
-
Encapsulates a bootstrap check.
- BootstrapCheck.BootstrapCheckResult - Class in org.elasticsearch.bootstrap
-
Encapsulate the result of a bootstrap check.
- BootstrapContext - Class in org.elasticsearch.bootstrap
-
Context that is passed to every bootstrap check to make decisions on.
- BootstrapContext(Environment, Metadata) - Constructor for class org.elasticsearch.bootstrap.BootstrapContext
- BootstrapInfo - Class in org.elasticsearch.bootstrap
-
Exposes system startup information
- bootstrapNewHistory() - Method in class org.elasticsearch.index.store.Store
-
Marks an existing lucene index with a new history uuid.
- bootstrapNewHistory(long, long) - Method in class org.elasticsearch.index.store.Store
-
Marks an existing lucene index with a new history uuid and sets the given local checkpoint as well as the maximum sequence number.
- BootstrapSettings - Class in org.elasticsearch.bootstrap
- bottom - Variable in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- bottom() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- BOTTOM_LEFT - org.elasticsearch.common.geo.GeoUtils.EffectivePoint
- BOTTOM_RIGHT - 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.builders.EnvelopeBuilder
- 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.SearchContextHighlight.FieldOptions
- boundaryChars(char[]) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting defines what constitutes a boundary for highlighting. - boundaryMaxScan - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryMaxScan() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryMaxScan() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryMaxScan(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls how far to look for boundary characters, and defaults to 20. - boundaryScannerLocale - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerLocale() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerLocale() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryScannerLocale(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
and boundaryScannerTypebreak_iterator
, this setting controls the locale to use by the BreakIterator, defaults to "root". - boundaryScannerType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryScannerType(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls which scanner to use for fragment boundaries, and defaults to "simple". - boundaryScannerType(HighlightBuilder.BoundaryScannerType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls which scanner to use for fragment boundaries, and defaults to "simple". - BoundedBreakIteratorScanner - Class in org.apache.lucene.search.uhighlight
-
A custom break iterator that is used to find break-delimited passages bounded by a provided maximum length in the
UnifiedHighlighter
context. - 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
- BREADTH_FIRST - org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
Creates buckets for all matching docs and then prunes to top-scoring buckets before a second pass over the data when child aggregators are called but only for docs from the top-scoring buckets
- breakdowns - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
- BREAKER - 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(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, 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 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(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 extends Terms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.terms
- BucketPriorityQueue(int, Comparator<? super B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.BucketPriorityQueue
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.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, SearchContext, 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
- bucketsBuilder - Variable in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- bucketScript(String, Map<String, String>, Script) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- bucketScript(String, Script, String...) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- BucketScriptPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- BucketScriptPipelineAggregationBuilder(String, Map<String, String>, Script) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- BucketScriptPipelineAggregationBuilder(String, Script, String...) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- BucketScriptPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
-
Read from a stream.
- BucketScriptPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- BucketScriptPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregator
-
Read from a stream.
- bucketSelector(String, Map<String, String>, Script) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- bucketSelector(String, Script, String...) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- BucketSelectorPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSelectorPipelineAggregationBuilder(String, Map<String, String>, Script) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- BucketSelectorPipelineAggregationBuilder(String, Script, String...) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- BucketSelectorPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
-
Read from a stream.
- BucketSelectorPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSelectorPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregator
-
Read from a stream.
- BucketSignificancePriorityQueue<B extends SignificantTerms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.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.FromSingle
- bucketSort(String, List<FieldSortBuilder>) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- BucketSortPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
-
Builds a pipeline aggregation that allows sorting the buckets of its parent aggregation.
- BucketSortPipelineAggregationBuilder(String, List<FieldSortBuilder>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- BucketSortPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
-
Read from a stream.
- BucketSortPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSortPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregator
-
Read from a stream.
- bucketsPaths - Variable in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- bucketsPaths() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- bucketToXContent(CompositeAggregation.Bucket, XContentBuilder, ToXContent.Params) - Static method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
- BucketUtils - Class in org.elasticsearch.search.aggregations.bucket
-
Helper functions for common Bucketing functions
- BUFFER_SIZE - Static variable in class org.elasticsearch.common.io.Streams
- 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.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.DataStreamMetadata.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- build() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- build() - Method in class org.elasticsearch.cluster.RestoreInProgress.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- build() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- build() - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
Builds the routing table.
- build() - Method in class org.elasticsearch.common.cache.CacheBuilder
- build() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
Builds a new instance of the
- build() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
Builds a new instance of the
- build() - Method in class org.elasticsearch.common.geo.builders.CoordinatesBuilder
- build() - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- build() - Method in interface org.elasticsearch.common.recycler.Recycler.Factory
- build() - Method in class org.elasticsearch.common.Rounding.Builder
- build() - Method in class org.elasticsearch.common.rounding.Rounding.Builder
-
Deprecated.
- build() - Method in class org.elasticsearch.common.settings.Settings.Builder
- build() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Builds an
Ordinals
instance from the builders current state. - build() - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
- build() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
- build() - Method in class org.elasticsearch.repositories.ShardGenerations.Builder
- build() - Method in class org.elasticsearch.script.ScriptMetadata.Builder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel.EWMAModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel.LinearModelBuilder
- build() - Method in interface org.elasticsearch.search.aggregations.pipeline.MovAvgModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel.SimpleModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.support.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.suggest.completion.context.CategoryContextMapping.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.ContextBuilder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions.Builder
- build() - Method in class org.elasticsearch.snapshots.SnapshotInfo.SnapshotInfoBuilder
- build() - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Creates a new
ConnectionProfile
based on the added connections. - build() - Method in class org.elasticsearch.transport.TransportRequestOptions.Builder
- build(int, int, InternalAggregations) - Method in interface org.elasticsearch.search.aggregations.bucket.BucketsAggregator.BucketBuilderForFixedCount
- build(long, int, 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, SearchContext, 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, double, double, ValuesSourceConfig, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorSupplier
- build(String, AggregatorFactories, int, int, int, ValuesSourceConfig, SearchContext, Aggregator, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregatorSupplier
- build(String, AggregatorFactories, int, AutoDateHistogramAggregationBuilder.RoundingInfo[], Function<Rounding, Rounding.Prepared>, ValuesSourceConfig, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorSupplier
- build(String, AggregatorFactories, GeoDistance, GeoPoint, DistanceUnit, ValuesSource, DocValueFormat, InternalRange.Factory, RangeAggregator.Range[], boolean, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregatorSupplier
- build(String, AggregatorFactories, Rounding, Rounding.Prepared, BucketOrder, boolean, long, ExtendedBounds, ValuesSourceConfig, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationSupplier
- build(String, AggregatorFactories, ValuesSource.Numeric, DocValueFormat, InternalRange.Factory, RangeAggregator.Range[], boolean, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.range.RangeAggregatorSupplier
- build(String, AggregatorFactories, ValuesSourceConfig, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorSupplier
- build(String, AggregatorFactories, ValuesSource, int, GeoBoundingBox, int, int, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.GeoGridAggregatorSupplier
- build(String, AggregatorFactories, ValuesSource, DocValueFormat, List<BinaryRangeAggregator.Range>, boolean, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregatorSupplier
- build(String, ValuesSourceConfig, int, SearchContext, Aggregator, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.CardinalityAggregatorSupplier
- build(String, ValuesSourceConfig, SearchContext, Aggregator, double, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregatorProvider
- build(String, ValuesSourceConfig, SearchContext, Aggregator, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.MetricAggregatorSupplier
- build(String, ValuesSource, DocValueFormat, SearchContext, Aggregator, Map<String, Object>, double) - Method in interface org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregatorSupplier
- build(String, ValuesSource, SearchContext, Aggregator, double[], PercentilesConfig, boolean, DocValueFormat, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.PercentilesAggregatorSupplier
- build(String, SearchContext, Aggregator, ValuesSourceConfig, boolean, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregatorSupplier
- build(IndexReader, IndexOrdinalsFieldData, IndexSettings, CircuitBreakerService, Logger, Function<SortedSetDocValues, ScriptDocValues<?>>) - Static method in enum org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
-
Build global ordinals for the provided
IndexReader
. - build(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- build(ClusterState) - Static method in class org.elasticsearch.cluster.MasterNodeChangePredicate
-
builds a predicate that will accept a cluster state only if it was generated after the current has (re-)joined the master
- build(Priority) - Static method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
Build a cluster state update task configuration with the specified
Priority
and no timeout. - build(Priority, TimeValue) - Static method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
Build a cluster state update task configuration with the specified
Priority
and timeout. - build(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
- build(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
. - 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(TokenizerFactory, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.CustomNormalizerProvider
- build(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Creates an index-level
IndexAnalyzers
from this registry using the given index settings - build(IndexSettings, Map<String, AnalyzerProvider<?>>, Map<String, AnalyzerProvider<?>>, Map<String, TokenizerFactory>, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.Builder
-
Deprecated.
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.Mapper.Builder
-
Returns a newly built mapper.
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.ParametrizedFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- build(Mapper.BuilderContext, String, FieldType, FieldMapper.MultiFields, Explicit<Boolean>, Explicit<Boolean>, AbstractPointGeometryFieldMapper.ParsedPoint, FieldMapper.CopyTo) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.Builder
- build(Mapper.BuilderContext, String, FieldType, FieldMapper.MultiFields, Explicit<Boolean>, Explicit<Boolean>, AbstractPointGeometryFieldMapper.ParsedPoint, FieldMapper.CopyTo) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- build(Mapper.Builder, Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- build(MapperService) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
- build(MapperService) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- build(MapperService) - Method in interface org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.CandidateGenerator
- build(QueryShardContext) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.sort.SortBuilder
-
Create a SortFieldAndFormat from this builder.
- build(QueryShardContext) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- build(QueryShardContext) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- build(QueryShardContext, AggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- build(QueryShardContext, AggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Internal: build an
AggregatorFactory
based on the configuration of this builder. - build(QueryShardContext, AggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- build(SearchContext, InnerHitsContext) - Method in class org.elasticsearch.index.query.InnerHitContextBuilder
- 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 - org.elasticsearch.search.profile.aggregation.AggregationTimingType
- BUILD_SCORER - org.elasticsearch.search.profile.query.QueryTimingType
- Build.Flavor - Enum in org.elasticsearch
- Build.Type - Enum in org.elasticsearch
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- 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.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.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.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
- 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(QueryShardContext, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- buildBucketedSort(QueryShardContext, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- buildBucketedSort(QueryShardContext, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- buildBucketedSort(QueryShardContext, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- buildBucketedSort(QueryShardContext, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.SortBuilder
-
Create a BucketedSort which is useful for sorting inside of aggregations.
- 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
- buildContext(QueryShardContext) - 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 - 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
- buildDescription() - Method in class org.elasticsearch.action.search.SearchRequest
- buildEmpty(IndexSettings, IndexReader, IndexOrdinalsFieldData) - Static method in enum org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
- 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.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.MedianAbsoluteDeviationAggregator
- 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
- buildEmptySubAggregations() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- builder - Variable in class org.elasticsearch.index.mapper.Mapper.Builder
- 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.DataStreamMetadata
- 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.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.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() - Static method in class org.elasticsearch.transport.TransportRequestOptions
- 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
- builder(Client, BulkProcessor.Listener) - Static method in class org.elasticsearch.action.bulk.BulkProcessor
-
Deprecated.Use
BulkProcessor.builder(java.util.function.BiConsumer, org.elasticsearch.action.bulk.BulkProcessor.Listener)
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(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(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.DataStreamMetadata.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.FieldMapper.CopyTo.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.IgnoredFieldMapper.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.IndexFieldMapper.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(double, double, int, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.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.BooleanFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.GeoShapeFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.Builder
-
Deprecated.
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.Mapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.ObjectMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.ParametrizedFieldMapper.Builder
-
Creates a new Builder with a field name
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.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, FieldType) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.Builder
- Builder(String, FieldType) - Constructor for class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.Builder
- Builder(String, FieldType) - Constructor for class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.Builder
-
default builder - used for external mapper
- Builder(String, FieldType) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Builder
- Builder(String, FieldType) - Constructor for class org.elasticsearch.index.mapper.MetadataFieldMapper.Builder
- Builder(String, FieldType, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.Builder
- Builder(String, FieldType, boolean, boolean, ShapeBuilder.Orientation, boolean) - Constructor for class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.Builder
- Builder(String, LegacyGeoShapeFieldMapper.DeprecatedParameters) - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.Builder
-
Deprecated.
- Builder(String, NumberFieldMapper.NumberType) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- Builder(String, RangeType) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- Builder(Function<SortedSetDocValues, ScriptDocValues<?>>, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData.Builder
- Builder(Function<MapperService, String>, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData.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(Metadata) - Constructor for class org.elasticsearch.cluster.metadata.Metadata.Builder
- Builder(DiscoveryNodes) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- Builder(RestoreInProgress) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.Builder
- Builder(IndexShardRoutingTable) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- Builder(RoutingTable) - Constructor for class org.elasticsearch.cluster.routing.RoutingTable.Builder
- Builder(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(IndexNumericFieldData.NumericType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.Builder
- Builder(Index) - Constructor for class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- Builder(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- Builder(RootObjectMapper.Builder, MapperService) - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.Builder
- Builder(ShardId) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- Builder(ScriptMetadata) - Constructor for class org.elasticsearch.script.ScriptMetadata.Builder
- Builder(ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData.Builder
- Builder(ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData.Builder
- Builder(ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData.Builder
- Builder(ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData.Builder
- Builder(ConnectionProfile) - Constructor for class org.elasticsearch.transport.ConnectionProfile.Builder
-
copy constructor, using another profile as a base
- BuilderContext(Settings, ContentPath) - Constructor for class org.elasticsearch.index.mapper.Mapper.BuilderContext
- 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
- buildFieldDoc(SortAndFormats, Object[]) - Static method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- 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
- 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(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- buildFullName(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.ParametrizedFieldMapper.Builder
-
Builds the full name of the field, taking into account parent objects
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.LineStringBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.MultiPointBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- buildGeometry() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
build lucene geometry.
- buildHelpWidths(Table, RestRequest) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- buildIndexFieldDataCache(IndexFieldDataCache.Listener, Index, String) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- buildIndexSort(Function<String, MappedFieldType>, Function<MappedFieldType, 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. - 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. - 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) - 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) - Method in class org.elasticsearch.rest.action.RestToXContentListener
- 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
- buildResultAndLogHealthChange(ClusterState, RoutingAllocation, String) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.LineStringBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.MultiPointBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- buildS4J() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Create a new Shape from this builder.
- buildS4JGeometry(GeometryFactory, boolean) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- buildShapeQuery(QueryShardContext, MappedFieldType) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
builds the appropriate lucene shape query
- buildShapeQuery(QueryShardContext, MappedFieldType) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- buildShardResults(Profilers) - Static method in class org.elasticsearch.search.profile.SearchProfileShardResults
-
Helper method to convert Profiler into InternalProfileShardResults, which can be serialized to other nodes, emitted as JSON, etc.
- 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, Boolean) - Static method in class org.elasticsearch.transport.ConnectionProfile
-
Builds a connection profile that is dedicated to a single channel type.
- buildSort(List<SortBuilder<?>>, QueryShardContext) - 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. - 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 - 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(int, DocWriteRequest.OpType, BulkItemResponse.Failure) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse
- BulkItemResponse(int, DocWriteRequest.OpType, DocWriteResponse) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse
- 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.
- 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
- 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 - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- BYTE - 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
- ByteBufferReference - Class in org.elasticsearch.common.bytes
-
This is a
BytesReference
backed by aByteBuffer
. - 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.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 - org.elasticsearch.common.unit.ByteSizeUnit
- BYTES - org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- 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 - 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(Index, 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 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
- bytesOutputOrNull() - Method in class org.elasticsearch.rest.AbstractRestChannel
-
An accessor to the raw value of the channel bytes output.
- bytesPerValue(BytesRef) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData.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
- bytesToLong(BytesRef) - Static method in class org.elasticsearch.common.Numbers
- 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(BytesReference, 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.CellIdSource
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithScript
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
-
Get the current
ValuesSource.Bytes.WithScript.BytesValues
. - 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 in org.elasticsearch.common.util
-
Utility methods to do byte-level encoding.
C
- cache - Variable in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- cache - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- cache - Variable in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- cache() - Method in class org.elasticsearch.index.IndexService
- cache() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- 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.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 org.elasticsearch.common.geo.GeoDistance
-
compute the distance between two points using the selected algorithm (PLANE, ARC)
- 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
- CALENDAR - org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- calendarInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Sets the interval of the DateHistogram using calendar units (`1d`, `1w`, `1M`, etc).
- calendarInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Sets the interval of the DateHistogram using calendar units (`1d`, `1w`, `1M`, etc).
- calendarInterval(DateHistogramInterval) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalConsumer
- calendarInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
-
Sets the interval of the DateHistogram using calendar units (`1d`, `1w`, `1M`, etc).
- 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(RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given node can allow any allocation at all at this state of theRoutingAllocation
. - canAllocate(RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canAllocate(RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
- 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.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
- 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. - 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
- CancellableTask - Class in org.elasticsearch.tasks
-
A task that can be canceled
- CancellableTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.tasks.CancellableTask
- 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.IOInterruptible - Interface in org.elasticsearch.common.util
- CancellableThreads.OnCancel - Interface in org.elasticsearch.common.util
- cancelOnParentLeaving() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- cancelOnParentLeaving() - Method in class org.elasticsearch.tasks.CancellableTask
-
Returns true if this task should be automatically cancelled if the coordinating node that requested this task left the cluster.
- 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.
- 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
- canDecompress(int) - Method in class org.elasticsearch.transport.TransportDecompressor
- canDeleteIndexContents(Index, IndexSettings) - 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 - 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
- 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
. - 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.SearchService.CanMatchResponse
- canMatch(ShardSearchRequest) - Method in class org.elasticsearch.search.SearchService
-
This method does a very quick rewrite of the query and returns true if the query can potentially match any documents.
- canMatch(ShardSearchRequest, ActionListener<SearchService.CanMatchResponse>) - Method in class org.elasticsearch.search.SearchService
- CanMatchResponse(boolean, MinAndMax<?>) - Constructor for class org.elasticsearch.search.SearchService.CanMatchResponse
- CanMatchResponse(StreamInput) - Constructor for class org.elasticsearch.search.SearchService.CanMatchResponse
- 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. - 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.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.RestCancelTasksAction
- 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
- 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(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, SearchContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- CardinalityAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.metrics
- CardinalityUpperBound - Enum in org.elasticsearch.search.aggregations
-
Upper bound of how many
owningBucketOrds
that anAggregator
will have to collect into. - cast() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- castToDouble(SortedNumericDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Wrap the provided
SortedNumericDocValues
instance to cast all values to doubles. - castToLong(SortedNumericDoubleValues) - Static method in enum 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 - 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 class 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 org.elasticsearch.common.geo.builders.ShapeBuilder.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
- CellIdSource - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Wrapper class to help convert
MultiGeoPointValues
to numeric long values for bucketing. - CellIdSource(ValuesSource.GeoPoint, int, GeoBoundingBox, CellIdSource.GeoPointLongEncoder) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource
- CellIdSource.GeoPointLongEncoder - Interface in org.elasticsearch.search.aggregations.bucket.geogrid
-
The encoder to use to convert a geopoint's (lon, lat, precision) into a long-encoded bucket key for aggregating.
- center() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Get the center of the circle
- center(double, double) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
set the center of the circle
- center(Coordinate) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Set the center of the circle
- centeredModulus(double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
- CENTIMETERS - 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
- 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.rest.action.admin.indices.RestAnalyzeAction.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 - 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(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(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
- checkBlock(ClusterSearchShardsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- 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(GetSnapshotsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- 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(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
- 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 java.lang.Exception> - Interface in org.elasticsearch.common
-
A
BiConsumer
-like interface which allows throwing checked exceptions. - CheckedBiFunction<T,U,R,E extends java.lang.Exception> - Interface in org.elasticsearch.common
-
A
BiFunction
-like interface which allows throwing checked exceptions. - CheckedSupplier<R,E extends java.lang.Exception> - Interface in org.elasticsearch.common
-
A
Supplier
-like interface which allows throwing checked exceptions. - checkForCancel() - Method in class org.elasticsearch.common.util.CancellableThreads
- 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. - checkForOverlappingPatterns(Map<String, Collection<SystemIndexDescriptor>>) - Static method in class org.elasticsearch.indices.SystemIndexDescriptor
-
Given a collection of
SystemIndexDescriptor
s and their sources, checks to see if the index patterns of the listed descriptors overlap with any of the other patterns. - 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, 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, 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.
- 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() - Method in class org.elasticsearch.index.engine.TranslogLeafReader
- 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
- checkNegativeBoost(float) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- checkNoRemainingFields(String, Map<?, ?>, Version) - Static method in class org.elasticsearch.index.mapper.DocumentMapperParser
- checkNoRemainingFields(Map<?, ?>, Version, String) - Static method in class org.elasticsearch.index.mapper.DocumentMapperParser
- checkNotAnnotated() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- checkNotAnnotated() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- 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, 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, 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
- checkShardLimit(int, ClusterState) - Method in class org.elasticsearch.indices.ShardLimitValidator
-
Checks to see if an operation can be performed without taking the cluster over the cluster-wide shard limit.
- 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 org.elasticsearch.common.xcontent.ToXContent> - Class in org.elasticsearch.repositories.blobstore
-
Snapshot metadata file format used in v2.0 and above
- ChecksumBlobStoreFormat(String, String, CheckedFunction<XContentParser, T, IOException>, NamedXContentRegistry, boolean) - 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.common.geo.parsers.CoordinateNode
- 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
- chunkSize() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns data file chunk size.
- chunkSize() - Method in class org.elasticsearch.repositories.fs.FsRepository
- cidrMaskToMinMax(String) - Static method in class org.elasticsearch.common.network.Cidrs
-
Parses an IPv4 address block in CIDR notation into a pair of longs representing the bottom and top of the address block
- Cidrs - Class in org.elasticsearch.common.network
- circle(CircleBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- CIRCLE - org.elasticsearch.common.geo.GeoShapeType
- CircleBuilder - Class in org.elasticsearch.common.geo.builders
- CircleBuilder() - Constructor for class org.elasticsearch.common.geo.builders.CircleBuilder
-
Creates a circle centered at [0.0, 0.0].
- CircleBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.CircleBuilder
-
Read from a stream.
- 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 in org.elasticsearch.common.breaker
- CircuitBreaker.Type - Enum 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 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 - 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 - org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- CLEAN_FILES - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- CLEAN_WITH_CORRUPTED_MARKER - 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.
- cleanPath() - Static method in class org.elasticsearch.common.blobstore.BlobPath
- 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.
- 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.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.metrics.MeanMetric
- clear() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- clear() - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Clears any resources associated with this field data.
- clear() - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
-
Clears all the field data stored cached in on this index.
- clear() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- clear() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
- clear() - Method in class org.elasticsearch.index.fielddata.IndexHistogramFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- clear() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- 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.LeafFieldsLookup
- clear() - Method in class org.elasticsearch.search.lookup.SourceLookup
- clear() - Method in class org.elasticsearch.transport.TransportRequestDeduplicator
-
Remove all tracked requests from this instance so that the first time
TransportRequestDeduplicator.executeOnce(T, org.elasticsearch.action.ActionListener<java.lang.Void>, java.util.function.BiConsumer<T, org.elasticsearch.action.ActionListener<java.lang.Void>>)
is invoked with any request it triggers an actual request execution. - clear(int) - Method in class org.apache.lucene.util.CombinedBitSet
- clear(int) - Method in class org.elasticsearch.common.util.BitArray
-
Clear the
index
th bit. - clear(int, int) - Method in class org.apache.lucene.util.CombinedBitSet
- 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
- clearFileSizes() - 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.
- clearReleasables(SearchContext.Lifetime) - Method in class org.elasticsearch.search.internal.SearchContext
- 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
- 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
- ClearVotingConfigExclusionsResponse - Class in org.elasticsearch.action.admin.cluster.configuration
-
A response to
ClearVotingConfigExclusionsRequest
indicating that voting config exclusions have been cleared from the cluster state. - ClearVotingConfigExclusionsResponse() - Constructor for class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsResponse
- ClearVotingConfigExclusionsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsResponse
- 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
- CLOCKWISE - Static variable in enum org.elasticsearch.common.geo.builders.ShapeBuilder.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.DateFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.FieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- clone() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- 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 - org.elasticsearch.action.admin.indices.shrink.ResizeType
- cloneLocalPeerRecoveryRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
- cloneLocalPeerRecoveryRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
- close() - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- 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.bytes.ReleasableBytesReference
- close() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- close() - Method in class org.elasticsearch.common.geo.builders.CoordinatesBuilder
-
Makes a closed ring out of the current coordinates by adding the starting point as the end point.
- close() - Method in class org.elasticsearch.common.geo.builders.LineStringBuilder
-
Closes the current lineString by adding the starting point as the end point.
- close() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
-
Close the shell of the polygon
- 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.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 interface org.elasticsearch.common.lease.Releasable
- 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.LongObjectPagedHashMap
- 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.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.PagedBytesLeafFieldData
- close() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetBytesLeafFieldData
- close() - Method in class org.elasticsearch.index.mapper.MapperService
- 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.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.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.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.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.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.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.RemoteClusterService
- close() - Method in class org.elasticsearch.transport.RemoteConnectionManager
- close() - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- close() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- close() - Method in interface org.elasticsearch.transport.Transport.Connection
- close() - Method in class org.elasticsearch.transport.TransportDecompressor
- close() - Method in class org.elasticsearch.watcher.ResourceWatcherService
- close(boolean, Iterable<Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
- close(boolean, Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
- close(Iterable<? extends Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Release the provided
Releasable
s. - 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(Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Release the provided
Releasable
s. - CLOSE - 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.
- 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 - org.elasticsearch.action.support.IndicesOptions.WildcardStates
- CLOSED - org.elasticsearch.common.component.Lifecycle.State
- CLOSED - org.elasticsearch.index.shard.IndexShardState
- CLOSED - 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 - Class 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.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.search.internal.SearchContext
- 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
- closeWhileHandlingException(Iterable<? extends Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Release the provided
Releasable
s, ignoring exceptions. - closeWhileHandlingException(Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Release the provided
Releasable
s, ignoring exceptions. - cluster() - Method in interface org.elasticsearch.client.AdminClient
-
A client allowing to perform actions/operations against the cluster.
- CLUSTER - 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 - 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_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(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
- ClusterApplier.ClusterApplyListener - Interface in org.elasticsearch.cluster.service
-
Listener for results of cluster state application
- 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 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(StreamInput) - Constructor for class org.elasticsearch.cluster.block.ClusterBlocks
- 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 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.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.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) - Constructor for class org.elasticsearch.transport.ClusterConnectionManager
- ClusterConnectionManager(ConnectionProfile, Transport) - 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 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 in org.elasticsearch.cluster.health
- 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<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.
- ClusterModule - Class in org.elasticsearch.cluster
-
Configures classes and services that affect the entire cluster.
- ClusterModule(Settings, ClusterService, List<ClusterPlugin>, ClusterInfoService) - 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 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) - 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 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. - clusterStatePublished(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardFailedClusterStateTaskExecutor
- clusterStatePublished(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardStartedClusterStateTaskExecutor
- clusterStatePublished(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor
-
Callback invoked after new cluster state is published.
- clusterStatePublished(ClusterChangedEvent) - 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
- 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
- ClusterStateUpdateResponse - Class in org.elasticsearch.cluster.ack
-
Base response returned after a cluster state update
- ClusterStateUpdateResponse(boolean) - Constructor for class org.elasticsearch.cluster.ack.ClusterStateUpdateResponse
- ClusterStateUpdaters - Class in org.elasticsearch.gateway
- ClusterStateUpdaters() - Constructor for class org.elasticsearch.gateway.ClusterStateUpdaters
- 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
- 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) - 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>, ClusterState) - 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
- 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, Logger) - Constructor for class org.elasticsearch.index.codec.CodecService
- coerce - Variable in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.Builder
- coerce - Variable in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- coerce() - Method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.Builder
- coerce() - Method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- coerce(boolean) - Method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.Builder
- coerce(boolean) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- coerce(boolean) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- coerce(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.Builder
- coerce(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- coerce(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- COERCE - org.elasticsearch.index.query.GeoValidationMethod
- COERCE - Static variable in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.Defaults
- COERCE - Static variable in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.Names
- COERCE - Static variable in class org.elasticsearch.index.mapper.NumberFieldMapper.Defaults
- 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
- 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
- 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.HyperLogLogPlusPlus
- COLLECT - 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.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.histogram.AbstractHistogramAggregator
- 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 class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- 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. - COLLECTION - org.elasticsearch.search.internal.SearchContext.Lifetime
-
This life time is for objects that only live during collection time.
- 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
- 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.
- 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 - Variable in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- 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.
- collectV2Mappings(Map<String, String>, ClusterState, String, NamedXContentRegistry, String) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- combine(double, double, double) - Method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
- combine(float, float) - Method in enum 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(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. - 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 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
- COMMA - Static variable in class org.elasticsearch.common.geo.parsers.GeoWKTParser
- 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(long, long) - Method in class org.elasticsearch.gateway.PersistedClusterStateService.Writer
- COMMIT_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- COMMIT_MISMATCH - 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 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.MatchQuery
- 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 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(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
- compareDiscardNaN(double, double, boolean) - Static method in enum org.elasticsearch.common.util.Comparators
-
Compare
d1
againstd2
, pushing 0d/0d at the bottom. - 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(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.action.search.SearchShardIterator
- 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) - 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(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.
- 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
- 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(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.index.query.QueryShardContext
-
Compile script using script service
- compile(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.script.ScriptService
- compileTemplate(String, String, String, String, ScriptService) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- COMPLEMENT - org.elasticsearch.index.query.RegexpFlag
-
Enables complement expression of the form:
~<expression>
- completed() - Method in enum org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Returns true if snapshot completed (successfully or not)
- completed() - Method in enum org.elasticsearch.cluster.RestoreInProgress.State
-
Returns true if restore process completed (either successfully or with failure)
- completed() - Method in enum org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- completed() - Method in enum org.elasticsearch.cluster.SnapshotsInProgress.State
- completed() - Method in enum org.elasticsearch.snapshots.SnapshotState
-
Returns true if snapshot completed (successfully or not)
- completed(ObjectContainer<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 - 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 - 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, FieldType, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo, int) - 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
- CompletionFieldMapper.TypeParser - 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) - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- CompletionFieldType(String, FieldType, NamedAnalyzer, 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(QueryShardContext) - 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(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(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- 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
- CompositeBytesReference - Class in org.elasticsearch.common.bytes
-
A composite
BytesReference
that allows joining multiple bytes references into one without copying. - 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
- CompositeValuesSourceBuilder<AB extends CompositeValuesSourceBuilder<AB>> - Class in org.elasticsearch.search.aggregations.bucket.composite
-
A
ValuesSource
builder forCompositeAggregationBuilder
- 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_SETTING - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
When set to true metadata files are stored in compressed format.
- 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_FIELD - Static variable in enum org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- 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_MAX_SCORE - org.elasticsearch.search.profile.query.QueryTimingType
- computeAndValidateAliasProperties() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- 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, 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.
- 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
- 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
- CONCRETE_INDEX - 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
- 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
- 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 org.elasticsearch.common.recycler.Recyclers
- concurrent(Recycler.Factory<T>, int) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Create a concurrent implementation that can support concurrent access from
concurrencyLevel
threads with little contention. - CONCURRENT - org.elasticsearch.common.util.PageCacheRecycler.Type
- ConcurrentCollections - Class in org.elasticsearch.common.util.concurrent
- concurrentDeque(Recycler.C<T>, int) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Return a concurrent recycler based on a deque.
- ConcurrentDequeRecycler<T> - Class in org.elasticsearch.common.recycler
-
A
Recycler
implementation based on a concurrentDeque
. - ConcurrentDequeRecycler(Recycler.C<T>, int) - Constructor for class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- ConcurrentHashMapLong<T> - Class in org.elasticsearch.common.util.concurrent
- ConcurrentHashMapLong(ConcurrentMap<Long, T>) - Constructor for class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- 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
- configFile() - Method in class org.elasticsearch.env.Environment
-
The config directory.
- configs - Variable in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- 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.
- 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 - org.elasticsearch.rest.RestStatus
-
The request could not be completed due to a conflict with the current state of the resource.
- CONNECT - 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<Void>) - 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<Void>) - Method in class org.elasticsearch.transport.TransportService
-
Connect to the specified node with the given connection profile.
- connectToNode(DiscoveryNode, ConnectionProfile, ConnectionManager.ConnectionValidator, ActionListener<Void>) - Method in class org.elasticsearch.transport.ClusterConnectionManager
-
Connects to a node with the given connection profile.
- connectToNode(DiscoveryNode, ConnectionProfile, ConnectionManager.ConnectionValidator, ActionListener<Void>) - Method in interface org.elasticsearch.transport.ConnectionManager
- connectToNode(DiscoveryNode, ConnectionProfile, ConnectionManager.ConnectionValidator, ActionListener<Void>) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- 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
- connectToRemoteMasterNode(TransportAddress, ActionListener<DiscoveryNode>) - Method in class org.elasticsearch.discovery.HandshakingTransportAddressConnector
- connectToRemoteMasterNode(TransportAddress, ActionListener<DiscoveryNode>) - Method in interface org.elasticsearch.discovery.PeerFinder.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 - 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.
- 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.
- consumeTopDocs() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns and nulls out the top docs for this search results.
- 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 - org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- CONTAINS - 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
- 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.common.collect.CopyOnWriteHashMap
- containsKey(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- 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.LeafFieldsLookup
- 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. - containsProcessor(String) - Method in class org.elasticsearch.ingest.IngestInfo
- containsQuery(String, Object, Object, boolean, boolean) - Method in enum 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.concurrent.ConcurrentHashMapLong
- 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.LeafFieldsLookup
- 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(boolean) - Method in class org.elasticsearch.rest.RestRequest
- 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.DateFieldMapper
- 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.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.LegacyGeoShapeFieldMapper
-
Deprecated.
- 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.VersionFieldMapper
- CONTENT_TYPE_OPTION - Static variable in class org.elasticsearch.script.Script
-
Compiler option for
XContentType
used for templates. - 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
- contentToWKT() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- contentToWKT() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- contentToWKT() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- contentToWKT() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- contentToWKT() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- contentToWKT() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- 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.DateFieldMapper
- 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.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.LegacyGeoShapeFieldMapper
-
Deprecated.
- 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.MatchQuery
- context - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- context - Variable in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- context - Variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlighterContext
- 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.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.Aggregator
-
Return the
SearchContext
attached with thisAggregator
. - context() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- context() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- context() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- context(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- Context(ClusterState, IndicesOptions, long, boolean, boolean, boolean, boolean) - Constructor for class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.Context
- CONTEXT - org.elasticsearch.search.internal.SearchContext.Lifetime
-
This life time is for objects that need to live until the search context they are attached to is destroyed.
- 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.BucketAggregationScript
- CONTEXT - Static variable in class org.elasticsearch.script.BucketAggregationSelectorScript
- 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.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.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.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_PARAM - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- CONTEXT_MODE_SNAPSHOT - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- CONTEXT_MODE_SNAPSHOT - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- 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
- 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 org.elasticsearch.common.xcontent.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 in org.elasticsearch.search.suggest.completion.context
- contextMappings(ContextMappings) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
-
Add context mapping to this field
- 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.index.mapper.CompletionFieldMapper.Fields
- CONTEXTS - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- CONTEXTS_ALLOWED_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- CONTINUE - 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 org.elasticsearch.common.unit.DistanceUnit
-
Convert a given value into another unit
- convert(double, DistanceUnit, DistanceUnit) - Static method in enum 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 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.PlainActionFuture
- convert(T) - Method in class org.elasticsearch.action.support.PlainListenableActionFuture
- 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
. - 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, InputStream, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Convert a string in some
XContent
format to aMap
. - convertToMap(XContent, String, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Convert a string in some
XContent
format to aMap
. - convertToOrdinalsFilter(DocValueFormat) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- convertToRuntime(Exception) - Static method in class org.elasticsearch.ExceptionsHelper
- convertToShardContext() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Returns an instance of
QueryShardContext
if available of null otherwise - convertToShardContext() - Method in class org.elasticsearch.index.query.QueryShardContext
- 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.
- coordinate - Variable in class org.elasticsearch.common.geo.parsers.CoordinateNode
- coordinate(double, double) - Method in class org.elasticsearch.common.geo.builders.CoordinatesBuilder
-
Add a new coordinate to the collection
- coordinate(double, double) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Add a new coordinate to the collection
- coordinate(Coordinate) - Method in class org.elasticsearch.common.geo.builders.CoordinatesBuilder
-
Add a new coordinate to the collection
- coordinate(Coordinate) - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- coordinate(Coordinate) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Add a new coordinate to the collection
- coordinateListToWKT(List<Coordinate>) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- CoordinateNode - Class in org.elasticsearch.common.geo.parsers
-
Node used to represent a tree of coordinates.
- coordinates - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- coordinates() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- coordinates() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
-
The coordinates setup by the builder will be assembled to a polygon.
- coordinates(boolean) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Copy all coordinate to a new Array
- coordinates(Collection<? extends Coordinate>) - Method in class org.elasticsearch.common.geo.builders.CoordinatesBuilder
-
Add a collection of coordinates to the current coordinates
- coordinates(Collection<? extends Coordinate>) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Add a collection of coordinates to the collection
- coordinates(Coordinate...) - Method in class org.elasticsearch.common.geo.builders.CoordinatesBuilder
-
Add an array of coordinates to the current coordinates
- coordinates(Coordinate...) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Add a array of coordinates to the collection
- coordinatesArray(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- CoordinatesBuilder - Class in org.elasticsearch.common.geo.builders
-
A builder for a list of coordinates.
- CoordinatesBuilder() - Constructor for class org.elasticsearch.common.geo.builders.CoordinatesBuilder
- coordinatesToXcontent(XContentBuilder, boolean) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
builds an array of coordinates to a
XContentBuilder
- coordinationMetadata() - Method in class org.elasticsearch.cluster.ClusterState
- coordinationMetadata() - Method in class org.elasticsearch.cluster.metadata.Metadata
- coordinationMetadata(CoordinationMetadata) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- CoordinationMetadata - Class in org.elasticsearch.cluster.coordination
- CoordinationMetadata(long, CoordinationMetadata.VotingConfiguration, CoordinationMetadata.VotingConfiguration, Set<CoordinationMetadata.VotingConfigExclusion>) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata
- CoordinationMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata
- CoordinationMetadata.Builder - Class in org.elasticsearch.cluster.coordination
- CoordinationMetadata.VotingConfigExclusion - Class in org.elasticsearch.cluster.coordination
- CoordinationMetadata.VotingConfiguration - Class in org.elasticsearch.cluster.coordination
-
A collection of persistent node ids, denoting the voting configuration for cluster state changes.
- CoordinationState - Class in org.elasticsearch.cluster.coordination
-
The core class of the cluster state coordination algorithm, directly implementing the formal model
- CoordinationState(DiscoveryNode, CoordinationState.PersistedState, ElectionStrategy) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationState
- CoordinationState.PersistedState - Interface in org.elasticsearch.cluster.coordination
-
Pluggable persistence layer for
CoordinationState
. - CoordinationState.VoteCollection - Class in org.elasticsearch.cluster.coordination
-
A collection of votes, used to calculate quorums.
- CoordinationStateRejectedException - Exception in org.elasticsearch.cluster.coordination
-
This exception is thrown when rejecting state transitions on the
CoordinationState
object, for example when receiving a publish request with the wrong term or version. - CoordinationStateRejectedException(String, Object...) - Constructor for exception org.elasticsearch.cluster.coordination.CoordinationStateRejectedException
- CoordinationStateRejectedException(StreamInput) - Constructor for exception org.elasticsearch.cluster.coordination.CoordinationStateRejectedException
- Coordinator - Class in org.elasticsearch.cluster.coordination
- Coordinator(String, Settings, ClusterSettings, TransportService, 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 in org.elasticsearch.cluster.coordination
- 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(InputStream, OutputStream) - Static method in class org.elasticsearch.common.io.Streams
- copy(InputStream, OutputStream, byte[]) - Static method in class org.elasticsearch.common.io.Streams
-
Copy the contents of the given InputStream 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
- 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.
- copyNamedQueries() - Method in class org.elasticsearch.index.query.QueryShardContext
- 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 - Variable in class org.elasticsearch.index.mapper.ParametrizedFieldMapper.Builder
- 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
- copyTo(FieldMapper.CopyTo) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- 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 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 - 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. - corsConfig - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- CorsHandler - Class in org.elasticsearch.http
-
This file is forked from the https://netty.io project.
- 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.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.common.cache.Cache
-
The number of entries in the cache.
- count() - Method in class org.elasticsearch.common.metrics.CounterMetric
- count() - Method in class org.elasticsearch.common.metrics.MeanMetric
- count() - Method in class org.elasticsearch.index.fielddata.HistogramValue
-
The current count of the histogram
- 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. - 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
- 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_CLOCKWISE - Static variable in enum org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
- counterGetAndIncrement() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- CounterMetric - Class in org.elasticsearch.common.metrics
- 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
- 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>, 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>, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- create(String, List<LongTerms.Bucket>, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- create(String, List<StringTerms.Bucket>, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- create(String, List<UnmappedTerms.Bucket>, 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(ShardId, String, long, Path, ChannelFactory, ByteSizeValue, long, long, LongSupplier, LongSupplier, long, TragicExceptionHolder, LongConsumer) - Static method in class org.elasticsearch.index.translog.TranslogWriter
- 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(SearchContext, Aggregator, CardinalityUpperBound) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Creates the aggregator.
- 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 org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- create(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
- CREATE - org.elasticsearch.action.DocWriteRequest.OpType
-
Creates the resource.
- CREATE - org.elasticsearch.index.translog.Translog.Operation.Type
-
Deprecated.
- CREATE_INDEX - org.elasticsearch.index.IndexService.IndexCreationContext
- CREATE_WEIGHT - 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>) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreClusterStateListener
-
Creates a cluster state listener and registers it with the cluster service.
- 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(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.DoubleTerms
- 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.InternalTerms
-
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.LongTerms
- 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.StringTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- 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
- createCIDR(long, int) - Static method in class org.elasticsearch.common.network.Cidrs
- 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.
- createCopyToContext() - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that will be within a copy-to operation.
- CREATED - org.elasticsearch.action.DocWriteResponse.Result
- CREATED - org.elasticsearch.index.shard.IndexShardState
- CREATED - 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, TimeValue, TimeValue) - Constructor for class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
- createDeleteTombstoneDoc(String, String, String) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- 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(Version) - Method in class org.elasticsearch.index.store.Store
-
creates an empty lucene index and a corresponding empty translog.
- 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. - createExternalValueContext(Object) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that will have the external value set.
- createFactory(String, ValuesSourceConfig, int, int, int, GeoBoundingBox, QueryShardContext, 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, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- createFactory(String, ValuesSourceConfig, int, int, int, GeoBoundingBox, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- createFieldNamesField(ParseContext) - Method in class org.elasticsearch.index.mapper.FieldMapper
- createFields(String, Number, boolean, boolean, boolean) - Method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- createFields(ParseContext, String, RangeFieldMapper.Range, boolean, boolean, boolean) - Method in enum org.elasticsearch.index.mapper.RangeType
- 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
- createIndex(CreateIndexClusterStateUpdateRequest, ActionListener<CreateIndexClusterStateUpdateResponse>) - 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. - 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
- CreateIndexClusterStateUpdateResponse - Class in org.elasticsearch.cluster.ack
-
A cluster state update response with specific fields for index creation.
- CreateIndexClusterStateUpdateResponse(boolean, boolean) - Constructor for class org.elasticsearch.cluster.ack.CreateIndexClusterStateUpdateResponse
- 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 new request to create an index with the specified name.
- CreateIndexRequest(String, Settings) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Constructs a new request to create an index with the specified name and settings.
- CreateIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- 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.
- createInnerHitQueryWeight() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- 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(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- createInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- createKeyword(String, MappedFieldType, Sort, int) - 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.
- createMapper(String, String, Explicit<Boolean>, ObjectMapper.Nested, ObjectMapper.Dynamic, Map<String, Mapper>, Settings) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- createMapper(String, String, Explicit<Boolean>, ObjectMapper.Nested, ObjectMapper.Dynamic, Map<String, Mapper>, Settings) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- 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.ParseContext
-
Return a new context that will be within multi-fields.
- createMultiFieldContext(Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- createNestedContext(String) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that will be used within a nested document.
- createNoopTombstoneDoc(String, String) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- createNumeric(String, MappedFieldType, Sort, int) - 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, ParsedMultiBucketAggregation.ParsedBucket, IOException>, CheckedFunction<XContentParser, ParsedMultiBucketAggregation.ParsedBucket, 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, SearchContext, Aggregator, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- createPercentilesAggregator(String, ValuesSource, SearchContext, Aggregator, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- createPercentilesAggregator(String, ValuesSource, SearchContext, 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 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
- 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.
- 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
- 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(SearchContext, 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.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.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<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) - Method in class org.elasticsearch.search.collapse.CollapseContext
- createTopDocsCollector(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- createTopLevelAggregators(SearchContext) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceRangeAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- createUnmapped(SearchContext, Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregatorFactory
- createUnmapped(SearchContext, 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(SearchContext, 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
- 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.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
. - CROSS_FIELDS - 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 - 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 - 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 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
- currentTimeInMillis() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- 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
- 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 - org.elasticsearch.cluster.ClusterState.Metric
- 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, int) - 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 org.elasticsearch.common.geo.builders.ShapeBuilder.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
- daemonThreadFactory(Settings, String...) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- DAMERAU_LEVENSHTEIN - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
String distance algorithm based on Damerau-Levenshtein algorithm.
- DANGLING_INDEX_IMPORTED - 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_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for a data node.
- DATA_STREAM - org.elasticsearch.cluster.metadata.IndexAbstraction.Type
-
An index abstraction that refers to a data stream.
- DATA_STREAMS_IN_SNAPSHOT - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- dataFiles() - Method in class org.elasticsearch.env.Environment
-
The data location.
- DataOutputStreamOutput - Class in org.elasticsearch.common.io.stream
- DataOutputStreamOutput(DataOutput) - Constructor for class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- DataStream - Class in org.elasticsearch.cluster.metadata
- DataStream(String, DataStream.TimestampField, List<Index>) - Constructor for class org.elasticsearch.cluster.metadata.DataStream
- DataStream(String, DataStream.TimestampField, List<Index>, long) - Constructor for class org.elasticsearch.cluster.metadata.DataStream
- DataStream(DataStream, List<IndexMetadata>) - 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
- DataStreamMetadata - Class in org.elasticsearch.cluster.metadata
-
Custom
Metadata
implementation for storing a map ofDataStream
s and their names. - DataStreamMetadata(Map<String, DataStream>) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamMetadata
- DataStreamMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamMetadata
- DataStreamMetadata.Builder - Class in org.elasticsearch.cluster.metadata
- 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>) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- DataStreamTemplate() - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- 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 - org.elasticsearch.common.time.FormatNames
- DATE - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- DATE - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- DATE - org.elasticsearch.index.mapper.RangeType
- DATE - org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- DATE - 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.index.mapper.RangeFieldMapper.Defaults
- DATE_HOUR - org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE - org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND - org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND_FRACTION - org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND_MILLIS - org.elasticsearch.common.time.FormatNames
- DATE_NANOS_CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper
- DATE_NANOSECONDS - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- DATE_OPTIONAL_TIME - org.elasticsearch.common.time.FormatNames
- DATE_TIME - org.elasticsearch.common.time.FormatNames
- DATE_TIME_FORMATTER - Static variable in class org.elasticsearch.cluster.routing.UnassignedInfo
- DATE_TIME_NO_MILLIS - 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
- 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.Defaults - Class in org.elasticsearch.index.mapper
- DateFieldMapper.Resolution - Enum in org.elasticsearch.index.mapper
- DateFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- DateFieldType(String) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- DateFieldType(String, boolean, boolean, DateFormatter, DateFieldMapper.Resolution, Map<String, String>) - 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, ExtendedBounds, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - 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.
- 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
- 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 in org.elasticsearch.search.aggregations.bucket.histogram
- DATELINE - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- DateMathExpressionResolver() - Constructor for class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.DateMathExpressionResolver
- 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<?, ?>, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - 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
- Dates(SortedNumericDocValues, boolean) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
- 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 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 - org.elasticsearch.common.rounding.DateTimeUnit
- DAY_OF_MONTH - 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 - org.elasticsearch.Build.Type
- DEBUG - 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
- debugEnabled() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- 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
- dec(long) - Method in class org.elasticsearch.common.metrics.MeanMetric
- 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 - 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 - 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 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) - Static method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceParseHelper
- declareFields(AbstractObjectParser<? extends ValuesSourceAggregationBuilder<?>, T>, 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 class 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<? extends ParsedMultiBucketAggregation, Void>, CheckedFunction<XContentParser, ParsedMultiBucketAggregation.ParsedBucket, IOException>, CheckedFunction<XContentParser, ParsedMultiBucketAggregation.ParsedBucket, 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
- 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
-
Adds
boost
andquery_name
parsing to theAbstractObjectParser
passed in. - 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(ReleasableBytesReference, Consumer<Object>) - Method in class org.elasticsearch.transport.InboundDecoder
- 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 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.TransportDecompressor
- decorate(CompoundProcessor, ConditionalProcessor, List<SimulateProcessorResult>) - Static method in class org.elasticsearch.ingest.TrackingResultProcessor
- decRef() - Method in class org.elasticsearch.index.store.Store
-
Decreases the refCount of this Store instance.
- decrementRecoveredOperations(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- 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
- 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
- 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 - org.elasticsearch.Build.Flavor
- DEFAULT - org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- DEFAULT - Static variable in enum 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 org.elasticsearch.common.unit.DistanceUnit
- DEFAULT - Static variable in enum 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_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_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_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_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- 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
-
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.resolve.ResolveIndexAction.Request
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.search.SearchRequest
- 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.MatchQuery
- DEFAULT_LENIENT - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for using lenient query parsing.
- DEFAULT_LENIENT_PARSING - Static variable in enum 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_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.MatchQuery
- 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_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_RECLAIM_DELETES_WEIGHT - Static variable in class org.elasticsearch.index.MergePolicyConfig
- 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_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_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_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_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_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.MatchQuery
- 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
- 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.QueryShardContext
- defaultFormat() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- defaultMapping() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Get the default mapping.
- defaultMappingType() - Method in enum org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
-
The default mapping type to use for fields of this
DynamicTemplate.XContentFieldType
. - 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.
- defaultPrefixTreeStrategy() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- 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.AbstractGeometryFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.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.DateFieldMapper.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.IndexFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults
-
Deprecated.
- Defaults() - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.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.SeqNoFieldMapper.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
- Defaults() - Constructor for class org.elasticsearch.index.mapper.VersionFieldMapper.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 - Class in org.elasticsearch.action.support
- DefaultShardOperationFailedException() - Constructor for class org.elasticsearch.action.support.DefaultShardOperationFailedException
- DefaultShardOperationFailedException(String, int, Throwable) - Constructor for class org.elasticsearch.action.support.DefaultShardOperationFailedException
- DefaultShardOperationFailedException(StreamInput) - Constructor for class org.elasticsearch.action.support.DefaultShardOperationFailedException
- DefaultShardOperationFailedException(ElasticsearchException) - Constructor for class 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, SearchContext, 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 - Variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractRareTermsAggregator
- definition - Variable in class org.elasticsearch.index.analysis.NameOrDefinition
- DeflateCompressor - Class in org.elasticsearch.common.compress
-
Compressor
implementation based on the DEFLATE compression algorithm. - DeflateCompressor() - Constructor for class org.elasticsearch.common.compress.DeflateCompressor
- 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. - 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 - 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
- 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.common.io.stream.FilterStreamInput
- delegate - Variable in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- delegateFailure(ActionListener<R>, BiConsumer<ActionListener<R>, T>) - Static method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that delegates all exceptions it receives to another listener.
- delegateResponse(ActionListener<T>, BiConsumer<ActionListener<T>, Exception>) - Static method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that delegates all responses it receives to another listener.
- 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(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 - org.elasticsearch.action.DocWriteRequest.OpType
-
Deletes a document
- DELETE - org.elasticsearch.index.engine.Engine.Operation.TYPE
- DELETE - org.elasticsearch.index.translog.Translog.Operation.Type
- DELETE - 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(List<String>) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Deletes the blobs with given names.
- deleteBlobsIgnoringIfNotExists(List<String>) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- deleteBlobsIgnoringIfNotExists(List<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 - org.elasticsearch.action.DocWriteResponse.Result
- DELETED - 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) - 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) - 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<ClusterStateUpdateResponse>) - 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) - 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) - Method in class org.elasticsearch.env.NodeEnvironment
-
Deletes a shard data directory iff the shards locks were successfully acquired.
- deleteShardDirectoryUnderLock(ShardLock, IndexSettings) - 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
- 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.
- 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 - org.elasticsearch.common.settings.Setting.Property
-
mark this setting as deprecated
- DEPRECATED_LONG_TIMEZONES - Static variable in class org.elasticsearch.common.time.DateUtils
- DEPRECATED_PARAMETERS_KEY - Static variable in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- DEPRECATED_SHORT_TZ_IDS - Static variable in class org.elasticsearch.common.time.DateUtils
- deprecatedAndMaybeLog(String, String, Object...) - Method in class org.elasticsearch.common.logging.DeprecationLogger
-
Adds a formatted warning message as a response header on the thread context, and logs a deprecation message if the associated key has not recently been seen.
- DeprecatedMessage - Class in org.elasticsearch.common.logging
-
A logger message used by
DeprecationLogger
. - DeprecatedMessage(String, String, Object...) - Constructor for class org.elasticsearch.common.logging.DeprecatedMessage
- DeprecatedParameters() - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- DeprecatedRoute(RestRequest.Method, String, String) - Constructor for class org.elasticsearch.rest.RestHandler.DeprecatedRoute
- deprecatedRoutes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- deprecatedRoutes() - Method in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- deprecatedRoutes() - Method in interface org.elasticsearch.rest.RestHandler
-
A list of routes handled by this RestHandler that are deprecated and do not have a direct replacement.
- DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- deprecationLogger - Variable in class org.elasticsearch.index.AbstractIndexComponent
- DeprecationLogger - Class in org.elasticsearch.common.logging
-
A logger that logs deprecation notices.
- DeprecationLogger(Logger) - Constructor for class org.elasticsearch.common.logging.DeprecationLogger
-
Creates a new deprecation logger based on the parent logger.
- 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, String, DeprecationLogger) - Constructor for class org.elasticsearch.rest.DeprecationRestHandler
-
Create a
DeprecationRestHandler
that encapsulates thehandler
using thedeprecationLogger
to log deprecationwarning
. - DEPTH_FIRST - 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 org.elasticsearch.common.recycler.Recyclers
-
Return a recycler based on a deque.
- dequeFactory(Recycler.C<T>, int) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Return a recycler based on a deque.
- DequeRecycler<T> - Class in org.elasticsearch.common.recycler
-
A
Recycler
implementation based on aDeque
. - 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 - org.elasticsearch.search.sort.SortOrder
-
Descending order.
- descendsFromGlobalAggregator(Aggregator) - Static method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- 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
- 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 - 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, 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 - 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(SearchContextId, SearchShardTarget) - 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.ingest.IngestMetadata
- diff(Metadata.Custom) - Method in class org.elasticsearch.script.ScriptMetadata
- 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
- digestToString(long) - Static method in class org.elasticsearch.index.store.Store
-
Produces a string representation of the given digest value.
- DIRECT - org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- 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
- disabled() - Static method in class org.elasticsearch.http.CorsHandler
- DISABLED - org.elasticsearch.index.mapper.EnabledAttributeMapper
- 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
- disableStatePersistence() - Method in class org.elasticsearch.cluster.block.ClusterBlock
-
Should global state persistence be disabled when this block is present.
- disableStatePersistence() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
Returns
true
if one of the global blocks as its disable state persistence flag set. - disassociateDeadNodes(ClusterState) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
-
Unassign any persistent tasks executing on nodes that are no longer in the cluster.
- disassociateDeadNodes(ClusterState, boolean, String) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
unassigned an shards that are associated with nodes that are no longer part of the cluster, potentially promoting replicas if needed.
- disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.ClusterConnectionManager
-
Disconnected from the given node, if not connected, will do nothing.
- disconnectFromNode(DiscoveryNode) - Method in interface org.elasticsearch.transport.ConnectionManager
- disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
- disconnectFromNodesExcept(DiscoveryNodes) - Method in class org.elasticsearch.cluster.NodeConnectionsService
-
Disconnect from any nodes to which we are currently connected which do not appear in the given nodes.
- Discovery - 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 - 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, TransportService, 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 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
- 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) - 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 - org.elasticsearch.common.geo.ShapeRelation
- DISJOINT - 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
- 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
- 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 org.elasticsearch.Build.Flavor
- displayName() - Method in enum 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
- DISTANCE_ERROR_PCT - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults
-
Deprecated.
- DISTANCE_ERROR_PCT - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Names
-
Deprecated.
- distanceErrorPct - Variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- distanceErrorPct() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- 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 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(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- doBuild(QueryShardContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- doBuild(QueryShardContext, 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.ParseContext
- doc() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- doc() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- doc() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- doc() - Method in class org.elasticsearch.search.lookup.SearchLookup
- 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(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 - 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_VALUES - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- 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
- 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
- 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
- docDeltasBuilder - Variable in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- 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.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
- 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, int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.search.internal.SearchContext
- docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.search.internal.SubSearchContext
- docIdsToLoadFrom() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- docIdsToLoadFrom() - Method in class org.elasticsearch.search.internal.SearchContext
- docIdsToLoadFrom() - Method in class org.elasticsearch.search.internal.SubSearchContext
- docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.SearchContext
- docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.SubSearchContext
- DOCKER - org.elasticsearch.Build.Type
- DocLookup - Class in org.elasticsearch.search.lookup
- 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.TranslogLeafReader
- 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.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.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.MedianAbsoluteDeviationAggregator
- 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.internal.FilteredSearchContext
- doClose() - Method in class org.elasticsearch.search.internal.SearchContext
- doClose() - Method in class org.elasticsearch.search.internal.SubSearchContext
- 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
- docMapper() - Method in class org.elasticsearch.index.mapper.ParseContext
- docMapper() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- docMapperParser() - Method in class org.elasticsearch.index.mapper.ParseContext
- docMapperParser() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- 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. - doCreateInternal(SearchContext, Map<String, ValuesSourceConfig>, DocValueFormat, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
-
Create the Aggregator.
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceRangeAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregatorFactory
- doCreateInternal(SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
-
Create the Aggregator for a
ValuesSource
that has values. - docs - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- docs() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- docs() - Method in class org.elasticsearch.index.engine.Engine.Index
- docs() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- docs(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Docs - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- DOCS - org.elasticsearch.index.mapper.TextSearchInfo.TermVector
- 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
- 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 org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents fromdocValues
that have a value. - docsWithValue(SortedSetDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents fromdocValues
that have a value. - docsWithValue(MultiGeoPointValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents frompointValues
that have a value. - docsWithValue(SortedBinaryDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents fromvalues
that have a value. - docsWithValue(SortedNumericDoubleValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents fromdoubleValues
that have a value. - document(int, StoredFieldVisitor) - Method in class org.elasticsearch.index.engine.TranslogLeafReader
- Document() - Constructor for class org.elasticsearch.index.mapper.ParseContext.Document
- 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(StreamInput) - Constructor for class org.elasticsearch.common.document.DocumentField
- DocumentFieldMappers - Class in org.elasticsearch.index.mapper
- DocumentFieldMappers(Collection<FieldMapper>, Collection<FieldAliasMapper>, Analyzer) - Constructor for class org.elasticsearch.index.mapper.DocumentFieldMappers
- documentMapper() - Method in class org.elasticsearch.index.mapper.MapperService
-
Return the document mapper, or
null
if no mapping has been put yet. - documentMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Return the
DocumentMapper
for the given type. - documentMapper(String) - Method in class org.elasticsearch.index.query.QueryShardContext
-
Returns s
DocumentMapper
instance for the given type. - DocumentMapper - Class in org.elasticsearch.index.mapper
- DocumentMapper(MapperService, Mapping) - Constructor for class org.elasticsearch.index.mapper.DocumentMapper
- DocumentMapper.Builder - Class in org.elasticsearch.index.mapper
- DocumentMapperForType - Class in org.elasticsearch.index.mapper
- DocumentMapperForType(DocumentMapper, Mapping) - Constructor for class org.elasticsearch.index.mapper.DocumentMapperForType
- documentMapperParser() - Method in class org.elasticsearch.index.mapper.MapperService
- DocumentMapperParser - Class in org.elasticsearch.index.mapper
- DocumentMapperParser(IndexSettings, MapperService, NamedXContentRegistry, SimilarityService, MapperRegistry, Supplier<QueryShardContext>) - Constructor for class org.elasticsearch.index.mapper.DocumentMapperParser
- documentMapperWithAutoCreate(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Returns the document mapper created, including a mapping update if the type has been dynamically created.
- 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
- 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.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
- docValueField(String) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a field to load from doc values and return as part of the search request.
- docValueField(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a field to load from the doc values and return as part of the search request.
- docValueField(String, String) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a field to load from doc values and return as part of the search request.
- docValueField(String, String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a field to load from the doc values and return as part of the search request.
- docValueFields() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the docvalue fields.
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Return a
DocValueFormat
that can be used to display and parse values as returned by the fielddata API. - 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.DateTime - Class in org.elasticsearch.search
- DocValueFormat.Decimal - Class in org.elasticsearch.search
- docValues(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- docValues(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- docValuesByDefault() - Method in class org.elasticsearch.index.mapper.FieldMapper
- docValuesByDefault() - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- docValuesByDefault() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper
-
Deprecated.
- docValuesByDefault() - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- 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
- 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 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 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(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
- 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(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, 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, FieldCapabilitiesIndexRequest, ActionListener<FieldCapabilitiesIndexResponse>) - Method in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesIndexAction
- 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, MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.action.search.TransportMultiSearchAction
- 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
- 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.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
- 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.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, ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.TransportBulkAction
- doMasterOperation(GetIndexRequest, String[], ClusterState, ActionListener<GetIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
- doMasterOperation(GetMappingsRequest, String[], ClusterState, ActionListener<GetMappingsResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
- doMasterOperation(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(boolean) - Method in class org.elasticsearch.action.support.PlainListenableActionFuture
- 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 - org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Snapshot completed successfully
- DONE - org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot completed successfully
- DONE - 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.nested.NestedAggregator
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- 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.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.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
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- 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.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.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.TcpTransport
- 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.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(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- doToFunction(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- doToFunction(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- doToFunction(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Build the Lucene ScoreFunction for this builder.
- doToFunction(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- doToFunction(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.WeightBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanTermQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.TypeQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- DOUBLE - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- DOUBLE - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- DOUBLE - org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- DOUBLE - org.elasticsearch.index.mapper.RangeType
- DOUBLE - 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
- doubleField(FieldInfo, double) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- doubleField(FieldInfo, double) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- Doubles(SortedNumericDoubleValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- 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, 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 org.elasticsearch.index.mapper.RangeType
-
Given the Range.to or Range.from Object value from a Range instance, converts that value into a Double.
- doubleValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource
- doubleValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
-
Get the current
SortedNumericDoubleValues
. - 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
- doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
- 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.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
- 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.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.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.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.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
- 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
- doXContentAnalyzers(XContentBuilder, boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper
-
Deprecated.
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- doXContentBody(XContentBuilder, boolean, 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.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.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 InternalTerms.Bucket>) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- 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
- dvRangeQuery(String, BinaryDocValuesRangeQuery.QueryType, Object, Object, boolean, boolean) - Method in enum org.elasticsearch.index.mapper.RangeType
- dynamic - Variable in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- dynamic() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- dynamic(ObjectMapper.Dynamic) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- Dynamic - org.elasticsearch.common.settings.Setting.Property
-
iff this setting can be dynamically updateable
- DYNAMIC - Static variable in class org.elasticsearch.index.mapper.ObjectMapper.Defaults
- DYNAMIC_DATE_TIME_FORMATTERS - Static variable in class org.elasticsearch.index.mapper.RootObjectMapper.Defaults
- 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
- DynamicKeyFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper that supports lookup of dynamic sub-keys.
- DynamicKeyFieldMapper(String, FieldType, MappedFieldType, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.DynamicKeyFieldMapper
- 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 in org.elasticsearch.index.mapper
- DynamicTemplate.XContentFieldType - Enum in org.elasticsearch.index.mapper
-
The type of a field as detected while parsing a json document.
- dynamicTemplates - Variable in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- dynamicTemplates() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- dynamicTemplates(Collection<DynamicTemplate>) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
E
- EAGER_GLOBAL_ORDINALS - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper.Defaults
- EAGER_SINGLETON - Static variable in class org.elasticsearch.common.inject.internal.Scoping
- eagerGlobalOrdinals - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- eagerGlobalOrdinals() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- eagerGlobalOrdinals(boolean) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- eagerGlobalOrdinals(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- 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
- Edge(Coordinate, ShapeBuilder.Edge) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
- Edge(Coordinate, ShapeBuilder.Edge, Coordinate) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
- ELASTICSEARCH - 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.
- empty() - Static method in class org.elasticsearch.cluster.metadata.Manifest
- 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) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- empty(int) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- empty(int) - Static method in class org.elasticsearch.index.fielddata.plain.AbstractLeafGeoPointFieldData
- Empty() - Constructor for class org.elasticsearch.transport.TransportRequest.Empty
- Empty() - Constructor for class org.elasticsearch.transport.TransportResponse.Empty
- Empty(StreamInput) - Constructor for class org.elasticsearch.transport.TransportRequest.Empty
- EMPTY - org.elasticsearch.index.query.RegexpFlag
-
Enables empty language expression:
#
- 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.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.RepositoryCleanupInProgress
- EMPTY - Static variable in class org.elasticsearch.cluster.RestoreInProgress
- 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.bytes.BytesArray
- EMPTY - Static variable in class org.elasticsearch.common.geo.parsers.GeoWKTParser
- 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.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.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.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.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.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.transport.TransportRequestOptions
- EMPTY_ARRAY - Static variable in class 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_SETTINGS - Static variable in class org.elasticsearch.common.settings.Settings.Builder
- EMPTY_STATE - Static variable in class org.elasticsearch.cluster.ClusterState
- EMPTY_STATS - Static variable in class org.elasticsearch.repositories.RepositoryStats
- EMPTY_STORE - 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_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
- emptyGeoPoint() - Static method in enum org.elasticsearch.index.fielddata.FieldData
- emptyMultiGeoPoints() - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
SortedNumericDoubleValues
that doesn't contain any value. - emptyNumericDouble() - Static method in enum 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
- emptySortedBinary() - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
SortedBinaryDocValues
that doesn't contain any value. - emptySortedNumericDoubles() - Static method in enum 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_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 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 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 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 enum org.elasticsearch.index.mapper.EnabledAttributeMapper
- enabled - Variable in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- enabled() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- enabled(boolean) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- enabled(boolean) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- ENABLED - org.elasticsearch.index.mapper.EnabledAttributeMapper
- 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.TypeParser
- ENABLED_SETTING - Static variable in class org.elasticsearch.monitor.fs.FsHealthService
- ENABLED_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- EnabledAttributeMapper - Enum in org.elasticsearch.index.mapper
- enablePositionIncrements - Variable in class org.elasticsearch.index.search.MatchQuery
- 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. - encode(double, double, int) - Method in interface org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource.GeoPointLongEncoder
- 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.SearchContextHighlight.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 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.
- 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 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 in org.elasticsearch.index.engine
- Engine.Operation.TYPE - Enum 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 in org.elasticsearch.index.engine
- Engine.Searcher - Class in org.elasticsearch.index.engine
- Engine.SearcherScope - Enum in org.elasticsearch.index.engine
- Engine.SyncedFlushResult - Enum 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, String, 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, EngineConfig.TombstoneDocSupplier) - Constructor for class org.elasticsearch.index.engine.EngineConfig
-
Creates a new
EngineConfig
- EngineConfig.TombstoneDocSupplier - Interface in org.elasticsearch.index.engine
-
A supplier supplies tombstone documents which will be used in soft-update methods.
- 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.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. - ensureExpectedToken(XContentParser.Token, XContentParser.Token, Supplier<XContentLocation>) - 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.
- ensureMajorVersionBarrier(Version, Version) - Static method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
-
ensures that the joining node's major version is equal or higher to the minClusterNodeVersion.
- 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) - Static method in class org.elasticsearch.common.collect.HppcMaps
-
Wraps the given map and prevent adding of
null
keys. - 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.
- ensureOpen() - Method in class org.elasticsearch.action.bulk.BulkProcessor
- 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(Exception) - Method in class org.elasticsearch.index.engine.Engine
- 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
- entries - Variable in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- entries - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
- entries() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- entries() - 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, List<IndexId>, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, Version, String) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(SnapshotsInProgress.Entry, SnapshotsInProgress.State, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(SnapshotsInProgress.Entry, SnapshotsInProgress.State, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, String) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(SnapshotsInProgress.Entry, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>) - 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, List<IndexId>, long, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, Map<String, Object>, Version) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(Snapshot, boolean, boolean, SnapshotsInProgress.State, List<IndexId>, List<String>, long, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, String, Map<String, Object>, Version) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(Snapshot, boolean, boolean, SnapshotsInProgress.State, List<IndexId>, List<String>, long, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, 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.concurrent.ConcurrentHashMapLong
- 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.LeafFieldsLookup
- entrySet() - Method in class org.elasticsearch.search.lookup.SourceLookup
- env - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Useful to provide access to the node's environment like config directory to processor factories.
- envelope(EnvelopeBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- ENVELOPE - org.elasticsearch.common.geo.GeoShapeType
- EnvelopeBuilder - Class in org.elasticsearch.common.geo.builders
- EnvelopeBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.EnvelopeBuilder
-
Read from a stream.
- EnvelopeBuilder(Coordinate, Coordinate) - Constructor for class org.elasticsearch.common.geo.builders.EnvelopeBuilder
-
Build an envelope from the top left and bottom right coordinates.
- 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.
- EPOCH - Static variable in class org.elasticsearch.common.Table
- EPOCH_MILLIS - org.elasticsearch.common.time.FormatNames
- EPOCH_SECOND - 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, HyperLogLogPlusPlus) - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- 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.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.get.GetSnapshotsResponse
- 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.IndexFeatureStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
- 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.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.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.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.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.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.DataStreamMetadata
- 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.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.RepositoriesMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
- 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.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.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.bytes.AbstractBytesReference
- 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.FieldMemoryStats
- equals(Object) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- equals(Object) - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- equals(Object) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- equals(Object) - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- equals(Object) - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- equals(Object) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- equals(Object) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- 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.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.concurrent.ConcurrentHashMapLong
- equals(Object) - Method in class org.elasticsearch.common.util.CuckooFilter
- 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.GeoPointFieldMapper.ParsedGeoPoint
- equals(Object) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- equals(Object) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypesQuery
- 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.PrimaryReplicaSyncer.ResyncTask.Status
- equals(Object) - Method in class org.elasticsearch.index.shard.ReplicationGroup
- equals(Object) - Method in class org.elasticsearch.index.shard.ShardId
- 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.File
- 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.PluginInfo
- 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.ShardGenerations
- 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.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.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.ExtendedBounds
- 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.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.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.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.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.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.Decimal
- equals(Object) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
- equals(Object) - Method in class org.elasticsearch.search.fetch.subphase.FetchDocValuesContext.FieldAndFormat
- equals(Object) - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- 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.SearchContextId
- 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.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.RestoreInfo
- equals(Object) - Method in class org.elasticsearch.snapshots.Snapshot
- 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.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.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_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.PluginInfo
- ES_PLUGIN_PROPERTIES - Static variable in class org.elasticsearch.plugins.PluginInfo
- EsAbortPolicy - Class in org.elasticsearch.common.util.concurrent
- EsAbortPolicy() - Constructor for class org.elasticsearch.common.util.concurrent.EsAbortPolicy
- 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 - org.elasticsearch.index.query.SimpleQueryStringFlag
- escapeAndEncode(String) - Static method in class org.elasticsearch.common.logging.DeprecationLogger
-
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
- 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.SearchService.CanMatchResponse
- 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.shard.IndexShard
-
Returns the estimated number of history operations whose seq# at least the provided seq# in this shard.
- estimateNumberOfHistoryOperations(String, Engine.HistorySource, MapperService, 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, MapperService, 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, MapperService, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- 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.MaxSizeCondition
- evaluate(Condition.Stats) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownCondition
- eventListener - Variable in class org.elasticsearch.index.engine.Engine
- EVICTED - 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 - 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.index.mapper.SourceFieldMapper
- excludes() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- excludes(String[]) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- 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 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(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, 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 interface org.elasticsearch.search.SearchPhase
-
Executes the search phase
- 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) - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Executes all registered async actions and notifies the listener once it's done.
- executeAsyncActions(ActionListener) - Method in class org.elasticsearch.index.query.QueryShardContext
- executeBulkRequest(int, Iterable<DocWriteRequest<?>>, BiConsumer<Integer, Exception>, BiConsumer<Thread, Exception>, IntConsumer) - 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
- executeIO(CancellableThreads.IOInterruptible) - Method in class org.elasticsearch.common.util.CancellableThreads
-
run the Interruptible, capturing the executing thread.
- 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<Void>, BiConsumer<T, ActionListener<Void>>) - Method in class org.elasticsearch.transport.TransportRequestDeduplicator
-
Ensures a given request not executed multiple times when another equal request is already in-flight.
- 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
- 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.replication.TransportReplicationAction
- executor() - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- executor() - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.configuration.TransportAddVotingConfigExclusionsAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.configuration.TransportClearVotingConfigExclusionsAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.TransportCleanupRepositoryAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportDeleteStoredScriptAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetStoredScriptAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportPutStoredScriptAction
- executor() - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
- executor() - Method in class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
- executor() - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
- executor() - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
- executor() - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- executor() - Method in class org.elasticsearch.action.admin.indices.create.AutoCreateAction.TransportAction
- executor() - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
- executor() - Method in class org.elasticsearch.action.admin.indices.dangling.delete.TransportDeleteDanglingIndexAction
- executor() - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- executor() - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
- executor() - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
- executor() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportAutoPutMappingAction
- executor() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
- executor() - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- executor() - Method in class org.elasticsearch.action.admin.indices.readonly.TransportAddIndexBlockAction
- executor() - Method in class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- executor() - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
- executor() - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
- executor() - Method in class org.elasticsearch.action.admin.indices.shards.TransportIndicesShardStoresAction
- executor() - Method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComponentTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComposableIndexTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetComponentTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetComposableIndexTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.post.TransportSimulateIndexTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.post.TransportSimulateTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComponentTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeSettingsAction
- executor() - Method in class org.elasticsearch.action.ingest.DeletePipelineTransportAction
- executor() - Method in class org.elasticsearch.action.ingest.GetPipelineTransportAction
- executor() - Method in class org.elasticsearch.action.ingest.PutPipelineTransportAction
- executor() - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
- executor() - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- executor() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- executor() - Method in class org.elasticsearch.action.update.TransportUpdateAction
- executor() - Method in interface org.elasticsearch.index.shard.GlobalCheckpointListeners.GlobalCheckpointListener
-
The executor on which the listener is notified.
- executor() - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.TransportAction
- executor() - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.TransportAction
- executor() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.TransportAction
- executor() - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.TransportAction
- 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. - 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
- executorName() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
- executorName() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
-
The name of the executor that the implementation of the callbacks of this lister should be executed on.
- exist(String) - Static method in enum org.elasticsearch.common.time.FormatNames
- EXISTING_INDEX_RESTORED - 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 - 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(QueryShardContext) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.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
- 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
- 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 - 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
- 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.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 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.rest.action.admin.indices.RestAnalyzeAction.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 org.elasticsearch.index.VersionType
-
Returns a human readable explanation for a version conflict on read.
- explainConflictForWrites(long, long, boolean) - Method in enum 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, 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
- 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 Type 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() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return extended bounds for this histogram, or
null
if none are set. - 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(ExtendedBounds) - 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.
- ExtendedBounds - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ExtendedBounds(Long, Long) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
-
Construct with parsed bounds.
- ExtendedBounds(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
-
Construct with unparsed bounds.
- ExtendedBounds(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
-
Read from a stream.
- 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 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.
- ExtensiblePlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to be themselves extensible. - ExtensiblePlugin.ExtensionLoader - Interface in org.elasticsearch.plugins
- EXTERNAL - org.elasticsearch.index.engine.Engine.SearcherScope
- EXTERNAL - org.elasticsearch.index.VersionType
- EXTERNAL_GTE - org.elasticsearch.index.VersionType
- externalValue() - Method in class org.elasticsearch.index.mapper.ParseContext
- externalValueSet() - Method in class org.elasticsearch.index.mapper.ParseContext
- 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
- 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.
- 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.QueryShardContext)
by recursively removingBoostQuery
wrappers. - extractTerms(Set<Term>) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- extractValue(String, Map<?, ?>) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- extractValue(Map<?, ?>, String...) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- extractWarningValueFromWarningHeader(String, boolean) - Static method in class org.elasticsearch.common.logging.DeprecationLogger
-
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.common.geo.builders.ShapeBuilder
- 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(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 org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- failed() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- FAILED - org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- FAILED - org.elasticsearch.cluster.SnapshotsInProgress.State
- FAILED - org.elasticsearch.snapshots.SnapshotState
-
Snapshot failed
- FAILED_DEPENDENCY - 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_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.QueryShardContext
-
This method fails if
QueryShardContext.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(Exception) - Static method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
- failure(String) - Static method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- failure(T, Exception) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- Failure(String, int, Throwable) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
- Failure(String, int, Throwable) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
- Failure(String, int, Throwable, String) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
- Failure(String, int, Throwable, String) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
- Failure(String, String, int, Throwable) - Constructor for class 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 class 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 class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- FAILURE - org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Snapshot failed
- FAILURE - org.elasticsearch.cluster.RestoreInProgress.State
-
Restore failed
- FAILURE - org.elasticsearch.index.engine.Engine.Result.Type
- FAILURE - org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot failed
- FAILURE - 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 - org.elasticsearch.index.mapper.ObjectMapper.Dynamic
- FALSE - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper.Values
- familyTypeName() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the field family type, as used in field capabilities
- FAST_PHRASE_SUFFIX - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper
- 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
- FEATURE_PREFIX - Static variable in class org.elasticsearch.transport.TransportSettings
- features() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- features(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- FEET - org.elasticsearch.common.unit.DistanceUnit
- 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
- 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(List<FetchDocValuesContext.FieldAndFormat>) - Constructor for class org.elasticsearch.search.fetch.subphase.FetchDocValuesContext
- FetchDocValuesContext.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.
- 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
- fetchFields() - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Returns true if the stored fields should be fetched, false otherwise.
- FETCHING_SHARD_DATA - org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
Waiting on getting shard data from all nodes before making a decision about where to allocate the shard
- 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
- 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
- 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(SearchContextId, 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.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
- 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.search.fetch.subphase.FetchDocValuesContext.FieldAndFormat
-
The name of the field.
- field - Variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlighterContext
- 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.SearchContextHighlight.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.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.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.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 org.elasticsearch.common.rounding.DateTimeUnit
- 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.common.unit.Fuzziness
- FIELD - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- FIELD_COORDINATES - Static variable in interface org.elasticsearch.common.geo.parsers.ShapeParser
- 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_GEOMETRIES - Static variable in interface org.elasticsearch.common.geo.parsers.ShapeParser
- FIELD_NAME - Static variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- FIELD_ORIENTATION - Static variable in interface org.elasticsearch.common.geo.parsers.ShapeParser
- FIELD_PRECISION - Static variable in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- FIELD_RADIUS - Static variable in class org.elasticsearch.common.geo.builders.CircleBuilder
- FIELD_TYPE - Static variable in interface org.elasticsearch.common.geo.parsers.ShapeParser
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.Defaults
- 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.DateFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- 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.IndexFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.IpFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.NumberFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.RangeFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.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.index.mapper.TypeFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.VersionFieldMapper.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(String, String) - Constructor for class org.elasticsearch.search.fetch.subphase.FetchDocValuesContext.FieldAndFormat
-
Sole constructor.
- FieldAndFormat(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.FetchDocValuesContext.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, 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
- FieldCapabilitiesIndexRequest - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesIndexResponse - Class in org.elasticsearch.action.fieldcaps
-
Response for
TransportFieldCapabilitiesIndexAction
. - 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(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 in org.elasticsearch.index.fielddata
-
Utility methods, similar to Lucene's
DocValues
. - FieldData - 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) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Return a fielddata builder for this field
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- fielddataBuilder(String) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.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() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the field-data fields.
- 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
- fielddataMaxFrequency() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- fielddataMinFrequency() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- fielddataMinSegmentSize() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- 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
- FieldLookup - Class in org.elasticsearch.search.lookup
- fieldMapper(String) - Method in class org.elasticsearch.index.query.QueryShardContext
- FieldMapper - Class in org.elasticsearch.index.mapper
- FieldMapper(String, FieldType, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.FieldMapper
- FieldMapper.Builder<T extends FieldMapper.Builder<T>> - 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.MultiFields - Class in org.elasticsearch.index.mapper
- FieldMapper.MultiFields.Builder - Class in org.elasticsearch.index.mapper
- 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.SortedSetOrdinalsIndexFieldData
- 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.search.fetch.subphase.highlight.HighlighterContext
- 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
- 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
- FieldNameAnalyzer - Class in org.elasticsearch.index.analysis
- FieldNameAnalyzer(Map<String, Analyzer>) - Constructor for class org.elasticsearch.index.analysis.FieldNameAnalyzer
- 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
- FieldNamesFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- FieldNamesFieldType() - Constructor for class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- fieldOptions() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.Field
- FieldOptions() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.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.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.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.highlight.HighlightBuilder
- fields() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight
- 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.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.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.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.ingest.SimulatePipelineRequest.Fields
- Fields() - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- Fields() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.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. - FieldsLookup - Class in org.elasticsearch.search.lookup
- 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 - org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- 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.index.mapper.FieldMapper.Builder
- fieldType - Variable in class org.elasticsearch.index.mapper.FieldMapper
- fieldType - Variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointIndexer
- fieldType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlighterContext
- 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.FieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- 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.LegacyGeoShapeFieldMapper
-
Deprecated.
- 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() - Method in class org.elasticsearch.search.lookup.FieldLookup
- 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.internal.FilteredSearchContext
- fieldType(String) - Method in class org.elasticsearch.search.internal.SearchContext
-
Given the full name of a field, returns its
MappedFieldType
. - fieldTypes() - Method in class org.elasticsearch.index.mapper.MapperService
-
Returns all mapped field types.
- 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 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.
- file(String) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- File(String, long, boolean) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.File
- File(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.File
- 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
- 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.
- 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
- 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
- fileStore - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
-
Cached FileStore from path
- 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
- 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.transport.NodeDisconnectedException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.NotSerializableTransportException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.RemoteTransportException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
- 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(Terms, TermsEnum, LeafReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- filter(IntervalsSource, QueryShardContext, 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.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, SearchContext, 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, QueryShardContext, 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
- 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 - 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
- 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
- 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
- filterNodeIds(DiscoveryNodes, String[]) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- filterPlugins(Class<T>) - Method in class org.elasticsearch.plugins.PluginsService
- 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
- FiltersAggregator(String, AggregatorFactories, String[], Supplier<Weight[]>, boolean, String, SearchContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- 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, QueryShardContext, 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, LeafReaderContext) - 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
- 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 - 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 - org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Snapshot metadata is being written
- FINALIZE - org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot metadata is being written
- FINALIZE - 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(ShardGenerations, long, Metadata, SnapshotInfo, Version, Function<ClusterState, ClusterState>, ActionListener<RepositoryData>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- finalizeSnapshot(ShardGenerations, long, Metadata, SnapshotInfo, Version, Function<ClusterState, ClusterState>, ActionListener<RepositoryData>) - Method in class org.elasticsearch.repositories.FilterRepository
- finalizeSnapshot(ShardGenerations, long, Metadata, SnapshotInfo, Version, Function<ClusterState, ClusterState>, ActionListener<RepositoryData>) - Method in interface org.elasticsearch.repositories.Repository
-
Finalizes snapshotting process
- 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.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.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
- 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>>) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Finds all mappings for types and concrete indices.
- findNameFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Finds reference to a snapshotted file by its snapshot name
- findNestedObjectMapper(int, SearchContext, LeafReaderContext) - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
Returns the best nested
ObjectMapper
instances that is in the scope of the specified nested docId. - 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
- findTemplate(ContentPath, String, DynamicTemplate.XContentFieldType) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- findTemplateBuilder(ParseContext, String, String, DynamicTemplate.XContentFieldType) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
-
Find a template.
- findTemplateBuilder(ParseContext, String, DynamicTemplate.XContentFieldType) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- 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.
- finishAggregation() - Method in class org.elasticsearch.transport.InboundAggregator
- finishConstruction() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- finished - Variable in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- finishHim() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- 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 - org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- 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.
- FIXED - org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- FIXED - org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- FIXED_16 - org.elasticsearch.index.mapper.RangeType.LengthType
- FIXED_4 - org.elasticsearch.index.mapper.RangeType.LengthType
- FIXED_8 - org.elasticsearch.index.mapper.RangeType.LengthType
- FIXED_AUTO_QUEUE_SIZE - 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.
- fixNegativeQueryIfNeeded(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
- fixRedundantIncludes() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
-
Removes redundant root includes in
ObjectMapper.Nested
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(String) - Static method in class org.elasticsearch.repositories.ShardGenerations
-
Filters out unreliable numeric shard generations read from
RepositoryData
orIndexShardSnapshotStatus
, returningnull
in their place. - fixWeightedFragInfo(MappedFieldType, Field[], 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(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.
- flattenProcessors() - Method in class org.elasticsearch.ingest.CompoundProcessor
- flavor() - Method in class org.elasticsearch.Build
- FLOAT - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- FLOAT - org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- FLOAT - 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
- floatParam(String, boolean, Function<FieldMapper, Float>, float) - Static method in class org.elasticsearch.index.mapper.ParametrizedFieldMapper.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.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(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 - 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.
- 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 org.elasticsearch.common.hash.MurmurHash3
- FOLDER_FOUND_CAN_DELETE - 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 - 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 - org.elasticsearch.action.support.IndicesOptions.Option
- FORBID_CLOSED_INDICES - org.elasticsearch.action.support.IndicesOptions.Option
- forbidClosedIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
- FORBIDDEN - 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_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 - 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. - 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() - 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(SearchContextHighlight.Field) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight
- 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(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
- 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) - 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
. - 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.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.FetchDocValuesContext.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.mapper.DateFieldMapper.Builder
- 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.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(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(String) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- format(String) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- 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.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.NodeNamePatternConverter
- format(Passage[], String) - Method in class org.apache.lucene.search.uhighlight.CustomPassageFormatter
- format(BytesRef) - Method in interface org.elasticsearch.search.DocValueFormat
-
Format a binary value.
- 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_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 in org.elasticsearch.common.time
- formats - Variable in class org.elasticsearch.search.sort.SortAndFormats
- 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.
- formatter - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- 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
- formatWarning(String) - Static method in class org.elasticsearch.common.logging.DeprecationLogger
-
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 org.elasticsearch.common.geo.GeoShapeType
- forName(String) - Static method in enum 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>) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
Build a InternalAggregation.ReduceContext to perform a partial reduction.
- 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
- 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 - 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.SearchContextHighlight.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.SearchContextHighlight.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.SearchContextHighlight.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
- freeContext(SearchContextId) - Method in class org.elasticsearch.search.SearchService
- freezeContext() - Method in class org.elasticsearch.index.query.QueryShardContext
-
if this method is called the query context will throw exception if methods are accessed that could yield different results across executions like
QueryShardContext.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
- 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 - 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 - 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
- fromAllocationStatus(UnassignedInfo.AllocationStatus) - Static method in enum 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 org.elasticsearch.common.Priority
- 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 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 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 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 org.elasticsearch.Build.Flavor
- fromDisplayName(String, boolean) - Static method in enum org.elasticsearch.Build.Type
- fromEdits(int) - Static method in class org.elasticsearch.common.unit.Fuzziness
-
Creates a
Fuzziness
instance from an edit distance. - 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 org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- fromId(byte) - Static method in enum org.elasticsearch.action.DocWriteRequest.OpType
- fromId(byte) - Static method in enum org.elasticsearch.action.search.SearchType
-
Constructs search type based on the internal id.
- fromId(byte) - Static method in enum org.elasticsearch.action.ThreadingModel
- fromId(byte) - Static method in enum org.elasticsearch.cluster.metadata.IndexMetadata.State
- fromId(byte) - Static method in enum org.elasticsearch.index.shard.IndexShardState
- fromId(byte) - Static method in enum org.elasticsearch.index.translog.Translog.Operation.Type
- fromId(byte) - Static method in enum org.elasticsearch.indices.recovery.RecoveryState.Stage
- fromId(int) - Static method in enum org.elasticsearch.common.unit.ByteSizeUnit
- fromId(int) - Static method in class org.elasticsearch.Version
- 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
- fromMap(Map<String, Object>, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromMeters(double) - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Convert a value given in meters to a value of this unit
- fromName(String) - Static method in enum 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
- 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 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 org.elasticsearch.index.IndexModule.Type
- FromSingle(BigArrays) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- fromStream(StreamInput) - Static method in enum 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 org.elasticsearch.action.DocWriteRequest.OpType
- fromString(String) - Static method in enum org.elasticsearch.action.search.SearchType
-
The a string representation search type to execute, defaults to
SearchType.DEFAULT
. - fromString(String) - Static method in enum org.elasticsearch.cluster.health.ClusterHealthStatus
- fromString(String) - Static method in enum org.elasticsearch.cluster.metadata.IndexMetadata.State
- fromString(String) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
- fromString(String) - Static method in enum org.elasticsearch.common.geo.GeoDistance
-
Get a
GeoDistance
according to a given name. - fromString(String) - Static method in enum org.elasticsearch.common.geo.SpatialStrategy
- fromString(String) - Static method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
- fromString(String) - Static method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- fromString(String) - Static method in enum org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- fromString(String) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
-
Convert a String to a
DistanceUnit
- fromString(String) - Static method in enum org.elasticsearch.index.mapper.DynamicTemplate.MatchType
- fromString(String) - Static method in enum org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- fromString(String) - Static method in enum org.elasticsearch.index.query.GeoExecType
- fromString(String) - Static method in enum org.elasticsearch.index.query.GeoValidationMethod
- fromString(String) - Static method in enum 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 org.elasticsearch.index.VersionType
- fromString(String) - Static method in enum org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- fromString(String) - Static method in enum org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- fromString(String) - Static method in enum org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- fromString(String) - Static method in enum org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
- fromString(String) - Static method in enum org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- fromString(String) - Static method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- fromString(String) - Static method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- fromString(String) - Static method in enum org.elasticsearch.search.MultiValueMode
-
A case insensitive version of
MultiValueMode.valueOf(String)
- fromString(String) - Static method in enum org.elasticsearch.search.rescore.QueryRescoreMode
- fromString(String) - Static method in enum org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
- fromString(String) - Static method in enum org.elasticsearch.search.sort.SortMode
- fromString(String) - Static method in enum org.elasticsearch.search.sort.SortOrder
- fromString(String) - Static method in enum 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 org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory.ExecutionMode
- fromString(String, DeprecationLogger) - Static method in enum org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory.ExecutionMode
- fromString(String, VersionType) - Static method in enum org.elasticsearch.index.VersionType
- fromType(String) - Static method in enum org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- fromValue(byte) - Static method in enum org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Generate snapshot state from code
- fromValue(byte) - Static method in enum org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- fromValue(byte) - Static method in enum org.elasticsearch.cluster.health.ClusterHealthStatus
- fromValue(byte) - Static method in enum org.elasticsearch.cluster.RestoreInProgress.State
-
Returns state corresponding to state code
- fromValue(byte) - Static method in enum org.elasticsearch.cluster.routing.ShardRoutingState
- fromValue(byte) - Static method in enum org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- fromValue(byte) - Static method in enum org.elasticsearch.cluster.SnapshotsInProgress.State
- fromValue(byte) - Static method in enum org.elasticsearch.index.VersionType
- fromValue(byte) - Static method in enum 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(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.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.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.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 class org.elasticsearch.action.search.ShardSearchFailure
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- fromXContent(XContentParser) - Static method in class 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.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.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) - Method in class org.elasticsearch.common.geo.GeoJson
- fromXContent(XContentParser) - Method in interface org.elasticsearch.common.geo.GeometryFormat
-
Parser JSON representation of a geometry
- 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.BoolQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.BoostingQueryBuilder
- 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
- 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.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.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.SearchSourceBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.collapse.CollapseBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.fetch.subphase.FetchDocValuesContext.FieldAndFormat
-
Parse a
FetchDocValuesContext.FieldAndFormat
from someXContent
. - fromXContent(XContentParser) - Static method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- 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.SearchProfileShardResults
- 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.SnapshotShardFailure
-
Deserializes snapshot failure information from JSON
- fromXContent(XContentParser) - Static method in class org.elasticsearch.tasks.TaskInfo
- 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, 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.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.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
- 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(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
- FS - org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- FS - 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(long, FsInfo.IoStats, FsInfo.Path[], DiskUsage, DiskUsage) - 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, 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, ClusterInfoService) - Constructor for class org.elasticsearch.monitor.fs.FsService
- FULL_CONCURRENCY_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- 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 class 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 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.MatchQuery
- 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 - 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
- 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.MatchQuery
- 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, QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- fuzzyQuery(Object, Fuzziness, int, int, boolean, QueryShardContext) - 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.MatchQuery
- 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 - org.elasticsearch.cluster.metadata.Metadata.XContentContext
- GATEWAY_TIMEOUT - 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
- GatewayException - Exception in org.elasticsearch.gateway
- GatewayException(StreamInput) - Constructor for exception org.elasticsearch.gateway.GatewayException
- 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
- 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 - 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
- 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
- generateShardId(IndexMetadata, String, String) - Static method in class org.elasticsearch.cluster.routing.OperationRouting
- 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 - org.elasticsearch.search.suggest.completion.context.ContextMapping.Type
- 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, ShapeBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.use
QueryBuilders.geoDisjointQuery(String, Geometry)
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 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, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - 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 in org.elasticsearch.index.query
-
Specifies how a geo query should be run.
- 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 class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.PrefixTrees
-
Deprecated.
- GEOHASH - Static variable in interface org.elasticsearch.search.DocValueFormat
- GEOHASH_TREE_LEVELS - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults
-
Deprecated.
- geoHashCellHeight(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the height (in meters) of geohash cells at a specific level
- 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, SearchContext, 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, ShapeBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.
- 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(boolean, boolean, GeometryValidator) - Constructor for class org.elasticsearch.common.geo.GeoJson
- GeoLineDecomposer - Class in org.elasticsearch.common.geo
-
Splits lines by datelines.
- GEOMETRYCOLLECTION - org.elasticsearch.common.geo.GeoShapeType
- GeometryCollectionBuilder - Class in org.elasticsearch.common.geo.builders
- GeometryCollectionBuilder() - Constructor for class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
Build and empty GeometryCollectionBuilder.
- GeometryCollectionBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
Read from a stream.
- geometryFormat(XContentParser) - Method in class org.elasticsearch.common.geo.GeometryParser
-
Returns a geometry format object that can parse and then serialize the object back to the same format.
- geometryFormat(XContentParser, AbstractPointGeometryFieldMapper) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.PointParser
- GeometryFormat<ParsedFormat> - Interface in org.elasticsearch.common.geo
-
Geometry serializer/deserializer
- geometryIndexer - Variable in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- geometryIndexer() - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- 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() - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- GeometryParser - Class in org.elasticsearch.common.geo
-
An utility class with a geometry parser methods supporting different shape representation formats
- GeometryParser(boolean, boolean, boolean) - Constructor for class org.elasticsearch.common.geo.GeometryParser
- geometryQueryBuilder - Variable in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- geometryQueryBuilder() - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- geometryToShapeBuilder(Geometry) - Static method in class org.elasticsearch.index.query.LegacyGeoShapeQueryProcessor
- 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 - org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- GEOPOINT - org.elasticsearch.search.aggregations.support.ValueType
- GeoPointFieldMapper - Class in org.elasticsearch.index.mapper
-
Field Mapper for geo_point types.
- GeoPointFieldMapper(String, FieldType, MappedFieldType, FieldMapper.MultiFields, Explicit<Boolean>, Explicit<Boolean>, AbstractPointGeometryFieldMapper.ParsedPoint, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper
- GeoPointFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.GeoPointFieldType - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.GeoPointIndexer - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.ParsedGeoPoint - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- GeoPointFieldType(String) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- GeoPointFieldType(String, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- GeoPoints(MultiGeoPointValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- 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
-
A filter to filter based on a polygon defined by a set of locations / points.
- GeoPolygonQueryBuilder - Class in org.elasticsearch.index.query
- GeoPolygonQueryBuilder(String, List<GeoPoint>) - Constructor for class org.elasticsearch.index.query.GeoPolygonQueryBuilder
- GeoPolygonQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
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, FieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Explicit<Boolean>, Explicit<ShapeBuilder.Orientation>, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- GeoShapeFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- GeoShapeFieldMapper.GeoShapeFieldType - Class in org.elasticsearch.index.mapper
- GeoShapeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- GeoShapeFieldType(String) - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- GeoShapeFieldType(String, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.GeoShapeFieldMapper.GeoShapeFieldType
- GeoShapeFieldType(String, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- 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
- 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, ShapeBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.use
QueryBuilders.geoShapeQuery(String, Geometry)
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
- 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, ShapeBuilder) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Deprecated.use
GeoShapeQueryBuilder(String, Geometry)
instead - 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
- GeoShapeType - Enum in org.elasticsearch.common.geo
-
Enumeration that lists all
GeoShapeType
s that can be parsed and indexed - 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
- 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, SearchContext, 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
- 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 in org.elasticsearch.common.geo
-
Represents the point of the geohash cell that should be used as the value of geohash
- GeoValidationMethod - Enum 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, ShapeBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.use
QueryBuilders.geoWithinQuery(String, Geometry)
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
- GeoWKTParser - Class in org.elasticsearch.common.geo.parsers
-
Parses shape geometry represented in WKT format complies with OGC® document: 12-063r5 and ISO/IEC 13249-3:2016 standard located at http://docs.opengeospatial.org/is/12-063r5/12-063r5.html
- 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.FieldCapabilitiesIndexResponse
-
Get the field capabilities map
- get() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
-
Get the field capabilities map.
- get() - Method in class org.elasticsearch.cluster.AbstractDiffable
- 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.similarity.SimilarityProvider
-
Return the wrapped
Similarity
. - get() - Method in class org.elasticsearch.index.translog.TragicExceptionHolder
- get() - Method in class org.elasticsearch.transport.OutboundHandler.SendContext
- get(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- get(double, Explanation) - Method in class org.elasticsearch.script.ScoreScript.ExplanationHolder
- 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.ByteBufferReference
- 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.BitArray
-
Is the
index
th bit set? - 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 interface org.elasticsearch.common.util.ByteArray
-
Get an element given its index.
- get(long) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- 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, 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(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.common.collect.CopyOnWriteHashMap
- get(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- 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.LeafFieldsLookup
- 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.ParseContext.Document
- 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(CheckedConsumer<PlainActionFuture<T>, E>) - Static method in class org.elasticsearch.action.support.PlainActionFuture
- 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(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, BiFunction<String, Engine.SearcherScope, Engine.Searcher>) - Method in class org.elasticsearch.index.engine.Engine
- get(Engine.Get, BiFunction<String, Engine.SearcherScope, Engine.Searcher>) - Method in class org.elasticsearch.index.engine.InternalEngine
- get(Engine.Get, BiFunction<String, Engine.SearcherScope, 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 - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- Get(boolean, boolean, String, String, Term) - Constructor for class org.elasticsearch.index.engine.Engine.Get
- GET - org.elasticsearch.rest.RestRequest.Method
- GET - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- 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
- 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.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
- 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
- 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
- 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 - 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
-
Return the
AggregationProfiler
. - getAggregationProfileResults() - Method in class org.elasticsearch.search.profile.ProfileShardResult
- 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
- getAggregationUsage() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- getAggregator(ValuesSourceConfig, String) - 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 - 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.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>>) - 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
- 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 - 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. - 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.index.engine.EngineConfig
-
Returns the allocation ID for the 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.
- 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(DocumentMapper, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- getAnalyzer(MappedFieldType, boolean) - Method in class org.elasticsearch.index.search.MatchQuery
- getAnalyzer(Version) - Method in enum 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
- getAnyRemoteConnection() - Method in class org.elasticsearch.transport.RemoteConnectionManager
- 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
- getArgs(Geometry, ShapeRelation) - Static method in class org.elasticsearch.index.query.LegacyGeoShapeQueryProcessor
- getAsBoolean() - Method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.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(Params, ClusterState) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Returns the node id where the params has to be executed,
- 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.
- 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
- getAverageSizeInBytes() - Method in class org.elasticsearch.index.shard.DocsStats
-
Returns the average size in bytes of all documents in this stats.
- 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
- 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
- getBinaryDocValues(String) - Method in class org.elasticsearch.index.engine.TranslogLeafReader
- getBinaryValue(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- getBinding() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- getBitsetFilterCache() - Method in class org.elasticsearch.index.query.QueryShardContext
- 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
- getblock(byte[], int, int) - Static method in enum 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 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
- getBreaker() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- 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(SearchContextHighlight.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.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.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
- getBuilder(CoordinateNode, DistanceUnit.Distance, ShapeBuilder.Orientation, boolean) - Method in enum org.elasticsearch.common.geo.GeoShapeType
- 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.ParseContext.Document
-
Get back fields that have been previously added with
ParseContext.Document.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()
. - 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
- getBytesWanted() - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- getBytesWritten() - Method in class org.elasticsearch.transport.StatsTracker
- getCache() - Method in enum 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
- 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 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 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 class 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
- 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
- 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. - getChildQuery() - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
-
Return the child query.
- 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
- 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.PluginInfo
-
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
- getClient() - Method in class org.elasticsearch.index.query.QueryShardContext
- getClientActions() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Client actions added by this plugin.
- 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
- 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
- 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
- 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
- getComparator(SortOrder) - Static method in class org.elasticsearch.search.sort.MinAndMax
- 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
- 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
- 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
- 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 boolean indicating if compression is enabled or
null
if no explicit compression is set on this profile. - getCompressionLevel() - Method in class org.elasticsearch.http.HttpHandlingSettings
- 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 - getConcreteIndexAndAliasMetadatas() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
-
Returns the unique alias metadata per concrete index.
- 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.
- 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(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.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
- 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
- getCopySettings() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- getCoreCacheHelper() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
- getCoreCacheHelper() - Method in class org.elasticsearch.index.engine.TranslogLeafReader
- 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
-
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
- 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 current profiler.
- 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.gateway.PersistedClusterStateService
- getDataStream() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- getDataStream() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- getDataStreamMappingSnippet() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- getDataStreams() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getDataStreams() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- getDataStreamTemplate() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- 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 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
- 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(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.AllFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.IdFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in interface org.elasticsearch.index.mapper.MetadataFieldMapper.TypeParser
-
Get the default
MetadataFieldMapper
to use, if nothing had to be parsed. - getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper.TypeParser
- 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.
- 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) - getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedBytesHashSamplerAggregator
- getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedMapSamplerAggregator
- getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedNumericSamplerAggregator
- getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedOrdinalsSamplerAggregator
- getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractRareTermsAggregator
- 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
- 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
- getDeprecatedMethod() - Method in class org.elasticsearch.rest.RestHandler.ReplacedRoute
- getDeprecatedPath() - Method in class org.elasticsearch.rest.RestHandler.ReplacedRoute
- getDeprecationMessage() - Method in class org.elasticsearch.rest.RestHandler.DeprecatedRoute
- 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.restore.RestoreSnapshotRequest
- getDescription() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- 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.search.SearchScrollRequest
- 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 class org.elasticsearch.indices.SystemIndexDescriptor
- 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.PluginInfo
-
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.Persistent