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
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.State
- ABORTED - org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot aborted
- abortIfNotCompleted(String) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set whether or not version conflicts cause the action to abort.
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- abortRelocationHandoff() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Fails a relocation handoff attempt.
- absoluteTimeInMillis() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Returns the value of milliseconds since UNIX epoch.
- AbstractAggregationBuilder<AB extends AbstractAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations
-
Base implementation of a
AggregationBuilder
. - AbstractAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Constructs a new aggregation builder.
- AbstractAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Read from a stream.
- AbstractAggregationBuilder(AbstractAggregationBuilder<AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- AbstractAllocateAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Abstract base class for allocating an unassigned shard to a node
- AbstractAllocateAllocationCommand(String, int, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- AbstractAllocateAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Read from a stream.
- AbstractAllocateAllocationCommand.Builder<T extends AbstractAllocateAllocationCommand> - Class in org.elasticsearch.cluster.routing.allocation.command
-
Works around ObjectParser not supporting constructor arguments.
- AbstractAllocationDecision - Class in org.elasticsearch.cluster.routing.allocation
-
An abstract class for representing various types of allocation decisions.
- AbstractAllocationDecision(DiscoveryNode, List<NodeAllocationResult>) - Constructor for class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- AbstractAllocationDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- AbstractAsyncTask - Class in org.elasticsearch.common.util.concurrent
-
A base class for tasks that need to repeat.
- AbstractAsyncTask(Logger, ThreadPool, TimeValue, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- AbstractAtomicGeoPointFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractAtomicGeoPointFieldData() - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractAtomicGeoPointFieldData
- AbstractAtomicOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractAtomicOrdinalsFieldData(Function<SortedSetDocValues, ScriptDocValues<?>>) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractAtomicOrdinalsFieldData
- AbstractBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- AbstractBindingBuilder<T> - Class in org.elasticsearch.common.inject.internal
-
Bind a value or constant.
- AbstractBindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- AbstractBlobContainer - Class in org.elasticsearch.common.blobstore.support
-
A base abstract blob container that implements higher level container methods.
- AbstractBlobContainer(BlobPath) - Constructor for class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
- AbstractBulkByScrollRequest<Self extends AbstractBulkByScrollRequest<Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkByScrollRequest() - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Constructor for deserialization.
- AbstractBulkByScrollRequest(SearchRequest, boolean) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Constructor for actual use.
- AbstractBulkByScrollRequestBuilder<Request extends AbstractBulkByScrollRequest<Request>,Self extends AbstractBulkByScrollRequestBuilder<Request,Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkByScrollRequestBuilder(ElasticsearchClient, Action<Request, BulkByScrollResponse, Self>, SearchRequestBuilder, Request) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
- AbstractBulkIndexByScrollRequest<Self extends AbstractBulkIndexByScrollRequest<Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkIndexByScrollRequest() - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
-
Constructor for deserialization.
- AbstractBulkIndexByScrollRequest(SearchRequest, boolean) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
-
Constructor for actual use.
- AbstractBulkIndexByScrollRequestBuilder<Request extends AbstractBulkIndexByScrollRequest<Request>,Self extends AbstractBulkIndexByScrollRequestBuilder<Request,Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkIndexByScrollRequestBuilder(ElasticsearchClient, Action<Request, BulkByScrollResponse, Self>, SearchRequestBuilder, Request) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequestBuilder
- AbstractCatAction - Class in org.elasticsearch.rest.action.cat
- AbstractCatAction(Settings) - 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
- AbstractComponent - Class in org.elasticsearch.common.component
-
Deprecated.declare your own logger
- AbstractComponent() - Constructor for class org.elasticsearch.common.component.AbstractComponent
-
Deprecated.
- 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
- AbstractHDRPercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- AbstractHDRPercentilesAggregator(String, ValuesSource.Numeric, SearchContext, Aggregator, double[], int, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- 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
- AbstractIndexAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Class in org.elasticsearch.index.analysis
- AbstractIndexAnalyzerProvider(IndexSettings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
-
Constructs a new analyzer component, with the index name and its settings and the analyzer name.
- AbstractIndexComponent - Class in org.elasticsearch.index
- AbstractIndexComponent(IndexSettings) - Constructor for class org.elasticsearch.index.AbstractIndexComponent
-
Constructs a new index component, with the index name and its settings.
- AbstractIndexFieldData<FD extends AtomicFieldData> - Class in org.elasticsearch.index.fielddata.plain
- AbstractIndexFieldData(IndexSettings, String, IndexFieldDataCache) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- AbstractIndexFieldData.PerValueEstimator - Interface in org.elasticsearch.index.fielddata.plain
-
A
PerValueEstimator
is a sub-class that can be used to estimate the memory overhead for loading the data. - AbstractIndexOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractIndexOrdinalsFieldData(IndexSettings, String, IndexFieldDataCache, CircuitBreakerService, double, double, int) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- AbstractIndexShardComponent - Class in org.elasticsearch.index.shard
- AbstractIndexShardComponent(ShardId, IndexSettings) - Constructor for class org.elasticsearch.index.shard.AbstractIndexShardComponent
- AbstractInternalProfileTree<PB extends AbstractProfileBreakdown<?>,E> - Class in org.elasticsearch.search.profile
- AbstractInternalProfileTree() - Constructor for class org.elasticsearch.search.profile.AbstractInternalProfileTree
- AbstractLatLonPointDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLatLonPointDVIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- AbstractLatLonPointDVIndexFieldData.LatLonPointDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLifecycleComponent - Class in org.elasticsearch.common.component
- AbstractLifecycleComponent() - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
- AbstractLifecycleComponent(Settings) - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
-
Deprecated.the settings parameters are not used, therefore the use of this constructor is deprecated. Going to be removed in subsequent versions. The parameterless constructor should be used instead.
- 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.movavg.models.MovAvgModel.AbstractModelParser
- AbstractModule - Class in org.elasticsearch.common.inject
-
A support class for
Module
s which reduces repetition and results in a more readable configuration. - AbstractModule() - Constructor for class org.elasticsearch.common.inject.AbstractModule
- AbstractNamedDiffable<T extends NamedDiffable<T>> - Class in org.elasticsearch.cluster
-
Abstract diffable object with simple diffs implementation that sends the entire object if object has changed or nothing is object remained the same.
- AbstractNamedDiffable() - Constructor for class org.elasticsearch.cluster.AbstractNamedDiffable
- AbstractNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- AbstractPipelineAggregationBuilder<PAB extends AbstractPipelineAggregationBuilder<PAB>> - Class in org.elasticsearch.search.aggregations.pipeline
-
Base implementation of a
PipelineAggregationBuilder
. - AbstractPipelineAggregationBuilder(String, String, String[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- AbstractPipelineAggregationBuilder(StreamInput, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
-
Read from a stream.
- AbstractProcessor - Class in org.elasticsearch.ingest
-
An Abstract Processor that holds a processorTag field to be used by other processors.
- AbstractProcessor(String) - Constructor for class org.elasticsearch.ingest.AbstractProcessor
- AbstractProfileBreakdown<T extends java.lang.Enum<T>> - Class in org.elasticsearch.search.profile
-
A record of timings for the various operations that may happen during query execution.
- AbstractProfileBreakdown(Class<T>) - Constructor for class org.elasticsearch.search.profile.AbstractProfileBreakdown
-
Sole constructor.
- AbstractProfiler<PB extends AbstractProfileBreakdown<?>,E> - Class in org.elasticsearch.search.profile
- AbstractProfiler(AbstractInternalProfileTree<PB, E>) - Constructor for class org.elasticsearch.search.profile.AbstractProfiler
- AbstractQueryBuilder<QB extends AbstractQueryBuilder<QB>> - Class in org.elasticsearch.index.query
-
Base class for all classes producing lucene queries.
- AbstractQueryBuilder() - Constructor for class org.elasticsearch.index.query.AbstractQueryBuilder
- AbstractQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.AbstractQueryBuilder
- AbstractRangeAggregatorFactory<AF extends AbstractRangeAggregatorFactory<AF,R>,R extends RangeAggregator.Range> - Class in org.elasticsearch.search.aggregations.bucket.range
- AbstractRangeAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, R[], boolean, InternalRange.Factory<?, ?>, SearchContext, 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
- AbstractRecyclerC<T> - Class in org.elasticsearch.common.recycler
- AbstractRecyclerC() - Constructor for class org.elasticsearch.common.recycler.AbstractRecyclerC
- AbstractRefCounted - Class in org.elasticsearch.common.util.concurrent
-
A basic RefCounted implementation that is initialized with a ref count of 1 and calls
AbstractRefCounted.closeInternal()
once it reaches a 0 ref count - AbstractRefCounted(String) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractRefCounted
- AbstractResourceWatcher<Listener> - Class in org.elasticsearch.watcher
-
Abstract resource watcher framework, which handles adding and removing listeners and calling resource observer.
- AbstractResourceWatcher() - Constructor for class org.elasticsearch.watcher.AbstractResourceWatcher
- AbstractRestChannel - Class in org.elasticsearch.rest
- AbstractRestChannel(RestRequest, boolean) - Constructor for class org.elasticsearch.rest.AbstractRestChannel
-
Construct a channel for handling the request.
- AbstractRoutingChangesObserver() - Constructor for class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- AbstractRunnable - Class in org.elasticsearch.common.util.concurrent
-
An extension to runnable.
- AbstractRunnable() - Constructor for class org.elasticsearch.common.util.concurrent.AbstractRunnable
- AbstractScopedSettings - Class in org.elasticsearch.common.settings
-
A basic setting service that can be used for per-index and per-cluster settings.
- AbstractScopedSettings(Settings, Set<Setting<?>>, Set<SettingUpgrader<?>>, Setting.Property) - Constructor for class org.elasticsearch.common.settings.AbstractScopedSettings
- AbstractScopedSettings(Settings, Settings, AbstractScopedSettings) - Constructor for class org.elasticsearch.common.settings.AbstractScopedSettings
- AbstractScopedSettings.SettingUpdater<T> - Interface in org.elasticsearch.common.settings
-
Transactional interface to update settings.
- AbstractSortedDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractSortedDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- AbstractSortedNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractSortedNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- AbstractSortedSetDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractSortedSetDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- AbstractSortingNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractSortingNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- AbstractTDigestPercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- AbstractTDigestPercentilesAggregator(String, ValuesSource.Numeric, SearchContext, Aggregator, double[], double, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- 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, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenizerFactory
- accept() - Method in class org.apache.lucene.analysis.miscellaneous.DeDuplicatingTokenFilter
- accept(int) - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.LongFilter
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.PartitionedLongFilter
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.SetBackedLongFilter
- accept(long, Exception) - Method in interface org.elasticsearch.index.shard.GlobalCheckpointListeners.GlobalCheckpointListener
-
Callback when the global checkpoint is updated or the shard is closed.
- accept(BytesRef) - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Always accept the term.
- accept(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.StringFilter
- accept(T) - Method in interface org.elasticsearch.common.CheckedConsumer
- accept(T, U) - Method in interface org.elasticsearch.common.CheckedBiConsumer
- acceptDataLoss - Variable in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- acceptDataLoss - Variable in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand.Builder
- acceptDataLoss() - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
-
The operation only executes if the user explicitly agrees to possible data loss
- ACCEPTED - org.elasticsearch.rest.RestStatus
-
The request has been accepted for processing, but the processing has not been completed.
- acceptedGlobalOrdinals - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- acceptedGlobalOrdinals(SortedSetDocValues) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.OrdinalsFilter
- acceptIncomingRequests() - Method in class org.elasticsearch.transport.TransportService
-
start accepting incoming requests.
- acceptScopingVisitor(BindingScopingVisitor<V>) - Method in interface org.elasticsearch.common.inject.Binding
-
Accepts a scoping visitor.
- acceptScopingVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in interface org.elasticsearch.common.inject.Binding
-
Accepts a target visitor.
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- acceptVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.Scoping
- acceptVisitor(ElementVisitor<R>) - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- acceptVisitor(ElementVisitor<T>) - Method in interface org.elasticsearch.common.inject.spi.Element
-
Accepts an element visitor.
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.Message
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
- acceptVisitor(ElementVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- 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
- ack() - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledResponse
- 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
Discovery.AckListener
so that the cluster state update can be acknowledged - AckClusterStatePublishResponseHandler(Set<DiscoveryNode>, Discovery.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, Action<Request, Response, RequestBuilder>, 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() - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedResponse(boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- ackTimeout() - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
- ackTimeout() - Method in interface org.elasticsearch.cluster.ack.AckedRequest
-
Returns the acknowledgement timeout
- ackTimeout() - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Returns the maximum time interval to wait for acknowledgements
- ackTimeout() - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout(TimeValue) - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Sets the acknowledgement timeout
- acquire() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
- acquire(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Acquires a lock for the given key.
- acquireAllPrimaryOperationsPermits(ActionListener<Releasable>, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire all primary operation permits.
- acquireAllReplicaOperationsPermits(long, long, long, ActionListener<Releasable>, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire all replica operation permits whenever the shard is ready for indexing (see
IndexShard.acquireAllPrimaryOperationsPermits(ActionListener, TimeValue)
. - acquireFSLockForPaths(IndexSettings, Path...) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Acquires, then releases, all
write.lock
files in the given shard paths. - acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Snapshots the most recent index and returns a handle to it.
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
Creates a new
IndexCommit
snapshot from the currently running engine. - acquirePrimaryOperationPermit(ActionListener<Releasable>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a primary operation permit whenever the shard is ready for indexing.
- acquirePrimaryOperationPermit(IndexShard, TransportVerifyShardBeforeCloseAction.ShardRequest, ActionListener<Releasable>) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- acquirePrimaryOperationPermit(IndexShard, Request, ActionListener<Releasable>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Executes the logic for acquiring one or more operation permit on a primary shard.
- acquireReplicaOperationPermit(long, long, long, ActionListener<Releasable>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a replica operation permit whenever the shard is ready for indexing (see
IndexShard.acquirePrimaryOperationPermit(ActionListener, String, Object)
). - acquireReplicaOperationPermit(IndexShard, TransportVerifyShardBeforeCloseAction.ShardRequest, ActionListener<Releasable>, long, long, long) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- acquireReplicaOperationPermit(IndexShard, ReplicaRequest, ActionListener<Releasable>, long, long, long) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Executes the logic for acquiring one or more operation permit on a replica shard.
- acquireRetentionLock() - Method in class org.elasticsearch.index.engine.Engine
-
Acquires a lock on the translog files and Lucene soft-deleted documents to prevent them from being trimmed
- acquireRetentionLock() - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireRetentionLock() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireRetentionLock() - 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
- 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<Request extends ActionRequest,Response extends ActionResponse,RequestBuilder extends ActionRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action
-
Base action.
- Action(String) - Constructor for class org.elasticsearch.action.Action
- 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(GenericAction<Request, 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) - 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,RequestBuilder extends ActionRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action
- ActionRequestBuilder(ElasticsearchClient, Action<Request, Response, RequestBuilder>, 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.
- activate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
Activate throttling, which switches the lock to be a real lock
- activatePrimaryMode(long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Initializes the global checkpoint tracker in primary mode (see
ReplicationTracker.primaryMode
. - activateThrottling() - Method in class org.elasticsearch.index.engine.Engine
-
Request that this engine throttle incoming indexing requests to one thread.
- activateThrottling() - Method in class org.elasticsearch.index.engine.InternalEngine
- activateThrottling() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- activateThrottling() - Method in class org.elasticsearch.index.shard.IndexShard
- activateThrottling(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
Asks this shard to throttle indexing to one thread
- activateWithPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Activates the global checkpoint tracker in primary mode (see
ReplicationTracker.primaryMode
. - activateWithPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.index.shard.IndexShard
-
Updates the known allocation IDs and the local checkpoints for the corresponding allocations from a primary relocation source.
- active() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- active() - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- 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
- AdapterActionFuture<T,L> - Class in org.elasticsearch.action.support
- AdapterActionFuture() - Constructor for class org.elasticsearch.action.support.AdapterActionFuture
- adaptiveSelection() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- adaptiveSelection(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should adaptiveSelection statistics be returned.
- AdaptiveSelectionStats - Class in org.elasticsearch.node
-
Class representing statistics about adaptive replica selection.
- AdaptiveSelectionStats(Map<String, Long>, Map<String, ResponseCollectorService.ComputedNodeStats>) - Constructor for class org.elasticsearch.node.AdaptiveSelectionStats
- AdaptiveSelectionStats(StreamInput) - Constructor for class org.elasticsearch.node.AdaptiveSelectionStats
- add() - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Build a new
AliasAction
to add aliases. - add(byte[]) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- add(byte[], int, int, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(byte[], int, int, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds a framed data in binary format
- add(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds a framed data in binary format
- add(int, GetResponse) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- add(int, MultiGetResponse.Failure) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- add(int, MultiTermVectorsResponse.Failure) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- add(int, TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- add(int, TermVectorsResponse) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- add(int, T) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- add(long) - Method in class org.elasticsearch.common.util.LongHash
-
Try to add
key
. - add(long, long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- add(long, long, long) - Method in class org.elasticsearch.index.flush.FlushStats
- add(long, long, long) - Method in class org.elasticsearch.index.warmer.WarmerStats
- add(long, long, long, long, long, long, long, long, long, double) - Method in class org.elasticsearch.index.merge.MergeStats
- add(Iterable<DocWriteRequest<?>>) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(String) - Method in class org.elasticsearch.common.blobstore.BlobPath
- add(String) - Method in class org.elasticsearch.index.mapper.ContentPath
- add(String) - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
- add(String, Object) - Method in class org.elasticsearch.common.inject.internal.ToStringBuilder
- add(String, String, 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
- 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, int) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Try to add
key
. - add(CharsRef, CharsRef, boolean) - Method in class org.elasticsearch.index.analysis.ESSolrSynonymParser
- add(CharsRef, CharsRef, boolean) - Method in class org.elasticsearch.index.analysis.ESWordnetSynonymParser
- 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(DeleteRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
- 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(DocWriteRequest<?>...) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(DocWriteRequest<?>, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Add a request to the current BulkRequest.
- add(DocWriteRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkProcessor
- 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(IndexRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
- 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(UpdateRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
- 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(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, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(BytesReference, String, String, String, Object, 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, String[], FetchSourceContext, String, Object, 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
-
Adds a framed data in binary format
- add(FieldMemoryStats) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Adds / merges the given field memory stats into this stats instance
- add(Module...) - Method in class org.elasticsearch.common.inject.ModulesBuilder
- add(QueryCacheStats) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- add(RequestCacheStats) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- add(SegmentsStats) - Method in class org.elasticsearch.index.engine.SegmentsStats
- add(FieldDataStats) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- add(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
- add(GetStats) - Method in class org.elasticsearch.index.get.GetStats
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- add(MergeStats) - Method in class org.elasticsearch.index.merge.MergeStats
- add(QueryBuilder) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
-
Add a sub-query to this disjunction.
- add(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- add(RefreshStats) - Method in class org.elasticsearch.index.refresh.RefreshStats
- add(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- add(SearchStats.Stats) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- add(DocsStats) - Method in class org.elasticsearch.index.shard.DocsStats
- add(IndexingStats) - Method in class org.elasticsearch.index.shard.IndexingStats
- add(IndexingStats.Stats) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- add(IndexingStats, boolean) - Method in class org.elasticsearch.index.shard.IndexingStats
- add(StoreStats) - Method in class org.elasticsearch.index.store.StoreStats
- add(Translog.Operation) - Method in class org.elasticsearch.index.translog.Translog
-
Adds an operation to the transaction log.
- add(TranslogStats) - Method in class org.elasticsearch.index.translog.TranslogStats
- add(WarmerStats) - Method in class org.elasticsearch.index.warmer.WarmerStats
- add(FsInfo.Path) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- add(ScriptFieldsContext.ScriptField) - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext
- add(CompletionStats) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- add(Transport.ResponseContext<? extends TransportResponse>) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Adds a new response context and associates it with a new request ID.
- add(T) - Method in class org.elasticsearch.common.collect.EvictingQueue
-
Add the given element to the queue, possibly forcing an eviction from the head if
EvictingQueue.remainingCapacity()
is zero. - add(W) - Method in class org.elasticsearch.watcher.ResourceWatcherService
-
Register new resource watcher that will be checked in default
MEDIUM
frequency - add(W, ResourceWatcherService.Frequency) - Method in class org.elasticsearch.watcher.ResourceWatcherService
-
Register new resource watcher that will be checked in the given frequency
- Add(String, String, String, String, String, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.Add
-
Build the operation.
- ADD - org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource
-
to be overridden by subclasses
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- addAffixGroupUpdateConsumer(List<Setting.AffixSetting<?>>, BiConsumer<String, Settings>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a affix settings consumer that accepts the settings for a group of settings.
- addAffixMapUpdateConsumer(Setting.AffixSetting<T>, Consumer<Map<String, T>>, BiConsumer<String, T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer for affix settings.
- addAffixUpdateConsumer(Setting.AffixSetting<A>, Setting.AffixSetting<B>, BiConsumer<String, Tuple<A, B>>, BiConsumer<String, Tuple<A, B>>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a affix settings consumer that accepts the values for two settings.
- addAffixUpdateConsumer(Setting.AffixSetting<T>, BiConsumer<String, T>, BiConsumer<String, T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer for affix settings.
- addAggregation(AggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an aggregation to the search operation.
- addAggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an aggregation to the search operation.
- addAggregator(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- addAlias(String[], String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, boolean) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(Alias) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds an alias that will be associated with the index when it gets created
- addAlias(Alias) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds an alias that will be added when the index template gets created.
- addAliasAction(IndicesAliasesRequest.AliasActions) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
Add the action to this request and validate it.
- addAliasAction(IndicesAliasesRequest.AliasActions) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias action to the request.
- addAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- addAll(Collection<? extends T>) - Method in class org.elasticsearch.common.collect.EvictingQueue
-
Add the given elements to the queue, possibly forcing evictions from the head if
EvictingQueue.remainingCapacity()
is zero or becomes zero during the execution of this method. - addAppender(Logger, Appender) - Static method in class org.elasticsearch.common.logging.Loggers
- addAsFromCloseToOpen(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsFromDangling(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsNew(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsNewRestore(IndexMetaData, RecoverySource.SnapshotRecoverySource, IntSet) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsRecovery(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsRestore(IndexMetaData, RecoverySource.SnapshotRecoverySource) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addBinding() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a binding builder used to add a new element in the set.
- addBinding() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- addBinding(K) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a binding builder used to add a new entry in the map.
- addBinding(K) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder
-
This creates two bindings.
- addBitsetMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addBlocks(IndexMetaData) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- addBootstrapSeed(KeyStoreWrapper) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Add the bootstrap seed setting, which may be used as a unique, secure, random value by the node
- 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.AnalyzeRequest
- 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.AnalyzeRequest
- 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.create.CreateIndexResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
Override in subclass to add custom fields following the common `_shards` field
- addDirectoryPath(Permissions, String, Path, String) - Static method in class org.elasticsearch.bootstrap.FilePermissionUtils
-
Add access to path (and all files underneath it); this also creates the directory if it does not exist.
- addDoc(int) - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Associates the given document id with the current ordinal.
- addDoc(ParseContext.Document) - Method in class org.elasticsearch.index.mapper.ParseContext
- addDoc(ParseContext.Document) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addDocValueField(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a docvalue based field to load and return.
- addDocValueField(String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load from doc values and return.
- addDocValueField(String, String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a docvalue based field to load and return.
- addDocValueField(String, String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load from the docvalue and return.
- addDocValuesMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addDynamicMapper(Mapper) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Add a new mapper dynamically created while parsing.
- addDynamicMapper(Mapper) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addDynamicMappingsUpdate(Mapping) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- added() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(String, Object...) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message which will be presented to the user at a later time.
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(String, Object...) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an error message for type
I
which will be presented to the user at a later time. - addError(Throwable) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(Throwable) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an exception, the full details of which will be logged, and the message of which will be presented to the user at a later time.
- addError(Throwable) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(Throwable) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an exception for type
I
, the full details of which will be logged, and the message of which will be presented to the user at a later time. - addError(Message) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(Message) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message to be presented to the user at a later time.
- addError(Message) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(Message) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an error message to be presented to the user at a later time.
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
-
Add a number of bytes, tripping the circuit breaker if the aggregated estimates are above the limit.
- addEstimateBytesAndMaybeBreak(long, String) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
-
add bytes to the breaker and maybe trip
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- addExposureBuilder(ExposureBuilder<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- addFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- addFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
- addField(ParseContext.Document, String, String, int, Map<String, Set<String>>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Adds a context-enabled field for all the defined mappings to
document
seeContextMappings.TypedContextField
- addFieldName(String) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Adds a field name
field
to the list of fields to load. - addFieldNames(List<String>) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Adds the field names
fieldNames
to the list of fields to load. - addFieldStringsFromParameter(TermVectorsRequest, String) - Static method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- addFileDetail(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addFileSizes(ImmutableOpenMap<String, Long>) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addFilterSettingParams(RestRequest) - Method in class org.elasticsearch.common.settings.SettingsFilter
- 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.rest.RestResponse
-
Add a custom header.
- addHeader(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new header with the given key.
- addHeader(String, List<String>) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new header with the given key.
- addHighPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds a high priority applier of updated cluster states.
- addHighPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Adds a high priority applier of updated cluster states.
- addHumanReadableSettings(Settings) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Adds human readable version and creation date settings.
- addIds(String...) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Adds ids to the query.
- addIgnoredField(String) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Add the given
field
to the set of ignored fields. - addIgnoredField(String) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addIgnoreShardForNode(ShardId, String) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- addIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- addIndexBoost(String, float) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the boost a specific index will receive when the query is executed against it.
- addIndexEventListener(IndexEventListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
IndexEventListener
for this index. - addIndexOperationListener(IndexingOperationListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
IndexingOperationListener
for this index. - addIndexShard(IndexShardRoutingTable) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- addIndexShardCount(ClusterStatsIndices.ShardStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- addIndexWriterMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addIndices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- addIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- addIndices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
- addIndices(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- 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.movavg.models.HoltWintersModel.SeasonalityType
- 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(Listener) - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Registers new listener
- addListener(ActionListener<T>) - Method in interface org.elasticsearch.action.ListenableActionFuture
-
Add an action listener to be invoked when a response has received.
- addListener(ActionListener<T>) - Method in class org.elasticsearch.action.support.PlainListenableActionFuture
- addListener(ActionListener<V>, ExecutorService, ThreadContext) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
-
Adds a listener to this future.
- addListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Add a listener for updated cluster states
- addListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Add a listener for updated cluster states
- addListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- addListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- addListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.ConnectionManager
- addLocalNodeMasterListener(LocalNodeMasterListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Add a listener for on/off local node master events
- addLocalNodeMasterListener(LocalNodeMasterListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Add a listener for on/off local node master events
- addLowPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds an applier which will be called after all high priority and normal appliers have been called.
- addLowPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Adds an applier which will be called after all high priority and normal appliers have been called.
- addMapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- addMapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- addMapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index template gets created.
- addMapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index template gets created.
- addMaskRange(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addMaskRange(String, String)
but uses the mask itself as a key. - addMaskRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new range to this aggregation using the CIDR notation.
- addMaxIndexAgeCondition(TimeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds condition to check if the index is at least
age
old - addMaxIndexAgeCondition(TimeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMaxIndexDocsCondition(long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds condition to check if the index has at least
numDocs
- addMaxIndexDocsCondition(long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMaxIndexSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds a size-based condition to check if the index size is at least
size
. - addMaxIndexSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMessage(String, Object...) - Method in class org.elasticsearch.common.inject.internal.Errors
- addMessage(Message) - Method in class org.elasticsearch.common.inject.internal.Errors
- addMessageListener(TransportMessageListener) - Method in class org.elasticsearch.transport.TcpTransport
- addMessageListener(TransportMessageListener) - Method in interface org.elasticsearch.transport.Transport
- addMetadata(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new piece of metadata with the given key.
- addMetadata(String, List<String>) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new piece of metadata with the given key.
- addModule(PluginInfo) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- addMultiField(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- addNamedQuery(String, Query) - Method in class org.elasticsearch.index.query.QueryShardContext
- addNeighbors(String, int, E) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Add all geohashes of the cells next to a given geohash to a list.
- addNeighbors(String, E) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Add all geohashes of the cells next to a given geohash to a list.
- 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(Suggest.Suggestion.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.
- addPending(ClusterState) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
Add an incoming, not yet committed cluster state
- addPendingDelete(Index, IndexSettings) - Method in class org.elasticsearch.indices.IndicesService
-
Adds a pending delete for the given index.
- addPendingDelete(ShardId, IndexSettings) - Method in interface org.elasticsearch.index.IndexService.ShardStoreDeleter
- addPendingDelete(ShardId, IndexSettings) - Method in class org.elasticsearch.indices.IndicesService
-
Adds a pending delete for the given index shard.
- addPing(ZenPing.PingResponse) - Method in class org.elasticsearch.discovery.zen.ZenPing.PingCollection
-
adds a ping if newer than previous pings from the same node
- addPingResponseToCollection(ZenPing.PingResponse) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- addPipelineAggregator(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- addPlugin(PluginInfo) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- addPlugins(Collection<Class<? extends Plugin>>, Class<? extends Plugin>...) - Static method in class org.elasticsearch.client.transport.TransportClient
- addPlugins(Collection<Class<? extends Plugin>>, Collection<Class<? extends Plugin>>) - Static method in class org.elasticsearch.client.transport.TransportClient
- addPointsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addProcessedFile(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Increments number of processed files
- addQueryProfiler() - Method in class org.elasticsearch.search.profile.Profilers
-
Switch to a new profile.
- addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, String, String)
but the key will be automatically generated based onfrom
andto
. - addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but the key will be automatically generated. - addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, DateTime, DateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- 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(DateTime, DateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, DateTime, DateTime)
but the key will be automatically generated based onfrom
andto
. - addRange(R) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- addReaderCloseListener(DirectoryReader, IndexReader.ClosedListener) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Adds the given listener to the provided directory reader.
- addRecoveredBytesToFile(String, long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addRefreshListener(Translog.Location, Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Add a listener for refreshes.
- addReleasable(Releasable, SearchContext.Lifetime) - Method in class org.elasticsearch.search.internal.SearchContext
-
Schedule the release of a resource.
- addReplica() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- addRepositories(String...) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Adds repositories to the list of repositories to get
- AddRequest() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.AddRequest
- 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, int) - Method in class org.elasticsearch.transport.TcpTransport
- addressesFromString(String, int) - Method in interface org.elasticsearch.transport.Transport
-
Returns an address from its string representation.
- addressesFromString(String, int) - Method in class org.elasticsearch.transport.TransportService
- addRestHandler(BaseRestHandler) - Method in class org.elasticsearch.usage.UsageService
-
Add a REST handler to this service.
- addResultReader(String, Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Add a reader for the shard level results of the aggregation.
- addResultReader(String, Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Add a reader for the shard level results of the aggregation.
- addResultReader(Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Add a reader for the shard level results of the aggregation with SearchPlugin.SearchExtensionSpec.getName()'s
ParseField.getPreferredName()
as theNamedWriteable.getWriteableName()
. - addResultReader(Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Add a reader for the shard level results of the aggregation with SearchPlugin.SearchExtensionSpec.getName()'s
ParseField.getPreferredName()
as theNamedWriteable.getWriteableName()
. - addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Adds a new retention lease.
- addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Adds a new retention lease.
- addScriptField(String, Script) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a script based field to load and return.
- addScriptField(String, Script) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- addScriptParam(String, Object) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.search.internal.SearchContext
- addSearchOperationListener(SearchOperationListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
SearchOperationListener
for this index. - addSettingsUpdateConsumer(Consumer<Settings>, List<? extends Setting<?>>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer that is only executed if any setting in the supplied list of settings is changed.
- addSettingsUpdateConsumer(Setting<A>, Setting<B>, BiConsumer<A, B>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer that accepts the values for two settings.
- addSettingsUpdateConsumer(Setting<A>, Setting<B>, BiConsumer<A, B>, BiConsumer<A, B>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer that accepts the values for two settings.
- addSettingsUpdateConsumer(Setting<T>, Consumer<T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer.
- addSettingsUpdateConsumer(Setting<T>, Consumer<T>) - Method in class org.elasticsearch.index.IndexModule
-
Adds a Setting and it's consumer for this index.
- addSettingsUpdateConsumer(Setting<T>, Consumer<T>, Consumer<T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer with a predicate that is only evaluated at update time.
- addSettingsUpdateConsumer(Setting<T>, Consumer<T>, Consumer<T>) - Method in class org.elasticsearch.index.IndexModule
-
Adds a Setting, it's consumer and validator for this index.
- addShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Adds a new shard routing (makes a copy of it), with reference data used from the index shard routing table if it needs to be created.
- addShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- addShardFailureCallback(Consumer<IndexShard.ShardFailure>) - Method in class org.elasticsearch.index.shard.IndexShard
- addSimilarity(String, TriFunction<Settings, Version, ScriptService, Similarity>) - Method in class org.elasticsearch.index.IndexModule
-
Registers the given
Similarity
with the given name. - addSingleFilePath(Permissions, Path, String) - Static method in class org.elasticsearch.bootstrap.FilePermissionUtils
-
Add access to single file path
- addSnapshot(SnapshotId, SnapshotState, List<IndexId>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Add a snapshot and its indices to the repository; returns a new instance.
- addSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Adds additional snapshots to the list of snapshots to return
- addSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Adds additional snapshots to the list of snapshots to return
- addSort(String, SortOrder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a sort against the given field name and the sort ordering.
- addSort(SortBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a generic sort builder.
- addSort(SortBuilder<?>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- addSortField(String, SortOrder) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Add a sort against the given field name.
- addSourceThrottling(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addStateApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds a applier of updated cluster states.
- addStateApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Adds a applier of updated cluster states.
- addStoredField(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a stored field to load and return (note, it must be stored) as part of the search request.
- addStoredFieldsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addSuggestion(String, SuggestionBuilder<?>) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Adds an
SuggestionBuilder
instance under a user defined name. - addSuggestion(String, SuggestionSearchContext.SuggestionContext) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext
- addSurface(BytesRef, BytesRef, long) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
- 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
- addText(String, String, float) - Method in class org.elasticsearch.common.lucene.all.AllEntries
- 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.
- addTokenFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- 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.AnalyzeRequest
- 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
- addTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClient
-
Adds a transport address that will be used to connect to.
- addTransportAddresses(TransportAddress...) - Method in class org.elasticsearch.client.transport.TransportClient
-
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, DateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(DateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, DateTime)
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, DateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(DateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, DateTime)
but the key will be computed automatically. - addValidationError(String) - Method in exception org.elasticsearch.common.ValidationException
-
Add a new validation error to the accumulating validation errors
- addValidationError(String, String, QueryValidationException) - Static method in exception org.elasticsearch.index.query.QueryValidationException
-
Helper method than can be used to add error messages to an existing
QueryValidationException
. - addValidationError(String, ActionRequestValidationException) - Static method in class org.elasticsearch.action.ValidateActions
- addValidationError(String, QueryValidationException) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- addValidationErrors(Iterable<String>) - Method in exception org.elasticsearch.common.ValidationException
-
Add a sequence of validation errors to the accumulating validation errors
- addValidationErrors(List<String>, QueryValidationException) - Static method in exception org.elasticsearch.index.query.QueryValidationException
-
Helper method than can be used to add error messages to an existing
QueryValidationException
. - addValue(double) - Method in class org.elasticsearch.common.ExponentiallyWeightedMovingAverage
- addVersionMapMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- 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
- adjacencyMatrix(String, String, Map<String, QueryBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
AdjacencyMatrix
aggregation with the given name and separator - adjacencyMatrix(String, Map<String, QueryBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
AdjacencyMatrix
aggregation with the given name. - AdjacencyMatrix - Interface in org.elasticsearch.search.aggregations.bucket.adjacency
-
A multi bucket aggregation where the buckets are defined by a set of filters (a bucket is produced per filter plus a bucket for each non-empty filter intersection so A, B and A&B).
- AdjacencyMatrix.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.adjacency
-
A bucket associated with a specific filter or pair (identified by its key)
- AdjacencyMatrixAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(String, String, Map<String, QueryBuilder>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(String, Map<String, QueryBuilder>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Read from a stream.
- AdjacencyMatrixAggregationBuilder(AdjacencyMatrixAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregator - Class in org.elasticsearch.search.aggregations.bucket.adjacency
-
Aggregation for adjacency matrices.
- AdjacencyMatrixAggregator(String, AggregatorFactories, String, String[], Weight[], SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- AdjacencyMatrixAggregator.KeyedFilter - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregatorFactory(String, List<AdjacencyMatrixAggregator.KeyedFilter>, String, SearchContext, 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.apache.lucene.search.XFilteredDocIdSetIterator
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- ADVANCE - org.elasticsearch.search.profile.query.QueryTimingType
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.DocValueBits
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.GeoPointValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Advance the iterator to exactly
target
and return whethertarget
has a value. - advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
- advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
- advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
- advanceMaxSeqNo(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Marks the provided sequence number as seen and updates the max_seq_no if needed.
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.engine.Engine
-
A replica shard receives a new max_seq_no_of_updates from its primary shard, then calls this method to advance this marker to at least the given sequence number.
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.shard.IndexShard
-
A replica calls this method to advance the max_seq_no_of_updates marker of its engine to at least the max_seq_no_of_updates value (piggybacked in a replication request) that it receives from its primary before executing that replication request.
- affixKeySetting(String, String, Function<String, Setting<T>>, Setting.AffixSetting...) - Static method in class org.elasticsearch.common.settings.Setting
-
This setting type allows to validate settings that have the same type and a common prefix and suffix.
- AffixSetting(Setting.AffixKey, Setting<T>, Function<String, Setting<T>>, Setting.AffixSetting...) - Constructor for class org.elasticsearch.common.settings.Setting.AffixSetting
- after(Priority) - Method in enum org.elasticsearch.common.Priority
- after(Version) - Method in class org.elasticsearch.Version
- AFTER_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- afterBulk(long, BulkRequest, Throwable) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback after a failed execution of bulk request.
- afterBulk(long, BulkRequest, BulkResponse) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback after a successful execution of bulk request.
- afterClose() - Method in class org.elasticsearch.common.component.LifecycleListener
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- afterIndexCreated(IndexService) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index has been created.
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index has been removed.
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in class org.elasticsearch.search.SearchService
- afterIndexShardClosed(ShardId, IndexShard, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been closed.
- afterIndexShardCreated(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been created.
- afterIndexShardDeleted(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been deleted from disk.
- afterIndexShardStarted(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been started.
- afterInjection(I) - Method in interface org.elasticsearch.common.inject.spi.InjectionListener
-
Invoked by Guice after it injects the fields and methods of instance.
- afterKey() - Method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
-
Returns the last key in this aggregation.
- afterKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- afterKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- afterLoad(TermsEnum, long) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData.PerValueEstimator
-
Possibly adjust a circuit breaker after field data has been loaded, now that the actual amount of memory used by the field data is known
- afterLoad(TermsEnum, long) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
-
Adjust the circuit breaker now that terms have been loaded, getting the actual used either from the parameter (if estimation worked for the entire set), or from the TermsEnum if it has been wrapped in a RamAccountingTermsEnum.
- afterRefresh(boolean) - Method in class org.elasticsearch.index.shard.RefreshListeners
- afterRelease(boolean) - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- afterRelease(boolean) - Method in class org.elasticsearch.common.recycler.DequeRecycler
-
Called after a release.
- afterStart() - Method in class org.elasticsearch.common.component.LifecycleListener
- afterStop() - Method in class org.elasticsearch.common.component.LifecycleListener
- afterWriteOperation() - Method in class org.elasticsearch.index.shard.IndexShard
-
Schedules a flush or translog generation roll if needed but will not schedule more than one concurrently.
- AggParseContext(String) - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactories.AggParseContext
- aggregateAfter(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
-
Sets the values that indicates which composite bucket this request should "aggregate after".
- AggregatedDfs - Class in org.elasticsearch.search.dfs
- AggregatedDfs(ObjectObjectHashMap<Term, TermStatistics>, ObjectObjectHashMap<String, CollectionStatistics>, long) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
- aggregateDfs(Collection<DfsSearchResult>) - Method in class org.elasticsearch.action.search.SearchPhaseController
- aggregation() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- aggregation() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ParsedScriptedMetric
- aggregation() - Method in interface org.elasticsearch.search.aggregations.metrics.scripted.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_NAME_FIELD - Static variable in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- Aggregation.CommonFields - Class in org.elasticsearch.search.aggregations
-
Common xcontent fields that are shared among addAggregation
- AggregationBuilder - Class in org.elasticsearch.search.aggregations
-
A factory that knows how to create an
Aggregator
of a specific type. - AggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.AggregationBuilder
-
Constructs a new aggregation builder.
- AggregationBuilder(AggregationBuilder, AggregatorFactories.Builder) - Constructor for class org.elasticsearch.search.aggregations.AggregationBuilder
- AggregationBuilder.CommonFields - Class in org.elasticsearch.search.aggregations
-
Common xcontent fields shared among aggregator builders
- AggregationBuilders - Class in org.elasticsearch.search.aggregations
-
Utility class to create aggregations.
- AggregationExecutionException - Exception in org.elasticsearch.search.aggregations
-
Thrown when failing to execute an aggregation
- AggregationExecutionException(String) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationInitializationException - Exception in org.elasticsearch.search.aggregations
-
Thrown when failing to execute an aggregation
- AggregationInitializationException(String) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInitializationException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInitializationException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationPath - Class in org.elasticsearch.search.aggregations.support
-
A path that can be used to sort/order buckets (in some multi-bucket aggregations, e.g.
- AggregationPath(List<AggregationPath.PathElement>) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationPath
- AggregationPath.PathElement - Class in org.elasticsearch.search.aggregations.support
- AggregationPhase - Class in org.elasticsearch.search.aggregations
-
Aggregation phase of a search request, used to collect aggregations
- AggregationPhase() - Constructor for class org.elasticsearch.search.aggregations.AggregationPhase
- AggregationProfileBreakdown - Class in org.elasticsearch.search.profile.aggregation
- AggregationProfileBreakdown() - Constructor for class org.elasticsearch.search.profile.aggregation.AggregationProfileBreakdown
- AggregationProfiler - Class in org.elasticsearch.search.profile.aggregation
- AggregationProfiler() - Constructor for class org.elasticsearch.search.profile.aggregation.AggregationProfiler
- AggregationProfileShardResult - Class in org.elasticsearch.search.profile.aggregation
-
A container class to hold the profile results for a single shard in the request.
- AggregationProfileShardResult(List<ProfileResult>) - Constructor for class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- AggregationProfileShardResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
-
Read from a stream.
- aggregations - Variable in class org.elasticsearch.action.search.SearchResponseSections
- aggregations - Variable in class org.elasticsearch.search.aggregations.Aggregations
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- aggregations() - Method in class org.elasticsearch.action.search.SearchResponseSections
- aggregations() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the bytes representing the aggregation builders for this request.
- aggregations() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- aggregations() - Method in class org.elasticsearch.search.internal.SearchContext
- aggregations(InternalAggregations) - Method in class org.elasticsearch.search.query.QuerySearchResult
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.SearchContext
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.SubSearchContext
- Aggregations - Class in org.elasticsearch.search.aggregations
-
Represents a set of
Aggregation
s - Aggregations() - Constructor for class org.elasticsearch.search.aggregations.Aggregations
- 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
- aggregationsAsMap - Variable in class org.elasticsearch.search.aggregations.Aggregations
- AggregationSpec(String, Writeable.Reader<? extends AggregationBuilder>, Aggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Specification for an
Aggregation
. - AggregationSpec(ParseField, Writeable.Reader<? extends AggregationBuilder>, Aggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Specification for an
Aggregation
. - AggregationTimingType - Enum in org.elasticsearch.search.profile.aggregation
- Aggregator - Class in org.elasticsearch.search.aggregations
-
An Aggregator.
- Aggregator() - Constructor for class org.elasticsearch.search.aggregations.Aggregator
- Aggregator.Parser - Interface in org.elasticsearch.search.aggregations
-
Parses the aggregation request and creates the appropriate aggregator factory for it.
- Aggregator.SubAggCollectionMode - Enum in org.elasticsearch.search.aggregations
-
Aggregation mode for sub aggregations.
- AggregatorBase - Class in org.elasticsearch.search.aggregations
-
Base implementation for concrete aggregators.
- AggregatorBase(String, AggregatorFactories, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorBase
-
Constructs a new Aggregator.
- AggregatorFactories - Class in org.elasticsearch.search.aggregations
- AggregatorFactories.AggParseContext - Class in org.elasticsearch.search.aggregations
-
Context to parse and aggregation.
- AggregatorFactories.Builder - Class in org.elasticsearch.search.aggregations
- AggregatorFactory<AF extends AggregatorFactory<AF>> - Class in org.elasticsearch.search.aggregations
- AggregatorFactory(String, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactory
-
Constructs a new aggregator factory.
- AggregatorFactory.MultiBucketAggregatorWrapper - Class in org.elasticsearch.search.aggregations
- aggregators() - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
- aggregators(Aggregator[]) - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
-
Registers all the created aggregators (top level aggregators) for the search execution context.
- AGGS_CONTEXT - Static variable in class org.elasticsearch.script.SearchScript
- AGGS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- aggsUsedForSorting - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- alias(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Set the alias this action is operating on.
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds an alias that will be associated with the index when it gets created
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds an alias that will be added when the index gets created.
- Alias - Class in org.elasticsearch.action.admin.indices.alias
-
Represents an alias, to be associated with an index
- Alias(String) - Constructor for class org.elasticsearch.action.admin.indices.alias.Alias
- Alias(AliasMetaData, IndexMetaData) - Constructor for class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
- AliasAction - Class in org.elasticsearch.cluster.metadata
-
Individual operation to perform on the cluster state as part of an
IndicesAliasesRequest
. - AliasAction.Add - Class in org.elasticsearch.cluster.metadata
-
Operation to add an alias to an index.
- AliasAction.NewAliasValidator - Interface in org.elasticsearch.cluster.metadata
-
Validate a new alias.
- AliasAction.Remove - Class in org.elasticsearch.cluster.metadata
-
Operation to remove an alias from an index.
- AliasAction.RemoveIndex - Class in org.elasticsearch.cluster.metadata
-
Operation to remove an index.
- AliasActions(IndicesAliasesRequest.AliasActions.Type) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- AliasActions(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Read from a stream.
- aliases() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- aliases() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- aliases() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- aliases() - Method in interface org.elasticsearch.action.AliasesRequest
-
Returns the array of aliases that the action relates to
- aliases() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- aliases(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- aliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Aliases to use with this action.
- aliases(Map) - 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) - 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. - aliasFilter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- aliasFilter() - Method in class org.elasticsearch.search.internal.SearchContext
- AliasFilter - Class in org.elasticsearch.search.internal
-
Represents a
QueryBuilder
and a list of alias names that filters the builder is composed of. - AliasFilter(StreamInput) - Constructor for class org.elasticsearch.search.internal.AliasFilter
- AliasFilter(QueryBuilder, String...) - Constructor for class org.elasticsearch.search.internal.AliasFilter
- AliasFilterParsingException - Exception in org.elasticsearch.indices
- AliasFilterParsingException(StreamInput) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
- AliasFilterParsingException(Index, String, String, Throwable) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
- AliasMetaData - Class in org.elasticsearch.cluster.metadata
- AliasMetaData(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetaData
- AliasMetaData.Builder - Class in org.elasticsearch.cluster.metadata
- AliasOrIndex - Interface in org.elasticsearch.cluster.metadata
-
Encapsulates the
IndexMetaData
instances of a concrete index or indices an alias is pointing to. - AliasOrIndex.Alias - Class in org.elasticsearch.cluster.metadata
-
Represents an alias and groups all
IndexMetaData
instances sharing the same alias name together. - AliasOrIndex.Index - Class in org.elasticsearch.cluster.metadata
-
Represents an concrete index and encapsulates its
IndexMetaData
- AliasValidator - Class in org.elasticsearch.cluster.metadata
-
Validator for an alias, to be used before adding an alias to the index metadata and make sure the alias is valid
- AliasValidator() - Constructor for class org.elasticsearch.cluster.metadata.AliasValidator
- all() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Sets to return all the data.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Sets to return all the data.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- all() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Include all data
- all() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Sets all flags to return all stats.
- all() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Sets all flags to return all stats.
- all() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
Sets all flags to return all stats.
- ALL - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- ALL - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- ALL - org.elasticsearch.index.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_FIELDS_FIELDS - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- 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
- allActiveShardsGrouped(String[], boolean, 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
- allAssignedShardsGrouped(String[], boolean, 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
- allElementsAreEqual(Iterable<?>, Iterable<?>) - Static method in class org.elasticsearch.common.util.iterable.Iterables
- allEnabled() - Method in class org.elasticsearch.index.mapper.MapperService
-
Returns true if the "_all" field is enabled on any type.
- allEntries() - Method in class org.elasticsearch.index.mapper.ParseContext
- allEntries() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- AllEntries - Class in org.elasticsearch.common.lucene.all
- AllEntries() - Constructor for class org.elasticsearch.common.lucene.all.AllEntries
- AllEntries.Entry - Class in org.elasticsearch.common.lucene.all
- AllField - Class in org.elasticsearch.common.lucene.all
- AllField(String, String, float, FieldType) - Constructor for class org.elasticsearch.common.lucene.all.AllField
- allFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- AllFieldMapper - Class in org.elasticsearch.index.mapper
- AllFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- AllFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- AllFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- allocate(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- allocate(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Allocates shards to nodes in the cluster.
- allocateDangled(Collection<IndexMetaData>, LocalAllocateDangledIndices.Listener) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices
- AllocateDangledRequest() - Constructor for class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledRequest
- AllocatedPersistentTask - Class in org.elasticsearch.persistent
-
Represents a executor node operation that corresponds to a persistent task
- AllocatedPersistentTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.persistent.AllocatedPersistentTask
- AllocatedPersistentTask.State - Enum in org.elasticsearch.persistent
- AllocateEmptyPrimaryAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned empty primary shard to a specific node.
- AllocateEmptyPrimaryAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
-
Creates a new
AllocateEmptyPrimaryAllocationCommand
- AllocateEmptyPrimaryAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
-
Read from a stream.
- AllocateEmptyPrimaryAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- AllocateReplicaAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned replica shard to a specific node.
- AllocateReplicaAllocationCommand(String, int, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
-
Creates a new
AllocateReplicaAllocationCommand
- AllocateReplicaAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
-
Read from a stream.
- AllocateReplicaAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- AllocateStalePrimaryAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned stale primary shard to a specific node.
- AllocateStalePrimaryAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
-
Creates a new
AllocateStalePrimaryAllocationCommand
- AllocateStalePrimaryAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
-
Read from a stream.
- AllocateStalePrimaryAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.BaseGatewayShardAllocator
-
Allocate unassigned shards to nodes (if any) where valid copies of the shard already exist.
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
- AllocateUnassignedDecision - Class in org.elasticsearch.cluster.routing.allocation
-
Represents the allocation decision by an allocator for an unassigned shard.
- AllocateUnassignedDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- ALLOCATION_DELAYED - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The allocation decision has been delayed waiting for a replica with a shard copy that left the cluster to rejoin.
- ALLOCATION_FAILED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of a failed allocation of the shard.
- AllocationCommand - Interface in org.elasticsearch.cluster.routing.allocation.command
-
A command to move shards in some way.
- AllocationCommand.Parser<T extends AllocationCommand> - Interface in org.elasticsearch.cluster.routing.allocation.command
- AllocationCommands - Class in org.elasticsearch.cluster.routing.allocation.command
-
A simple
AllocationCommand
composite managing severalAllocationCommand
implementations - AllocationCommands(AllocationCommand...) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Creates a new set of
AllocationCommands
- AllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
AllocationDecider
is an abstract base class that allows to make dynamic cluster- or index-wide shard allocation decisions on a per-node basis. - AllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
- AllocationDeciders - Class in org.elasticsearch.cluster.routing.allocation.decider
-
A composite
AllocationDecider
combining the "decision" of multipleAllocationDecider
implementations into a single allocation decision. - AllocationDeciders(Collection<AllocationDecider>) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- AllocationDecision - Enum in org.elasticsearch.cluster.routing.allocation
-
An enum which represents the various decision types that can be taken by the allocators and deciders for allocating a shard to a node.
- allocationExplain(ClusterAllocationExplainRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- allocationExplain(ClusterAllocationExplainRequest, ActionListener<ClusterAllocationExplainResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- allocationId - Variable in class org.elasticsearch.index.engine.Engine
- allocationId - Variable in class org.elasticsearch.index.shard.ShardStateMetaData
- allocationId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
An id that uniquely identifies an allocation.
- allocationId() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- AllocationId - Class in org.elasticsearch.cluster.routing
-
Uniquely identifies an allocation.
- AllocationService - Class in org.elasticsearch.cluster.routing.allocation
-
This service manages the node allocation of a cluster.
- AllocationService(AllocationDeciders, ShardsAllocator, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService(AllocationDeciders, GatewayAllocator, ShardsAllocator, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService.CommandsResult - Class in org.elasticsearch.cluster.routing.allocation
-
this class is used to describe results of applying a set of
AllocationCommand
- ALLOW_NO_INDICES - org.elasticsearch.action.support.IndicesOptions.Option
- ALLOW_NONE - Static variable in class org.elasticsearch.script.ScriptService
- ALLOW_UNMAPPED - Static variable in class org.elasticsearch.index.IndexSettings
- allowAliasesToMultipleIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
- ALLOWED_CONTENT_FIELD_NAMES - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper
- 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.ShardSearchLocalRequest
- allowPartialSearchResults() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- allowPartialSearchResults() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- 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
- allowsIndexOptions() - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- allowsIndexOptions() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
-
Numeric field types no longer support `index_options`
- allowsNull(Annotation[]) - Static method in class org.elasticsearch.common.inject.internal.Nullability
- allPrimaryShardsActive() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Returns
true
if all shards are primary and active. - allPrimaryShardsUnassigned() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Returns
true
if all primary shards are inShardRoutingState.UNASSIGNED
state. - allReplicasActive(ShardId, MetaData) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns
true
iff all replicas are active for the given shard routing. - allShards() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be validated on all shards instead of one random shard
- allShards() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the shards (replicas) for all indices in this routing table.
- allShards(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be validated on all shards instead of one random shard
- allShards(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the shards (replicas) for the provided index.
- allShards(String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- allShardsIncludingRelocationTargets(String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- allShardsStarted() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns
true
iff all shards in the routing table are started otherwisefalse
- AllTermQuery - Class in org.elasticsearch.common.lucene.all
-
A term query that takes all payload boost values into account.
- AllTermQuery(Term) - Constructor for class org.elasticsearch.common.lucene.all.AllTermQuery
- allTokenStream(String, String, float, Analyzer) - Static method in class org.elasticsearch.common.lucene.all.AllTokenStream
- AllTokenStream - Class in org.elasticsearch.common.lucene.all
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel.EWMAModelBuilder
-
Alpha controls the smoothing of the data.
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel.HoltLinearModelBuilder
-
Alpha controls the smoothing of the data.
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
-
Alpha controls the smoothing of the data.
- alreadyClosed() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
- 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
- AnalysisModule - Class in org.elasticsearch.indices.analysis
-
Sets up
AnalysisRegistry
. - AnalysisModule(Environment, List<AnalysisPlugin>) - Constructor for class org.elasticsearch.indices.analysis.AnalysisModule
- AnalysisModule.AnalysisProvider<T> - Interface in org.elasticsearch.indices.analysis
-
The basic factory interface for analysis components.
- AnalysisPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's analysis functionality. - analysisRegistry - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provide analyzer support
- AnalysisRegistry - Class in org.elasticsearch.index.analysis
-
An internal registry for tokenizer, token filter, char filter and analyzer.
- AnalysisRegistry(Environment, Map<String, AnalysisModule.AnalysisProvider<CharFilterFactory>>, Map<String, AnalysisModule.AnalysisProvider<TokenFilterFactory>>, Map<String, AnalysisModule.AnalysisProvider<TokenizerFactory>>, Map<String, AnalysisModule.AnalysisProvider<AnalyzerProvider<?>>>, Map<String, AnalysisModule.AnalysisProvider<AnalyzerProvider<?>>>, Map<String, PreConfiguredCharFilter>, Map<String, PreConfiguredTokenFilter>, Map<String, PreConfiguredTokenizer>, Map<String, PreBuiltAnalyzerProviderFactory>) - Constructor for class org.elasticsearch.index.analysis.AnalysisRegistry
- analyze(String, CharsRefBuilder) - Method in class org.elasticsearch.index.analysis.ESSolrSynonymParser
- analyze(String, CharsRefBuilder) - Method in class org.elasticsearch.index.analysis.ESWordnetSynonymParser
- 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(AnalyzeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- analyze(AnalyzeRequest, String, Analyzer, IndexAnalyzers, AnalysisRegistry, Environment) - Static method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- analyze(AnalyzeRequest, ActionListener<AnalyzeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- ANALYZE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- AnalyzeAction - Class in org.elasticsearch.action.admin.indices.analyze
- 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.AnalyzeRequest
- analyzer() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- analyzer() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
The actual analyzer.
- analyzer() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- 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.AnalyzeRequest
- analyzer(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
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(DetailAnalyzeResponse.AnalyzeTokenList) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- 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
- AnalyzeRequest - Class in org.elasticsearch.action.admin.indices.analyze
-
A request to analyze a text associated with a specific index.
- AnalyzeRequest() - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- AnalyzeRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
Constructs a new analyzer request for the provided index.
- AnalyzeRequest.NameOrDefinition - Class in org.elasticsearch.action.admin.indices.analyze
- 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
- AnalyzeResponse - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeResponse(List<AnalyzeResponse.AnalyzeToken>, DetailAnalyzeResponse) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- AnalyzeResponse.AnalyzeToken - Class in org.elasticsearch.action.admin.indices.analyze
- 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
- AnalyzeToken(String, int, int, int, int, String, Map<String, Object>) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- AnalyzeTokenList(String, AnalyzeResponse.AnalyzeToken[]) - Constructor for class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- analyzeWildcard() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- analyzeWildcard() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns whether wildcards should by analyzed.
- analyzeWildcard() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Returns whether to analyze wildcards.
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specifies whether wildcards should be analyzed.
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Specifies whether to analyze wildcards.
- analyzeWildcard(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set to
true
to enable analysis on wildcard and prefix queries. - and(Matcher<? super T>) - Method in class org.elasticsearch.common.inject.matcher.AbstractMatcher
- and(Matcher<? super T>) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
-
Returns a new matcher which returns
true
if both this and the given matcher returntrue
. - AND - org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
- AND - org.elasticsearch.index.query.Operator
- AND - org.elasticsearch.index.query.SimpleQueryStringFlag
- AnnotatedBindingBuilder<T> - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - AnnotatedConstantBindingBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - AnnotatedElementBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedConstantBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedElementBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- annotatedWith(Annotation) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
- annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedConstantBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedElementBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- annotatedWith(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
- annotatedWithInternal(Annotation) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
Sets the binding to a copy with the specified annotation on the bound key
- annotatedWithInternal(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
Sets the binding to a copy with the specified annotation on the bound key
- ANNOTATION_ALREADY_SPECIFIED - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- Annotations - Class in org.elasticsearch.common.inject.internal
-
Annotation utilities.
- Annotations() - Constructor for class org.elasticsearch.common.inject.internal.Annotations
- any() - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches any input.
- ANY - org.elasticsearch.search.aggregations.support.ValuesSourceType
- 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
- 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) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction.DeferredTokenFilterRegistry
- 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.TriFunction
-
Applies this function to the given arguments.
- apply(T) - Method in interface org.elasticsearch.cluster.Diff
-
Applies difference to the specified part and returns the resulted part
- apply(T, Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Applies the given value to the updater.
- apply(T, U) - Method in interface org.elasticsearch.common.CheckedBiFunction
- apply(T, U, ActionListener<C>) - Method in interface org.elasticsearch.common.AsyncBiFunction
- applyAsLong(IndicesFieldDataCache.Key, Accountable) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.FieldDataWeigher
- applyChanges(MetaData, RoutingTable) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetaDataUpdater
-
Updates the current
MetaData
based on the changes of this RoutingChangesObserver. - applyChanges(RestoreInProgress) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.action.ingest.IngestActionForwarder
- applyClusterState(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.ClusterStateApplier
-
Called when a new cluster state (
ClusterChangedEvent.state()
needs to be applied - applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.GatewayMetaState
- 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
- applyContentParser(CheckedConsumer<XContentParser, IOException>) - Method in class org.elasticsearch.rest.RestRequest
-
If there is any content then call
applyParser
with the parser, otherwise do nothing. - applyDeleteOperationOnPrimary(long, String, String, VersionType, long, long) - Method in class org.elasticsearch.index.shard.IndexShard
- applyDeleteOperationOnReplica(long, long, String, String, VersionType) - Method in class org.elasticsearch.index.shard.IndexShard
- applyFailedShard(ClusterState, ShardRouting, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- applyFailedShards(ClusterState, List<FailedShard>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- applyFailedShards(ClusterState, List<FailedShard>, List<StaleShard>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the failed shards.
- applyFailedShards(RoutingAllocation, List<FailedShard>) - Method in class org.elasticsearch.gateway.GatewayAllocator
- applyHardSizeLimit(Settings, String) - Method in class org.elasticsearch.threadpool.ExecutorBuilder
- applyIndexOperationOnPrimary(long, VersionType, SourceToParse, long, long, long, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- applyIndexOperationOnReplica(long, long, VersionType, long, boolean, SourceToParse) - Method in class org.elasticsearch.index.shard.IndexShard
- applyMinimumShouldMatch(BooleanQuery, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
- applySettings(Settings) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Applies the given settings to all the settings consumers or to none of them.
- applyStartedShards(ClusterState, List<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the started shards.
- applyStartedShards(RoutingAllocation, List<ShardRouting>) - Method in class org.elasticsearch.gateway.GatewayAllocator
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- applyTo(Binder) - Method in interface org.elasticsearch.common.inject.spi.Element
-
Writes this module element to the given binder (optional operation).
- applyTo(Binder) - Method in interface org.elasticsearch.common.inject.spi.ExposedBinding
-
Unsupported.
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.Message
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
- applyTo(ScopedBindingBuilder) - Method in class org.elasticsearch.common.inject.internal.Scoping
- applyTranslogOperation(Translog.Operation, Engine.Operation.Origin) - Method in class org.elasticsearch.index.shard.IndexShard
- 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.
- areValuesSourcesEmpty() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- array() - Method in class org.elasticsearch.common.bytes.BytesArray
- arrayAsArrayList(E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- arrayOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns an array type whose elements are all instances of
componentType
. - arrayToCommaDelimitedString(Object[]) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a String array as a CSV String.
- arrayToDelimitedString(Object[], String) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a String array as a delimited (e.g.
- arrayToDelimitedString(Object[], String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
- ArrayUtils - Class in org.elasticsearch.common.util
- ArrayValueMapperParser - Interface in org.elasticsearch.index.mapper
-
A marker interface indicating that this mapper can handle array value, and the array itself should be passed to it.
- asArrayList(E, E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- asArrayList(E, E, E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- asc - Variable in class org.elasticsearch.search.aggregations.InternalOrder
- ASC - org.elasticsearch.search.sort.SortOrder
-
Ascending order.
- asCopy() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns a copy of the current
IndexShardSnapshotStatus
. - asDistance() - Method in class org.elasticsearch.common.unit.Fuzziness
- asDistance(String) - Method in class org.elasticsearch.common.unit.Fuzziness
- asEagerSingleton() - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
Instructs the
Injector
to eagerly initialize this singleton-scoped binding upon creation. - asEagerSingleton() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- asFloat() - Method in class org.elasticsearch.common.unit.Fuzziness
- asList() - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Returns the it as a non null list.
- asList() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
The list of
Aggregation
s. - asMap() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- asMap() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- asMap() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Returns the
Aggregation
s keyed by aggregation name. - asMap() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- asMultiBucketAggregator(AggregatorFactory<?>, SearchContext, Aggregator) - Static method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Utility method.
- asSequentialAccessBits(int, ScorerSupplier) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Given a
ScorerSupplier
, return aBits
instance that will match all documents contained in the set. - assertClusterOrMasterStateThread() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- assertClusterOrMasterStateThread() - Static method in class org.elasticsearch.cluster.service.ClusterService
- 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 - assignedShards(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns all shards that are not in the state UNASSIGNED with the same shard ID as the given shard.
- assignedToNode() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
iff this shard is assigned to a node ie. - Assignment(String, String) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Assignment
- ASSIGNMENT_PARSER - Static variable in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- AssignmentDecision - Class in org.elasticsearch.persistent.decider
-
AssignmentDecision
represents the decision made during the process of assigning a persistent task to a node of the cluster. - AssignmentDecision(AssignmentDecision.Type, String) - Constructor for class org.elasticsearch.persistent.decider.AssignmentDecision
- AssignmentDecision.Type - Enum in org.elasticsearch.persistent.decider
- Assisted - Annotation Type in org.elasticsearch.common.inject.assistedinject
-
Annotates an injected parameter or field whose value comes from an argument to a factory method.
- AssistedInject - Annotation Type in org.elasticsearch.common.inject.assistedinject
-
Deprecated.
FactoryProvider
now works better with the standard @Inject annotation. When using that annotation, parameters are matched by name and type rather than by position. In addition, values that use the standard @Inject constructor annotation are eligible for method interception. - associateIndexWithNewTranslog(String) - Method in class org.elasticsearch.index.store.Store
-
Force bakes the given translog generation as recovery information in the lucene index.
- asString() - Method in class org.elasticsearch.common.unit.Fuzziness
- ASYNC - org.elasticsearch.index.translog.Translog.Durability
-
Async durability - translogs are synced based on a time interval.
- AsyncAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- AsyncBiFunction<T,U,C> - Interface in org.elasticsearch.common
-
A
BiFunction
-like interface designed to be used with asynchronous executions. - AsyncBroadcastAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- AsynchronousComputationException - Exception in org.elasticsearch.common.inject.internal
-
Wraps an exception that occurred during a computation in a different thread.
- AsynchronousComputationException(Throwable) - Constructor for exception org.elasticsearch.common.inject.internal.AsynchronousComputationException
- AsyncIOProcessor<Item> - Class in org.elasticsearch.common.util.concurrent
-
This async IO processor allows to batch IO operations and have a single writer processing the write operations.
- AsyncIOProcessor(Logger, int, ThreadContext) - Constructor for class org.elasticsearch.common.util.concurrent.AsyncIOProcessor
- AsyncShardFetch<T extends BaseNodeResponse> - Class in org.elasticsearch.gateway
-
Allows to asynchronously fetch shard related data from other nodes for allocation, without blocking the cluster update thread.
- AsyncShardFetch(Logger, String, ShardId, AsyncShardFetch.Lister<? extends BaseNodesResponse<T>, T>) - Constructor for class org.elasticsearch.gateway.AsyncShardFetch
- AsyncShardFetch.FetchResult<T extends BaseNodeResponse> - Class in org.elasticsearch.gateway
-
The result of a fetch operation.
- AsyncShardFetch.Lister<NodesResponse extends BaseNodesResponse<NodeResponse>,NodeResponse extends BaseNodeResponse> - Interface in org.elasticsearch.gateway
-
An action that lists the relevant shard data that needs to be fetched.
- asyncShardOperation(Request, ShardId, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- asyncShardOperation(ShardRequest, Task, ActionListener<ShardResponse>) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- atLeastOneNodeWithYesDecision() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Returns
true
if there is at least one node that returned aDecision.Type.YES
decision for allocating this shard. - AtomicArray<E> - Class in org.elasticsearch.common.util.concurrent
-
A list backed by an
AtomicReferenceArray
with potential null values, easily allowing to get the concrete values as a list usingAtomicArray.asList()
. - AtomicArray(int) - Constructor for class org.elasticsearch.common.util.concurrent.AtomicArray
- AtomicFieldData - Interface in org.elasticsearch.index.fielddata
-
The thread safe
LeafReader
level cache of the data. - AtomicGeoPointFieldData - Interface in org.elasticsearch.index.fielddata
-
AtomicFieldData
specialization for geo points. - AtomicNumericFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
AtomicFieldData
for numeric data. - AtomicOrdinalsFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
AtomicFieldData
for data that is indexed with ordinals. - attemptSyncedFlush(String[], IndicesOptions, ActionListener<SyncedFlushResponse>) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
-
a utility method to perform a synced flush for all shards of multiple indices.
- attemptSyncedFlush(ShardId, ActionListener<ShardsSyncedFlushResult>) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
- attr - Variable in class org.elasticsearch.common.Table.Cell
- attributes - Variable in class org.elasticsearch.index.engine.Segment
- attributes() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- attributes(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- ATTRIBUTES - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- AUTO - Static variable in class org.elasticsearch.common.unit.Fuzziness
- AUTO_CREATE_INDEX_SETTING - Static variable in class org.elasticsearch.action.support.AutoCreateIndex
- AUTO_INDEX_JTS_GEOMETRY - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- AUTO_SLICES - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AUTO_SLICES_VALUE - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AUTO_THROTTLE_SETTING - Static variable in class org.elasticsearch.index.MergeSchedulerConfig
- AUTO_VALIDATE_JTS_GEOMETRY - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- AutoCreateIndex - Class in org.elasticsearch.action.support
-
Encapsulates the logic of whether a new index should be automatically created when a write operation is about to happen in a non existing index.
- AutoCreateIndex(Settings, ClusterSettings, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.AutoCreateIndex
- AutoDateHistogramAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
-
Create a new builder with the given name.
- AutoDateHistogramAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
-
Read from a stream, for internal use only.
- AutoDateHistogramAggregationBuilder(AutoDateHistogramAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- AutoDateHistogramAggregationBuilder.RoundingInfo - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, int, AutoDateHistogramAggregationBuilder.RoundingInfo[], SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorFactory
- AutoExpandReplicas - Class in org.elasticsearch.cluster.metadata
-
This class acts as a functional wrapper around the
index.auto_expand_replicas
setting. - autoGeneratePhraseQueries() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Deprecated.
- autoGeneratePhraseQueries(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Deprecated.
- autoGenerateSynonymsPhraseQuery - Variable in class org.elasticsearch.index.search.MatchQuery
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- AutoQueueAdjustingExecutorBuilder - Class in org.elasticsearch.threadpool
-
A builder for executors that automatically adjust the queue length as needed, depending on Little's Law.
- available() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.StreamInput
- available() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
- availableCodecs() - Method in class org.elasticsearch.index.codec.CodecService
-
Returns all registered available codec names
- availableIndexFolders() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all folder names in ${data.paths}/nodes/{node.id}/indices folder
- availableIndexFolders(Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns folder names in ${data.paths}/nodes/{node.id}/indices folder that don't match the given predicate.
- availableIndexFoldersForPath(NodeEnvironment.NodePath) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return all directory names in the nodes/{node.id}/indices directory for the given node path.
- availableIndexFoldersForPath(NodeEnvironment.NodePath, Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return directory names in the nodes/{node.id}/indices directory for the given node path that don't match the given predicate.
- availableShardPaths(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all shard paths excluding custom shard path.
- availableShards() - Method in class org.elasticsearch.indices.IndexingMemoryController
- avg - Variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- avg - Variable in class org.elasticsearch.search.aggregations.metrics.stats.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.avg
-
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.avg
- AvgAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- AvgAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
-
Read from a stream.
- AvgAggregationBuilder(AvgAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- AvgAggregator - Class in org.elasticsearch.search.aggregations.metrics.avg
- AvgAggregator(String, ValuesSource.Numeric, DocValueFormat, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
- AvgAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.avg
- AvgAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregatorFactory
- avgBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- AvgBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg
- AvgBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- AvgBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
-
Read from a stream.
- AvgBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg
- AvgBucketPipelineAggregator(String, String[], BucketHelpers.GapPolicy, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
- AvgBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.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.
- 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.
- awaitTermination() - Method in interface org.elasticsearch.index.IndexWarmer.TerminationHandle
-
Wait until execution of the warm-up action completes.
- awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.threadpool.ThreadPool
- awaitTermination(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in interface org.elasticsearch.threadpool.Scheduler
- AwarenessAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
controls shard allocation based onawareness
key-value pairs defined in the node configuration. - AwarenessAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
B
- BACKGROUND_IS_SUPERSET - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- backgroundFilter() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- backgroundFilter() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- backgroundFilter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- backgroundFilter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- backgroundIsSuperset - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- backgroundIsSuperset - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
- backgroundSync(ShardId, RetentionLeases) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
-
Background sync the specified retention leases for the specified shard.
- backgroundSync(ShardId, RetentionLeases) - Method in interface org.elasticsearch.index.seqno.RetentionLeaseSyncer
- backoffPolicy - Variable in class org.elasticsearch.index.reindex.ScrollableHitSource
- BackoffPolicy - Class in org.elasticsearch.action.bulk
-
Provides a backoff policy for bulk requests.
- BackoffPolicy() - Constructor for class org.elasticsearch.action.bulk.BackoffPolicy
- BAD_GATEWAY - org.elasticsearch.rest.RestStatus
-
The server, while acting as a gateway or proxy, received an invalid response from the upstream server it accessed in attempting to fulfill the request.
- BAD_REQUEST - org.elasticsearch.rest.RestStatus
-
The request could not be understood by the server due to malformed syntax.
- BALANCED_ALLOCATOR - Static variable in class org.elasticsearch.cluster.ClusterModule
- BalancedShardsAllocator - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
The
BalancedShardsAllocator
re-balances the nodes allocations within an cluster based on aBalancedShardsAllocator.WeightFunction
. - BalancedShardsAllocator(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator.Balancer - Class in org.elasticsearch.cluster.routing.allocation.allocator
- BalancedShardsAllocator.WeightFunction - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
This class is the primary weight function used to create balanced over nodes and shards in the cluster.
- Balancer(Logger, RoutingAllocation, BalancedShardsAllocator.WeightFunction, float) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
- BAN_PARENT_ACTION_NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- base64UUID() - Static method in class org.elasticsearch.common.UUIDs
-
Generates a time-based UUID (similar to Flake IDs), which is preferred when generating an ID to be indexed into a Lucene index as primary key.
- BaseAggregationBuilder - Interface in org.elasticsearch.search.aggregations
-
Interface shared by
AggregationBuilder
andPipelineAggregationBuilder
so they can conveniently share the same namespace forXContentParser.namedObject(Class, String, Object)
. - BaseAliasesRequestBuilder<Response extends ActionResponse,Builder extends BaseAliasesRequestBuilder<Response,Builder>> - Class in org.elasticsearch.action.admin.indices.alias.get
- BaseAliasesRequestBuilder(ElasticsearchClient, Action<GetAliasesRequest, Response, Builder>, 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
- BaseGeoShapeFieldMapper - Class in org.elasticsearch.index.mapper
-
Base class for
GeoShapeFieldMapper
andLegacyGeoShapeFieldMapper
- BaseGeoShapeFieldMapper(String, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Explicit<Boolean>, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- BaseGeoShapeFieldMapper.BaseGeoShapeFieldType - Class in org.elasticsearch.index.mapper
- BaseGeoShapeFieldMapper.Builder<T extends BaseGeoShapeFieldMapper.Builder,Y extends BaseGeoShapeFieldMapper> - Class in org.elasticsearch.index.mapper
- BaseGeoShapeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- BaseGeoShapeFieldMapper.Names - Class in org.elasticsearch.index.mapper
- BaseGeoShapeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- BaseGeoShapeFieldType() - Constructor for class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- BaseGeoShapeFieldType(BaseGeoShapeFieldMapper.BaseGeoShapeFieldType) - Constructor for class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- BaseNodeRequest - Class in org.elasticsearch.action.support.nodes
- BaseNodeRequest() - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeRequest
- BaseNodeRequest(String) - 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() - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeResponse
- BaseNodeResponse(DiscoveryNode) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeResponse
- BaseNodesRequest<Request extends BaseNodesRequest<Request>> - Class in org.elasticsearch.action.support.nodes
- BaseNodesRequest() - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesRequest
- BaseNodesRequest(String...) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesRequest
- BaseNodesRequest(DiscoveryNode...) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesRequest
- BaseNodesResponse<TNodeResponse extends BaseNodeResponse> - Class in org.elasticsearch.action.support.nodes
- BaseNodesResponse() - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesResponse
- BaseNodesResponse(ClusterName, List<TNodeResponse>, List<FailedNodeException>) - 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(Settings) - Constructor for class org.elasticsearch.rest.BaseRestHandler
- BaseRestHandler.RestChannelConsumer - Interface in org.elasticsearch.rest
-
REST requests are handled by preparing a channel consumer that represents the execution of the request against a channel.
- BaseTasksRequest<Request extends BaseTasksRequest<Request>> - Class in org.elasticsearch.action.support.tasks
-
A base class for task requests
- BaseTasksRequest() - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksRequest
- BaseTasksRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksRequest
- BaseTasksResponse - Class in org.elasticsearch.action.support.tasks
-
Base class for responses of task-related operations
- BaseTasksResponse(List<TaskOperationFailure>, List<? extends ElasticsearchException>) - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksResponse
- 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() - 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).
- 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
- bbox(String) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Computes the bounding box coordinates from a given geohash
- bdd - Variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- BECOME_MASTER_TASK - Static variable in class org.elasticsearch.discovery.zen.NodeJoinController
-
a task indicated that the current node should become master, if no current master is known
- before(Version) - Method in class org.elasticsearch.Version
- beforeBulk(long, BulkRequest) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback before the bulk is executed.
- beforeClose() - Method in class org.elasticsearch.common.component.LifecycleListener
- beforeExecute(Thread, Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- beforeIndexAddedToCluster(Index, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called on the Master node only before the
IndexService
instances is created to simulate an index creation. - beforeIndexCreated(Index, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index gets created.
- beforeIndexRemoved(IndexService, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index get closed.
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets closed.
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.snapshots.SnapshotShardsService
- beforeIndexShardCreated(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets created.
- beforeIndexShardDeleted(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets deleted from disk Note: this method is only executed on the first attempt of deleting the shard.
- beforeLoad(Terms) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData.PerValueEstimator
-
Execute any pre-loading estimations for the terms.
- beforeLoad(Terms) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
-
Determine whether the BlockTreeTermsReader.FieldReader can be used for estimating the field data, adding the estimate to the circuit breaker if it can, otherwise wrapping the terms in a RamAccountingTermsEnum to be estimated on a per-term basis.
- beforeRefresh() - Method in class org.elasticsearch.index.shard.RefreshListeners
- beforeRelease() - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- beforeRelease() - Method in class org.elasticsearch.common.recycler.DequeRecycler
-
Called before releasing an object, returns true if the object should be recycled and false otherwise.
- beforeStart() - Method in class org.elasticsearch.common.component.LifecycleListener
- beforeStop() - Method in class org.elasticsearch.common.component.LifecycleListener
- BEST_COMPRESSION_CODEC - Static variable in class org.elasticsearch.index.codec.CodecService
- BEST_FIELDS - org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the best matching boolean field as main score and uses a tie-breaker to adjust the score based on remaining field matches
- BestBucketsDeferringCollector - Class in org.elasticsearch.search.aggregations.bucket
-
A specialization of
DeferringBucketCollector
that collects all matches and then is able to replay a given subset of buckets which represent the survivors from a pruning process performed by the aggregator that owns this collector. - BestBucketsDeferringCollector(SearchContext, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Sole constructor.
- BestDocsDeferringCollector - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
A specialization of
DeferringBucketCollector
that collects all matches and then replays only the top scoring documents to child aggregations. - beta(double) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.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.movavg.models.HoltWintersModel.HoltWintersModelBuilder
-
Equivalent to
alpha
, but controls the smoothing of the trend instead of the data - BG_COUNT - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- BigArray - Interface in org.elasticsearch.common.util
-
Base abstraction of an array.
- bigArrays - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
- bigArrays - Variable in class org.elasticsearch.transport.TcpTransport
- bigArrays() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- bigArrays() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- bigArrays() - Method in class org.elasticsearch.search.internal.SearchContext
- BigArrays - Class in org.elasticsearch.common.util
-
Utility class to work with arrays.
- BigArrays(PageCacheRecycler, CircuitBreakerService, String) - Constructor for class org.elasticsearch.common.util.BigArrays
- BigArrays(PageCacheRecycler, CircuitBreakerService, String, boolean) - Constructor for class org.elasticsearch.common.util.BigArrays
- bigQuery() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- bigQuery() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- BINARY - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BINARY - Static variable in interface org.elasticsearch.search.DocValueFormat
- BinaryDocValuesRangeQuery - Class in org.apache.lucene.queries
- BinaryDocValuesRangeQuery(String, BinaryDocValuesRangeQuery.QueryType, BinaryDocValuesRangeQuery.LengthType, BytesRef, BytesRef, Object, Object) - Constructor for class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- BinaryDocValuesRangeQuery.LengthType - Enum in org.apache.lucene.queries
- BinaryDocValuesRangeQuery.QueryType - Enum in org.apache.lucene.queries
- BinaryDVAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
-
AtomicFieldData
impl on top of Lucene's binary doc values. - BinaryDVAtomicFieldData(LeafReader, String) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryDVAtomicFieldData
- BinaryDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- BinaryDVIndexFieldData(Index, String) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- BinaryFieldMapper - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper(String, MappedFieldType, MappedFieldType, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper
- BinaryFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper.CustomBinaryDocValuesField - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- BinaryRange - Class in org.apache.lucene.document
-
A range field for binary encoded ranges
- BinaryRange(String, byte[]) - Constructor for class org.apache.lucene.document.BinaryRange
-
Create a new BinaryRange from a provided encoded binary range
- BinaryRangeAggregator - Class in org.elasticsearch.search.aggregations.bucket.range
-
A range aggregator for values that are stored in SORTED_SET doc values.
- BinaryRangeAggregator(String, AggregatorFactories, ValuesSource.Bytes, DocValueFormat, List<BinaryRangeAggregator.Range>, boolean, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- BinaryRangeAggregator.Range - Class in org.elasticsearch.search.aggregations.bucket.range
- BinaryRangeAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.range
- BinaryRangeAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Bytes>, List<BinaryRangeAggregator.Range>, boolean, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- binarySearch(double[], double, double) - Static method in class org.elasticsearch.common.util.ArrayUtils
-
Return the index of
value
inarray
, or-1
if there is no such index. - binaryValue() - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- bind(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- bind(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - bind(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- bind(String, InetSocketAddress) - Method in class org.elasticsearch.transport.TcpTransport
-
Binds to the given
InetSocketAddress
- bind(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(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
- BITS - Static variable in class org.elasticsearch.common.geo.GeoHashUtils
-
number of bits used for quantizing latitude and longitude values
- 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
- blend(TermContext[], 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
- 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.BlobStoreFormat
- blobNameFormat - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
- 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
- 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
- BlobStoreFormat<T extends ToXContent> - Class in org.elasticsearch.repositories.blobstore
-
Base class that handles serialization of various data structures during snapshot/restore operations.
- BlobStoreFormat(String, CheckedFunction<XContentParser, T, IOException>, NamedXContentRegistry) - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreFormat
- 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, Settings, NamedXContentRegistry) - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Constructs new BlobStoreRepository
- 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(Set<ClusterBlock>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- 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. - BOOLEAN - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- BOOLEAN - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BOOLEAN - org.elasticsearch.index.search.MatchQuery.Type
-
The text is analyzed and terms are added to a boolean query.
- BOOLEAN - org.elasticsearch.search.aggregations.support.ValueType
- BOOLEAN - Static variable in interface org.elasticsearch.search.DocValueFormat
- BooleanFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper for boolean fields.
- BooleanFieldMapper(String, MappedFieldType, MappedFieldType, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper
- BooleanFieldMapper.BooleanFieldType - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.Values - Class in org.elasticsearch.index.mapper
- BooleanFieldType() - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- BooleanFieldType(BooleanFieldMapper.BooleanFieldType) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- Booleans(SortedNumericDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- Booleans(SortedNumericDocValues, BiConsumer<String, String>) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- boolQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents matching boolean combinations of other queries.
- BoolQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents matching boolean combinations of other queries.
- BoolQueryBuilder() - Constructor for class org.elasticsearch.index.query.BoolQueryBuilder
-
Build an empty bool query.
- BoolQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.BoolQueryBuilder
-
Read from a stream.
- boolSetting(String, boolean, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- boolSetting(String, Function<Settings, String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- boolSetting(String, Setting<Boolean>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- boost - Variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- boost - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- boost() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
- 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
- bottomRight() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- bottomRight() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns the bottom right corner of the bounding box.
- bottomRight() - Method in interface org.elasticsearch.search.aggregations.metrics.geobounds.GeoBounds
-
Get the bottom-right location of the bounding box.
- bottomRight() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- bottomRight() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.ParsedGeoBounds
- boundAddress() - Method in interface org.elasticsearch.http.HttpServerTransport
- boundAddress() - Method in class org.elasticsearch.transport.TcpTransport
- boundAddress() - Method in interface org.elasticsearch.transport.Transport
-
The address the transport is bound on.
- boundAddress() - Method in class org.elasticsearch.transport.TransportService
- boundAddresses() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- BOUNDARY_CHARS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_MAX_SCAN_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_SCANNER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_SCANNER_LOCALE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryChars(char[]) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting defines what constitutes a boundary for highlighting. - boundaryMaxScan - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryMaxScan() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryMaxScan() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryMaxScan(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls how far to look for boundary characters, and defaults to 20. - boundaryScannerLocale - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerLocale() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerLocale() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryScannerLocale(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
and boundaryScannerTypebreak_iterator
, this setting controls the locale to use by the BreakIterator, defaults to "root". - boundaryScannerType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryScannerType(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls which scanner to use for fragment boundaries, and defaults to "simple". - boundaryScannerType(HighlightBuilder.BoundaryScannerType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls which scanner to use for fragment boundaries, and defaults to "simple". - BoundedBreakIteratorScanner - Class in org.apache.lucene.search.uhighlight
-
A custom break iterator that is used to find break-delimited passages bounded by a provided maximum length in the
UnifiedHighlighter
context. - BoundTransportAddress - Class in org.elasticsearch.common.transport
-
A bounded transport address is a tuple of
TransportAddress
, one array that represents the addresses the transport is bound to, and the other is the published one that represents the address clients should communicate on. - BoundTransportAddress(TransportAddress[], TransportAddress) - Constructor for class org.elasticsearch.common.transport.BoundTransportAddress
- BREADTH_FIRST - org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
Creates buckets for all matching docs and then prunes to top-scoring buckets before a second pass over the data when child aggregators are called but only for docs from the top-scoring buckets
- breaker() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- breaker(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node's circuit breaker stats be returned.
- BREAKER_TYPE_KEY - Static variable in class org.elasticsearch.node.Node
- breakerService - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- breakerService() - Method in class org.elasticsearch.common.util.BigArrays
- BreakerSettings - Class in org.elasticsearch.indices.breaker
-
Settings for a
CircuitBreaker
- BreakerSettings(String, long, double) - Constructor for class org.elasticsearch.indices.breaker.BreakerSettings
- BreakerSettings(String, long, double, CircuitBreaker.Type) - 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, Action<Request, Response, RequestBuilder>, Request) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
- BroadcastRequest<Request extends BroadcastRequest<Request>> - Class in org.elasticsearch.action.support.broadcast
- BroadcastRequest() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastRequest
- BroadcastRequest(String[]) - 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
- 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(ShardId, OriginalIndices) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardRequest(ShardId, BroadcastRequest) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardResponse - Class in org.elasticsearch.action.support.broadcast
- BroadcastShardResponse() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- BroadcastShardResponse(ShardId) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- Bucket(double, long, boolean, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- Bucket(long, long, boolean, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- Bucket(long, long, long, long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- Bucket(long, long, InternalAggregations, boolean, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- Bucket(long, long, 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(String, double, double, long, List<InternalAggregation>, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- Bucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- Bucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- Bucket(BytesRef, long, long, long, long, InternalAggregations, double, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- Bucket(BytesRef, long, long, long, long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- Bucket(BytesRef, long, InternalAggregations, boolean, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- Bucket(StreamInput, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, long, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, long, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
-
Read from a stream.
- Bucket(DocValueFormat, boolean, String, BytesRef, BytesRef, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- bucketAggregations(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Required method to build the child aggregations of the given bucket (identified by the bucket ordinal).
- BucketAggregationScript - Class in org.elasticsearch.script
-
A script used in bucket aggregations that returns a
double
value. - BucketAggregationScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.BucketAggregationScript
- BucketAggregationScript.Factory - Interface in org.elasticsearch.script
- BucketAggregationSelectorScript - Class in org.elasticsearch.script
-
A script used in bucket aggregations that returns a
boolean
value. - BucketAggregationSelectorScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.BucketAggregationSelectorScript
- BucketAggregationSelectorScript.Factory - Interface in org.elasticsearch.script
- BucketCollector - Class in org.elasticsearch.search.aggregations
-
A Collector that can collect data in separate buckets.
- BucketCollector() - Constructor for class org.elasticsearch.search.aggregations.BucketCollector
- bucketComparator(AggregationPath, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
-
Internal Optimization for ordering
InternalTerms.Bucket
s by a sub aggregation. - bucketCountThresholds - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregator
- bucketCountThresholds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- bucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- bucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- bucketCountThresholds(TermsAggregator.BucketCountThresholds) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- bucketCountThresholds(TermsAggregator.BucketCountThresholds) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- BucketCountThresholds(long, long, int, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- BucketCountThresholds(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
-
Read from a stream.
- BucketCountThresholds(TermsAggregator.BucketCountThresholds) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- bucketDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Utility method to return the number of documents that fell in the given bucket (identified by the bucket ordinal)
- bucketDocCount(long) - Method in interface org.elasticsearch.search.aggregations.bucket.SingleBucketAggregator
- bucketEmptyAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Utility method to build empty aggregations of the sub aggregators.
- BucketHelpers - Class in org.elasticsearch.search.aggregations.pipeline
-
A set of static helpers to simplify working with aggregation buckets, in particular providing utilities that help pipeline aggregations.
- BucketHelpers() - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketHelpers
- BucketHelpers.GapPolicy - Enum in org.elasticsearch.search.aggregations.pipeline
-
A gap policy determines how "holes" in a set of buckets should be handled.
- bucketMap - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- bucketMap - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- BucketMetricsParser - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics
-
A parser for parsing requests for a
BucketMetricsPipelineAggregator
- BucketMetricsParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsParser
- BucketMetricsPipelineAggregationBuilder<AF extends BucketMetricsPipelineAggregationBuilder<AF>> - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics
- BucketMetricsPipelineAggregationBuilder(String, String, String[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- BucketMetricsPipelineAggregationBuilder(StreamInput, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
-
Read from a stream.
- BucketMetricsPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics
-
A class of sibling pipeline aggregations which calculate metrics across the buckets of a sibling aggregation
- BucketMetricsPipelineAggregator(String, String[], BucketHelpers.GapPolicy, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
- BucketMetricsPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
-
Read from a stream.
- BucketMetricValue - Interface in org.elasticsearch.search.aggregations.pipeline.bucketmetrics
- 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.terms.GlobalOrdinalsStringTermsAggregator
- bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
- BucketPriorityQueue<B extends Terms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.terms
- BucketPriorityQueue(int, Comparator<? super B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.BucketPriorityQueue
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.significant.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, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- bucketScript(String, Map<String, String>, Script) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- bucketScript(String, Script, String...) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- BucketScriptPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketscript
- BucketScriptPipelineAggregationBuilder(String, Map<String, String>, Script) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- BucketScriptPipelineAggregationBuilder(String, Script, String...) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- BucketScriptPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
-
Read from a stream.
- BucketScriptPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketscript
- BucketScriptPipelineAggregator(String, Map<String, String>, Script, DocValueFormat, BucketHelpers.GapPolicy, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
- BucketScriptPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
-
Read from a stream.
- bucketSelector(String, Map<String, String>, Script) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- bucketSelector(String, Script, String...) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- BucketSelectorPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketselector
- BucketSelectorPipelineAggregationBuilder(String, Map<String, String>, Script) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- BucketSelectorPipelineAggregationBuilder(String, Script, String...) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- BucketSelectorPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
-
Read from a stream.
- BucketSelectorPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketselector
- BucketSelectorPipelineAggregator(String, Map<String, String>, Script, BucketHelpers.GapPolicy, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregator
- BucketSelectorPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregator
-
Read from a stream.
- BucketSignificancePriorityQueue<B extends SignificantTerms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.significant
- BucketSignificancePriorityQueue(int) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.BucketSignificancePriorityQueue
- bucketSort(String, List<FieldSortBuilder>) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- BucketSortPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketsort
-
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.bucketsort.BucketSortPipelineAggregationBuilder
- BucketSortPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
-
Read from a stream.
- BucketSortPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketsort
- BucketSortPipelineAggregator(String, List<FieldSortBuilder>, int, Integer, BucketHelpers.GapPolicy, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregator
- BucketSortPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregator
-
Read from a stream.
- bucketsPaths - Variable in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- bucketsPaths() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- bucketToXContent(CompositeAggregation.Bucket, XContentBuilder, ToXContent.Params) - Static method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
- BucketUtils - Class in org.elasticsearch.search.aggregations.bucket
-
Helper functions for common Bucketing functions
- BUFFER_SIZE - Static variable in class org.elasticsearch.common.io.Streams
- BufferedChecksumStreamInput - Class in org.elasticsearch.index.translog
-
Similar to Lucene's BufferedChecksumIndexInput, however this wraps a
StreamInput
so anything read will update the checksum - BufferedChecksumStreamInput(StreamInput, String) - Constructor for class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- BufferedChecksumStreamInput(StreamInput, String, BufferedChecksumStreamInput) - Constructor for class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- BufferedChecksumStreamOutput - Class in org.elasticsearch.index.translog
-
Similar to Lucene's BufferedChecksumIndexOutput, however this wraps a
StreamOutput
so anything written will update the checksum - BufferedChecksumStreamOutput(StreamOutput) - Constructor for class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- BufferPool(String, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- BufferPool(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- bufferSize - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- bufferSizeInBytes() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- build - Variable in class org.elasticsearch.Version
- build() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
- build() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup.Builder
- build() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats.IndexStatsBuilder
- build() - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Builds a new bulk processor.
- build() - Method in class org.elasticsearch.action.delete.DeleteResponse.Builder
- build() - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- build() - Method in class org.elasticsearch.action.index.IndexResponse.Builder
- build() - Method in class org.elasticsearch.action.update.UpdateResponse.Builder
- build() - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- build() - Method in class org.elasticsearch.cluster.ClusterState.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- build() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- build() - Method in class org.elasticsearch.cluster.RestoreInProgress.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- build() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- build() - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
Builds the routing table.
- build() - Method in class org.elasticsearch.common.cache.CacheBuilder
- build() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
Builds a new instance of the
- build() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
Builds a new instance of the
- build() - Method in class org.elasticsearch.common.geo.builders.CoordinatesBuilder
- build() - Method in interface org.elasticsearch.common.recycler.Recycler.Factory
- build() - Method in class org.elasticsearch.common.rounding.Rounding.Builder
- build() - Method in class org.elasticsearch.common.settings.Settings.Builder
- build() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Builds an
Ordinals
instance from the builders current state. - build() - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
- build() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
- build() - Method in class org.elasticsearch.script.ScriptMetaData.Builder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel.EWMAModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel.HoltLinearModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel.LinearModelBuilder
- build() - Method in interface org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel.SimpleModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.ContextBuilder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions.Builder
- build() - Method in class org.elasticsearch.snapshots.SnapshotInfo.SnapshotInfoBuilder
- build() - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Creates a new
ConnectionProfile
based on the added connections. - build() - Method in class org.elasticsearch.transport.TransportRequestOptions.Builder
- build(Object) - Static method in class org.elasticsearch.common.unit.Fuzziness
- build(String, TokenizerFactory, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.CustomNormalizerProvider
- build(Map<String, TokenizerFactory>, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.CustomAnalyzerProvider
- 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(InputIterator) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- build(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- build(ClusterState) - Static method in class org.elasticsearch.cluster.MasterNodeChangePredicate
-
builds a predicate that will accept a cluster state only if it was generated after the current has (re-)joined the master
- build(Priority) - Static method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
Build a cluster state update task configuration with the specified
Priority
and no timeout. - build(Priority, TimeValue) - Static method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
Build a cluster state update task configuration with the specified
Priority
and timeout. - build(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
- build(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- build(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
- build(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Creates an index-level
IndexAnalyzers
from this registry using the given index settings - build(IndexSettings, Map<String, AnalyzerProvider<?>>, Map<String, AnalyzerProvider<?>>, Map<String, TokenizerFactory>, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointDVIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.Builder
- build(FieldMapper.Builder, Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper.Builder
- 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.NumberFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper.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.SeqNoFieldMapper.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, MappedFieldType, MappedFieldType, Settings, FieldMapper.MultiFields, Explicit<Boolean>, Explicit<Boolean>, FieldMapper.CopyTo) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.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.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 @link
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(SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- build(SearchContext) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- build(SearchContext, AggregatorFactory<?>) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- build(SearchContext, AggregatorFactory<?>) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Internal: build an
AggregatorFactory
based on the configuration of this builder. - build(SearchContext, 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) - 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.Aggregator
-
Build an aggregation for data that has been collected into
bucket
. - buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTermsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- buildAggregation(List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
- buildAggregation(List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
-
Called after a collection run is finished to build the aggregation for the collected state.
- buildAggregation(List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
- buildAggregation(List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
- buildAggregation(List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
- buildAggregation(List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
- buildAggregation(List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
- buildAggregation(List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
- buildAliasFilter(ClusterState, String, Set<String>) - Method in class org.elasticsearch.indices.IndicesService
- buildAliasFilter(ClusterState, String, Set<String>) - Method in class org.elasticsearch.search.SearchService
- buildAnalyzerFactories(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- 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
- 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.
- buildDecisionsForAllNodes(ShardRouting, RoutingAllocation) - 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.
- buildDynamicHosts(UnicastHostsProvider.HostsResolver) - Method in class org.elasticsearch.discovery.zen.FileBasedUnicastHostsProvider
- buildDynamicHosts(UnicastHostsProvider.HostsResolver) - Method in class org.elasticsearch.discovery.zen.SettingsBasedHostsProvider
- buildDynamicHosts(UnicastHostsProvider.HostsResolver) - Method in interface org.elasticsearch.discovery.zen.UnicastHostsProvider
-
Builds the dynamic list of unicast hosts to be used for unicast discovery.
- 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.AggregatorFactory.MultiBucketAggregatorWrapper
- 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.GeoHashGridAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- 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.significant.GlobalOrdinalsSignificantTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregator
- 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.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.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
- builder(ClusterName) - Static method in class org.elasticsearch.cluster.ClusterState
- builder(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterState
- 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
- builder(TimeValue) - Static method in class org.elasticsearch.common.rounding.Rounding
- 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(TransportRequestOptions) - Static method in class org.elasticsearch.transport.TransportRequestOptions
- 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.ClusterStateTaskExecutor.ClusterTasksResult.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.index.fielddata.plain.AbstractLatLonPointDVIndexFieldData.Builder
- Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData.Builder
- Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData.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.SeqNoFieldMapper.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- Builder() - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
Create an empty builder.
- Builder() - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.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) - 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.ParentFieldMapper.Builder
- 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, LegacyGeoShapeFieldMapper.DeprecatedParameters) - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.Builder
-
Deprecated.
- Builder(String, MappedFieldType, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
-
default builder - used for external mapper
- Builder(String, MappedFieldType, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Builder
- Builder(String, MappedFieldType, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.MetadataFieldMapper.Builder
- Builder(String, MappedFieldType, MappedFieldType, boolean, boolean, ShapeBuilder.Orientation, boolean) - Constructor for class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- Builder(String, NumberFieldMapper.NumberType) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- Builder(String, RangeFieldMapper.RangeType, Version) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- Builder(Function<MapperService, String>) - 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(AliasMetaData) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetaData.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
- Builder(TimeValue) - Constructor for class org.elasticsearch.common.rounding.Rounding.Builder
- Builder(Index) - Constructor for class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- Builder(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- Builder(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Builder
- Builder(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.IgnoredFieldMapper.Builder
- Builder(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.IndexFieldMapper.Builder
- Builder(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.RoutingFieldMapper.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(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.bucketmetrics.BucketMetricsParser
- buildFactory(String, String, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.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
- 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
- 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. - buildLucene() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.LineStringBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.MultiPointBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- buildLucene() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
build lucene geometry.
- 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
. - buildNormalizerFactories(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- buildRecoveryTable(RestRequest, RecoveryResponse) - Method in class org.elasticsearch.rest.action.cat.RestRecoveryAction
-
buildRecoveryTable will build a table of recovery information suitable for displaying at the command line.
- buildRemoteClustersDynamicConfig(Settings) - Static method in class org.elasticsearch.transport.RemoteClusterAware
-
Builds the dynamic per-cluster config from the given settings.
- 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
- buildSeqNoStats(SegmentInfos) - Static method in class org.elasticsearch.index.engine.ReadOnlyEngine
- 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, boolean) - 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) - 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
- buildSynonymAnalyzer(TokenizerFactory, List<CharFilterFactory>, List<TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- buildSynonyms(Analyzer, Reader) - Method in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- 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
- 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_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() - Constructor for class org.elasticsearch.index.reindex.BulkByScrollResponse
- BulkByScrollResponse(Iterable<BulkByScrollResponse>, String) - 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, String) - 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, String) - Constructor for class org.elasticsearch.action.bulk.BulkRequestBuilder
- BulkRequestHandler - Class in org.elasticsearch.action.bulk
-
Implements the low-level details of bulk request handling
- 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
- bulkScorer(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- BulkShardRequest - Class in org.elasticsearch.action.bulk
- BulkShardRequest() - 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_UUID - Static variable in class org.elasticsearch.cluster.RestoreInProgress
-
Fallback UUID used for restore operations that were started before v7.0 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
. - ByteBufferReference(ByteBuffer) - Constructor for class org.elasticsearch.common.bytes.ByteBufferReference
- 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.io.stream.ReleasableBytesStreamOutput
-
Returns a
Releasable
implementation of aBytesReference
that represents the current state of the bytes in the stream. - bytes() - Method in class org.elasticsearch.common.text.Text
-
Returns a
BytesReference
view of the data. - bytes() - Method in class org.elasticsearch.transport.BytesTransportRequest
- bytes(XContentBuilder) - Static method in class 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.ValuesSourceType
- 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
- 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.
- BytesBinaryDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- BytesBinaryDVIndexFieldData(Index, String) - Constructor for class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData
- BytesBinaryDVIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- 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
- BytesMultiValuesSource(Map<String, ValuesSourceConfig<ValuesSource.Bytes>>, QueryShardContext) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSource.BytesMultiValuesSource
- 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 - Class in org.elasticsearch.common.bytes
-
A reference to bytes.
- BytesReference() - Constructor for class org.elasticsearch.common.bytes.BytesReference
- 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
- BytesRefs(SortedBinaryDocValues, BiConsumer<String, String>) - 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
. - 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
- bytesToDouble(byte[]) - Static method in class org.elasticsearch.common.Numbers
-
Converts a byte array to double.
- bytesToDouble(BytesRef) - Static method in class org.elasticsearch.common.Numbers
- bytesToFloat(byte[]) - Static method in class org.elasticsearch.common.Numbers
-
Converts a byte array to float.
- bytesToFloat(BytesRef) - Static method in class org.elasticsearch.common.Numbers
- bytesToInt(byte[]) - Static method in class org.elasticsearch.common.Numbers
-
Converts a byte array to an int.
- bytesToInt(BytesRef) - Static method in class org.elasticsearch.common.Numbers
- bytesToLong(byte[]) - Static method in class org.elasticsearch.common.Numbers
-
Converts a byte array to a long.
- bytesToLong(BytesRef) - Static method in class org.elasticsearch.common.Numbers
- bytesToShort(byte[]) - Static method in class org.elasticsearch.common.Numbers
-
Converts a byte array to an short.
- bytesToShort(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() - Constructor for class org.elasticsearch.transport.BytesTransportRequest
- BytesTransportRequest(BytesReference, Version) - Constructor for class org.elasticsearch.transport.BytesTransportRequest
- 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
-
Get the current
ValuesSource.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.WithScript
- 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.CacheStats - Class in org.elasticsearch.common.cache
- CacheBuilder<K,V> - Class in org.elasticsearch.common.cache
- cacheKey() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- cacheKey() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the cache key for this shard search request, based on its content
- cacheKey() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- CacheLoader<K,V> - Interface in org.elasticsearch.common.cache
- CacheStats(long, long, long) - Constructor for class org.elasticsearch.common.cache.Cache.CacheStats
- calcHighFreqMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
- calcLowFreqMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
- calcMinimumNumberShouldMatch(String, int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
- 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
- calculatePercentage(long, long) - Static method in class org.elasticsearch.monitor.os.OsStats
- calculateTaskOutputs(MasterService.TaskInputs, ClusterState, long) - Method in class org.elasticsearch.cluster.service.MasterService
- 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.movavg.models.EwmaModel
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Returns if the model can be cost minimized.
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.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.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(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
- CancellableCollector - Class in org.elasticsearch.search.query
-
Collector that checks if the task it is executed under is cancelled.
- CancellableCollector(BooleanSupplier, Collector) - Constructor for class org.elasticsearch.search.query.CancellableCollector
-
Constructor
- 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.
- 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
-
Action 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() - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- CancelTasksResponse(List<TaskInfo>, List<TaskOperationFailure>, List<? extends ElasticsearchException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- 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, long, double, double, boolean) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- 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
- 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.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) - 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
- 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 interface org.elasticsearch.rest.RestHandler
- canTripCircuitBreaker() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- canTripCircuitBreaker(Optional<RestHandler>) - Method in class org.elasticsearch.rest.RestController
- canUseIfSeqNo(ClusterState) - Static method in interface org.elasticsearch.action.DocWriteRequest
-
Tests if the cluster is ready for compare and write using sequence numbers.
- 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)
. - cardinality(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.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.cardinality
-
An aggregation that computes approximate numbers of unique terms.
- CardinalityAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.cardinality
- CardinalityAggregationBuilder(String, ValueType) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- CardinalityAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
-
Read from a stream.
- CardinalityAggregationBuilder(CardinalityAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- CardinalityAggregator - Class in org.elasticsearch.search.aggregations.metrics.cardinality
-
An aggregator that computes approximate counts of unique values.
- CardinalityAggregator(String, ValuesSource, int, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
- CardinalityAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.cardinality
- CardinalityAggregatorFactory(String, ValuesSourceConfig<ValuesSource>, Long, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregatorFactory
- 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.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.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
- 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
- CENTIMETERS - org.elasticsearch.common.unit.DistanceUnit
- centroid() - Method in interface org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroid
- centroid() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- centroid() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.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.DetailAnalyzeResponse.CharFilteredText
- CharFilterFactory - Interface in org.elasticsearch.index.analysis
- charfilters() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- charfilters(DetailAnalyzeResponse.CharFilteredText[]) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- charFilters() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- 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.
- checkAndNotify() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
- checkAndNotify() - Method in interface org.elasticsearch.watcher.ResourceWatcher
-
Called periodically by
ResourceWatcherService
so resource watcher can check the resource - checkBlock(ClusterAllocationExplainRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- checkBlock(ClusterHealthRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- 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.TransportCreateIndexAction
- 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(GetIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
- checkBlock(GetMappingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
- 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(RolloverRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- checkBlock(GetSettingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
- checkBlock(UpdateSettingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
- checkBlock(IndicesShardStoresRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.shards.TransportIndicesShardStoresAction
- checkBlock(ResizeRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- checkBlock(DeleteIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- checkBlock(GetIndexTemplatesRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- 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.TransportMasterNodeAction
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Checks for any conflicts between this field type and other.
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- checkConsistency() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- checkCorruptMarkerFileIsPresent(Directory) - Method in class org.elasticsearch.index.shard.RemoveCorruptedLuceneSegmentsAction
- 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. - CheckedConsumer<T,E extends java.lang.Exception> - Interface in org.elasticsearch.common
-
A
Consumer
-like interface which allows throwing checked exceptions. - CheckedRunnable<E extends java.lang.Exception> - Interface in org.elasticsearch.common
-
A
Runnable
-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. - checkFrequencies(long, long, long, long, String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- checkFrequencyValidity(long, long, long, long, String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.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.
- checkIndexClosing(ClusterState, Set<IndexMetaData>) - Static method in class org.elasticsearch.snapshots.RestoreService
-
Check if any of the indices to be closed are currently being restored from a snapshot and fail closing if such an index is found as closing an index that is being restored makes the index unusable (it cannot be recovered).
- checkIndexClosing(ClusterState, Set<IndexMetaData>) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Check if any of the indices to be closed are currently being snapshotted.
- checkIndexDeletion(ClusterState, Set<IndexMetaData>) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Check if any of the indices to be deleted are currently being snapshotted.
- checkIndexTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- checkIndexTime(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- checkIntegrity(StoreFileMetaData, Directory) - Static method in class org.elasticsearch.index.store.Store
- checkIntegrityNoException(StoreFileMetaData) - Method in class org.elasticsearch.index.store.Store
- checkIntegrityNoException(StoreFileMetaData, Directory) - Static method in class org.elasticsearch.index.store.Store
- 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
- checkParentLimit(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.
- 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.fieldcaps.TransportFieldCapabilitiesIndexAction
- 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
- checkSegmentInfoIntegrity(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
- checkShardLimit(int, ClusterState, DeprecationLogger) - Static method in class org.elasticsearch.indices.IndicesService
-
Checks to see if an operation can be performed without taking the cluster over the cluster-wide shard limit.
- checkShardLimit(Settings, ClusterState, DeprecationLogger) - Static method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
-
Checks whether an index can be created without going over the cluster 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.
- checksum() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- ChecksumBlobStoreFormat<T extends 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
- ChecksumBlobStoreFormat(String, String, CheckedFunction<XContentParser, T, IOException>, NamedXContentRegistry, boolean, XContentType) - 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.movavg.models.MovAvgModel.AbstractModelParser
- childBindingAlreadySet(Key<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- 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.
- ChildMemoryCircuitBreaker(BreakerSettings, ChildMemoryCircuitBreaker, 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
- ChiSquare - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- ChiSquare(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
- ChiSquare(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
-
Read from a stream.
- ChiSquare.ChiSquareBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- ChiSquareBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.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.
- 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.Type - Enum in org.elasticsearch.common.breaker
- 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) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
- CircuitBreakingException(String, long, long) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
- CircuitBreakingException(StreamInput) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
- 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
- cleanFiles(int, Store.MetadataSnapshot) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- cleanFiles(int, Store.MetadataSnapshot) - 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, Store.MetadataSnapshot) - 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(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.
- 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.lucene.all.AllEntries
- 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.ordinals.GlobalOrdinalsIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
- clear() - Method in class org.elasticsearch.index.fielddata.UidIndexFieldData
- clear() - Method in class org.elasticsearch.script.DeprecationMap
- 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(int) - Method in class org.elasticsearch.common.util.BitArray
- 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(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
- 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.
- clearField(String) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
- 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() - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- ClearIndicesCacheRequest(String...) - 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
- 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
- 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.
- 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() - 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
- CLIENT_TRANSPORT_NODES_SAMPLER_INTERVAL - Static variable in class org.elasticsearch.client.transport.TransportClient
- CLIENT_TRANSPORT_PING_TIMEOUT - Static variable in class org.elasticsearch.client.transport.TransportClient
- CLIENT_TRANSPORT_SNIFF - Static variable in class org.elasticsearch.client.transport.TransportClient
- CLIENT_TYPE - Static variable in class org.elasticsearch.client.transport.TransportClient
- 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<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.BooleanFieldMapper.BooleanFieldType
- clone() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- clone() - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- clone() - Method in class org.elasticsearch.index.mapper.FieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- clone() - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- clone() - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.GeoShapeFieldType
- clone() - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- clone() - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- clone() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- clone() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- clone() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- clone() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- 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.RangeFieldMapper.RangeFieldType
- clone() - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- clone() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Clone the model, returning an exact copy
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- close() - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- 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
-
Closes the client.
- close() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- close() - Method in class org.elasticsearch.common.bytes.ReleasablePagedBytesReference
- 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.ConcurrentDequeRecycler
- close() - Method in class org.elasticsearch.common.recycler.DequeRecycler
- close() - Method in class org.elasticsearch.common.recycler.NoneRecycler
- close() - Method in class org.elasticsearch.common.recycler.NoneRecycler.NV
- close() - Method in interface org.elasticsearch.common.recycler.Recycler
- 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 class org.elasticsearch.common.util.concurrent.ThreadContext
- 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.common.util.PageCacheRecycler
- 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.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.cache.bitset.BitsetFilterCache
- close() - Method in class org.elasticsearch.index.cache.IndexCache
- close() - Method in class org.elasticsearch.index.cache.query.DisabledQueryCache
- close() - Method in class org.elasticsearch.index.cache.query.IndexQueryCache
- close() - Method in class org.elasticsearch.index.engine.Engine
- close() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- close() - Method in class org.elasticsearch.index.engine.Engine.IndexCommitRef
- close() - Method in class org.elasticsearch.index.engine.Engine.Searcher
- close() - Method in class org.elasticsearch.index.engine.RecoveryCounter
- 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.BinaryDVAtomicFieldData
- close() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
- close() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVBytesAtomicFieldData
- 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.AggregatorFactory.MultiBucketAggregatorWrapper
- 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.significant.SignificantTermsAggregatorFactory
- close() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregatorFactory
- close() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- close() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- 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.threadpool.ThreadPool
- close() - Method in class org.elasticsearch.transport.CloseableConnection
- close() - Method in class org.elasticsearch.transport.ConnectionManager
- close() - Method in class org.elasticsearch.transport.InboundMessage
- close() - Method in class org.elasticsearch.transport.RemoteClusterService
- close() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- close() - Method in interface org.elasticsearch.transport.Transport.Connection
- 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<AcknowledgedResponse>) - 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 have 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.
- 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
- closeIndices(CloseIndexClusterStateUpdateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexStateService
-
Closes one or more indices.
- closeInternal() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
- closeInternal() - Method in class org.elasticsearch.env.ShardLock
- 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
- 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.
- closeWhileHandlingException(Iterable<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_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.ClusterService
- CLUSTER_STATE_SIZE - Static variable in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- 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.
- ClusterAllocationExplainAction - Class in org.elasticsearch.action.admin.cluster.allocation
-
Action 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.
- 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() - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainResponse
- ClusterAllocationExplainResponse(ClusterAllocationExplanation) - 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, Supplier<ClusterState.Builder>) - Constructor for class org.elasticsearch.cluster.service.ClusterApplierService
- clusterBlock() - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.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
- ClusterBlockException - Exception in org.elasticsearch.cluster.block
- 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
- 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.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
- 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.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(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
- 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>) - Constructor for class org.elasticsearch.cluster.ClusterInfo
-
Creates a new ClusterInfo instance.
- ClusterInfo(StreamInput) - Constructor for class org.elasticsearch.cluster.ClusterInfo
- 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, Action<Request, Response, Builder>, 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 at regular intervals
- 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
- 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
- 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 - Class in org.elasticsearch.cluster.service
- ClusterService(Settings, ClusterSettings, ThreadPool, Map<String, Supplier<ClusterState.Custom>>) - 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() - 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 - 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 interface org.elasticsearch.cluster.ClusterStateTaskExecutor
-
Callback invoked after new cluster state is published.
- clusterStatePublished(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
- clusterStatePublished(ClusterChangedEvent) - Method in class org.elasticsearch.discovery.zen.NodeJoinController.JoinTaskExecutor
- 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
- 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() - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- ClusterStateResponse(ClusterName, ClusterState, long, boolean) - 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
- 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
- clusterStateVersion() - Method in class org.elasticsearch.indices.recovery.RecoveryWaitForClusterStateRequest
- 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>) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- ClusterStatsIndices.ShardStats - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsNodeRequest() - 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
- 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() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
- ClusterStatsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
-
Get stats from nodes based on the nodes ids specified.
- ClusterStatsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsRequestBuilder(ElasticsearchClient, 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>) - 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
- 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
- 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.BaseGeoShapeFieldMapper.Builder
- coerce - Variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- coerce() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- coerce(boolean) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.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.BaseGeoShapeFieldMapper.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.BaseGeoShapeFieldMapper.Defaults
- COERCE - Static variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.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, long, ScoreDoc[], SortField[], Object[], float) - 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.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 given bucket.
- collect(int, long) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollectorBase
- collect(int, long) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingLeafBucketCollector
- collect(long, long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.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.bucketmetrics.avg.AvgBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.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.bucketmetrics.max.MaxBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
- 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
- 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
- collectMode - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- collectMode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Expert: get the collection mode.
- collectMode(Aggregator.SubAggCollectionMode) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Expert: set the collection mode.
- collectNodes(Set<String>, ActionListener<BiFunction<String, String, DiscoveryNode>>) - Method in class org.elasticsearch.transport.RemoteClusterService
-
Collects all nodes of the given clusters and returns / passes a (clusterAlias, nodeId) to
DiscoveryNode
function on success. - COLLECTOR - Static variable in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- CollectorResult - Class in org.elasticsearch.search.profile.query
-
Public interface and serialization container for profiled timings of the Collectors used in the search.
- CollectorResult(String, String, Long, List<CollectorResult>) - Constructor for class org.elasticsearch.search.profile.query.CollectorResult
- CollectorResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.query.CollectorResult
-
Read from a stream.
- collectSearchShards(IndicesOptions, String, String, Map<String, OriginalIndices>, ActionListener<Map<String, ClusterSearchShardsResponse>>) - Method in class org.elasticsearch.transport.RemoteClusterService
- 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
. - 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.scripted.ScriptedMetricAggregationBuilder
-
Get the
combine
script. - combineScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Set the
combine
script. - CombineScript(Map<String, Object>, Object) - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- 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
- commands() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Get the commands wrapped by this instance
- commands(AllocationCommands) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Set the allocation commands to execute.
- COMMIT_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- COMMIT_MISMATCH - org.elasticsearch.index.engine.Engine.SyncedFlushResult
- 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() - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateAction.CommitClusterStateRequest
- CommitClusterStateRequest(String) - 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
- 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
- commonTermsCutoff - Variable in class org.elasticsearch.index.search.MatchQuery
- commonTermsQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a common query for the provided field name and text.
- CommonTermsQueryBuilder - Class in org.elasticsearch.index.query
-
CommonTermsQuery query is a query that executes high-frequency terms in a optional sub-query to prevent slow queries due to "common" terms like stopwords.
- CommonTermsQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Constructs a new common terms query.
- CommonTermsQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Read from a stream.
- comparator - Variable in class org.elasticsearch.search.aggregations.InternalOrder
- comparator(Aggregator) - Method in class org.elasticsearch.search.aggregations.BucketOrder
- comparator(Aggregator) - Method in class org.elasticsearch.search.aggregations.InternalOrder.Aggregation
- comparator(Aggregator) - Method in class org.elasticsearch.search.aggregations.InternalOrder
- comparator(Aggregator) - 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(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(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(LongTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- compareKey(StringTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- compareKey(T) - Method in interface org.elasticsearch.search.aggregations.KeyComparable
-
Compare this
MultiBucketsAggregation.Bucket
skey
with another bucket. - compareTo(IndicesShardStoresResponse.StoreStatus) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- compareTo(NodeAllocationResult) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- compareTo(ShardIterator) - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
- compareTo(BytesReference) - Method in class org.elasticsearch.common.bytes.BytesReference
- 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(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(SearchShardTarget) - Method in class org.elasticsearch.search.SearchShardTarget
- 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
- COMPATIBILITY_VERSION - Static variable in class org.elasticsearch.action.admin.indices.shrink.ResizeAction
- 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.script.ScriptService
-
Compiles a script using the given context.
- 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.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
- 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, MappedFieldType, Settings, 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() - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- CompletionPersistentTaskAction - Class in org.elasticsearch.persistent
-
Action 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.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
- 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() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- CompletionSuggestion(String, int, boolean) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion
-
Ctr
- 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
- 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. - CompositeBytesReference(BytesReference...) - Constructor for class org.elasticsearch.common.bytes.CompositeBytesReference
- 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 - Variable in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- 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 - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- compression() - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
-
Returns the compression factor of the t-digest sketches used
- compression() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
-
Expert: get the compression.
- compression() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Expert: get the compression.
- compression() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
- compression(double) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
-
Set the compression factor of the t-digest sketches used
- compression(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
-
Expert: set the compression.
- compression(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Expert: set the compression.
- COMPRESSION_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- 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
- ComputationException - Exception in org.elasticsearch.common.inject.internal
-
Wraps an exception that occurred during a computation.
- ComputationException(Throwable) - Constructor for exception org.elasticsearch.common.inject.internal.ComputationException
- computeAndValidateWriteIndex() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
- 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.ScriptedSimilarity
- computeNxys(long, long, long, long, String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity
- 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
- 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, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Translates the provided index expression into actual concrete indices, properly deduplicated.
- 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. - concreteIndices(ClusterState, IndicesOptions, long, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Translates the provided index expression into actual concrete indices, properly deduplicated.
- 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(Supplier<R>) - 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(Supplier<R>) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- ConcreteShardRequest(R, String, long) - 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.
- 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
- 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() - Method in class org.elasticsearch.repositories.RepositoriesModule
- 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.
- 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.
- 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
-
Returns the current connected transport nodes that this client will use.
- 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.TransportService
- ConnectionManager - Class in org.elasticsearch.transport
-
This class manages node connections.
- ConnectionManager(Settings, Transport) - Constructor for class org.elasticsearch.transport.ConnectionManager
- ConnectionManager(ConnectionProfile, Transport) - Constructor for class org.elasticsearch.transport.ConnectionManager
- 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, ConnectionProfile) - Method in class org.elasticsearch.transport.TransportService
-
Connect to the specified node with the given connection profile
- connectToNode(DiscoveryNode, ConnectionProfile, CheckedBiConsumer<Transport.Connection, ConnectionProfile, IOException>) - Method in class org.elasticsearch.transport.ConnectionManager
-
Connects to a node with the given connection profile.
- connectToNodes(DiscoveryNodes) - Method in class org.elasticsearch.cluster.NodeConnectionsService
- 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
- 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
- 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.bucket.BucketsAggregator
-
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 - 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 - consumeNetworkReads(TcpChannel, BytesReference) - Method in class org.elasticsearch.transport.TcpTransport
-
Consumes bytes that are available from network reads.
- 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.index.seqno.LocalCheckpointTracker
-
Checks if the given sequence number was marked as completed in this tracker.
- 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 - containsIndex(Index) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
-
Returns true if the graveyard contains a tombstone for the given index.
- 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.DeprecationMap
- 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.RangeFieldMapper.RangeType
- containsValue(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- containsValue(Object) - Method in class org.elasticsearch.script.DeprecationMap
- 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
- content() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- content() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- content() - Method in class org.elasticsearch.rest.BytesRestResponse
- content() - Method in class org.elasticsearch.rest.RestRequest
- content() - Method in class org.elasticsearch.rest.RestResponse
-
The response content.
- content(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
-
Set the script source and the content type of the bytes.
- CONTENT_FIELD_NAME_CONTEXTS - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- CONTENT_FIELD_NAME_INPUT - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- CONTENT_FIELD_NAME_WEIGHT - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- CONTENT_TYPE - Static variable in class org.elasticsearch.client.Requests
-
The content type used to generate request builders (query / search).
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- 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.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.ParentFieldMapper
- 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.UidFieldMapper
- 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.
- 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.BaseGeoShapeFieldMapper
- 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.IdFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IndexFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- 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.UidFieldMapper
- 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.AggregatorFactory
- 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.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.AggregatorFactory.MultiBucketAggregatorWrapper
- 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 - 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.script.BucketAggregationScript
- CONTEXT - Static variable in class org.elasticsearch.script.BucketAggregationSelectorScript
- 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.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.SearchScript
-
The context used to compile
SearchScript
factories. - 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.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.movfn.MovingFunctionScript
- 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
- ContextIndexSearcher - Class in org.elasticsearch.search.internal
-
Context-aware extension of
IndexSearcher
. - ContextIndexSearcher(Engine.Searcher, QueryCache, QueryCachingPolicy) - Constructor for class org.elasticsearch.search.internal.ContextIndexSearcher
- ContextMapping<T extends ToXContent> - Class in org.elasticsearch.search.suggest.completion.context
-
A
ContextMapping
defines criteria that can be used to filter and/or boost suggestions at query time forCompletionFieldMapper
. - ContextMapping(ContextMapping.Type, String) - Constructor for class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Define a new context mapping of a specific type
- ContextMapping.InternalQueryContext - Class in org.elasticsearch.search.suggest.completion.context
- ContextMapping.Type - Enum 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(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(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
- convertAutomaton(Automaton) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- convertAutomaton(Automaton) - Method in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
- 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
- convertNowRangeToMatchAll() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
In pre-processing contexts that happen at index time 'now' date ranges should be replaced by a
MatchAllQueryBuilder
. - 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
- 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, 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(BytesRef, BytesRef) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- 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
- 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.
- copySettings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- copySettings(boolean) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- copyShards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- copyTo - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- copyTo - Variable in class org.elasticsearch.index.mapper.FieldMapper
- copyTo() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
List of fields where this field should be copied to
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.miscellaneous.DisableGraphAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- 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.
- copyWithNewSlice(SliceBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Create a shallow copy of this builder with a new slice configuration.
- CORE_CONTEXTS - Static variable in class org.elasticsearch.script.ScriptModule
- Correction - Class in org.elasticsearch.search.suggest.phrase
- Correction(double, DirectCandidateGenerator.Candidate[]) - Constructor for class org.elasticsearch.search.suggest.phrase.Correction
- corrections - Variable in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker.Result
- CORRUPTED - org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- CORRUPTED - Static variable in class org.elasticsearch.index.store.Store
- 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. - corsSettingAsArray(String) - Static method in class org.elasticsearch.rest.RestUtils
-
Return the CORS setting as an array of origins.
- cost() - Method in class org.apache.lucene.search.XFilteredDocIdSetIterator
- 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.search.aggregations.metrics.stats.InternalStats
- count - Variable in class org.elasticsearch.search.aggregations.metrics.stats.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.search.aggregations.AggregatorFactories.Builder
- count() - Method in interface org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroid
- count() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- count() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.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
- countPipelineAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
- 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.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.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.significant.InternalSignificantTerms
- create(long, long, List<SignificantLongTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
- create(long, long, List<SignificantStringTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
- create(long, long, List<UnmappedSignificantTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.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, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- create(String, List<InternalDateRange.Bucket>, DocValueFormat, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Factory
- create(String, List<InternalGeoDistance.Bucket>, DocValueFormat, boolean, List<PipelineAggregator>, 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<InternalGeoHashGrid.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- 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<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<SignificantLongTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
- create(List<SignificantStringTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
- create(List<UnmappedSignificantTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- create(List<DoubleTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- create(List<LongTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- create(List<StringTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- create(List<UnmappedTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- create(Map<String, Processor.Factory>, String, Map<String, Object>) - Method in class org.elasticsearch.ingest.DropProcessor.Factory
- create(Map<String, Processor.Factory>, String, Map<String, Object>) - Method in class org.elasticsearch.ingest.PipelineProcessor.Factory
- create(Map<String, Processor.Factory>, 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 class org.elasticsearch.index.analysis.SynonymGraphTokenFilterFactory
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- 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) - Static method in class org.elasticsearch.index.translog.TranslogWriter
- create(Aggregator, boolean) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Creates the aggregator
- create(InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Create a new copy of this
Aggregation
with the same settings as thisAggregation
and contains the provided sub-aggregations. - create(Version) - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
- create(Version) - Method in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- create(Version) - Method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
- create(Version) - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
- create(Version) - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
- create(Version) - Method in enum 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_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
- 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(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, InternalGeoHashGrid.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- 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, 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, SignificantLongTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
- createBucket(InternalAggregations, SignificantStringTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
- createBucket(InternalAggregations, UnmappedSignificantTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- createBucket(InternalAggregations, DoubleTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- createBucket(InternalAggregations, LongTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- createBucket(InternalAggregations, StringTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- createBucket(InternalAggregations, UnmappedTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
Create an array to hold some buckets.
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- 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.LongTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- 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, long, double) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- createCandidate(BytesRef, long, double, boolean) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- createCandidate(BytesRef, long, double, boolean) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- createCandidate(BytesRef, long, 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, 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(Client, ClusterService, ThreadPool, ResourceWatcherService, ScriptService, NamedXContentRegistry, Environment, NodeEnvironment, NamedWriteableRegistry) - 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
- createDeleteTombstoneDoc(String, String, String) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- createDirectSpellChecker() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- createEmpty() - 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
- createEnv(Terminal, 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.
- createFieldNamesField(ParseContext, List<IndexableField>) - 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.RangeFieldMapper.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
- 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>) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Creates a new
IndexService
for the given metadata. - createIndex(IndexMetaData, List<IndexEventListener>) - 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(TransportMessage, String, String, String, boolean) - 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.
- 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() - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- CreateIndexResponse(boolean, boolean, String) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- createInitialState(DiscoveryNode) - Method in class org.elasticsearch.discovery.single.SingleNodeDiscovery
- 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.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- createInternal(Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- createKeyword(String, Sort, int, boolean) - Static method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
-
Create a collapsing top docs collector on a
SortedDocValues
field. - 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, boolean, ObjectMapper.Nested, ObjectMapper.Dynamic, Boolean, Map<String, Mapper>, Settings) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- createMapper(String, String, boolean, ObjectMapper.Nested, ObjectMapper.Dynamic, Boolean, Map<String, Mapper>, Settings) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- 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
- createNormalizedWeight(Query, boolean) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- createNumeric(String, Sort, int, boolean) - Static method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
-
Create a collapsing top docs collector on a
NumericDocValues
field. - 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
- createPersistentTask(String, String, Params, ActionListener<PersistentTasksCustomMetaData.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Creates a new persistent task on master node
- createPipelineAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
- 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
- createReduceContext(boolean) - Method in class org.elasticsearch.search.SearchService
- createReduced(String, double[], TDigestState, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
- createReduced(String, double[], TDigestState, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
- createReduced(String, double[], DoubleHistogram, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
- createReduced(String, double[], DoubleHistogram, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
- createRequest(RestRequest) - Static method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- 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, RecoveryState, PeerRecoveryTargetService, PeerRecoveryTargetService.RecoveryListener, RepositoriesService, Consumer<IndexShard.ShardFailure>, Consumer<ShardId>, RetentionLeaseSyncer) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Creates a shard for the specified shard routing and starts recovery.
- createShard(ShardRouting, RecoveryState, PeerRecoveryTargetService, PeerRecoveryTargetService.RecoveryListener, RepositoriesService, Consumer<IndexShard.ShardFailure>, Consumer<ShardId>, RetentionLeaseSyncer) - 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
- 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
- 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
- createSubAggregators(Aggregator) - 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.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.ShardSearchTransportRequest
- 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
- createTopDocs(Sort, int, boolean) - Method in class org.elasticsearch.search.collapse.CollapseContext
- createTopDocsCollector(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- createTopLevelAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
- createUid(String) - Static method in class org.elasticsearch.index.mapper.Uid
- createUid(String, String) - Static method in class org.elasticsearch.index.mapper.Uid
- createUidAsBytes(String, String) - Static method in class org.elasticsearch.index.mapper.Uid
- createUidAsBytes(String, BytesRef) - Static method in class org.elasticsearch.index.mapper.Uid
- createUidAsBytes(BytesRef, BytesRef) - Static method in class org.elasticsearch.index.mapper.Uid
- createUidsForTypesAndId(Collection<String>, Object) - Static method in class org.elasticsearch.index.mapper.Uid
- createUidsForTypesAndIds(Collection<String>, Collection<?>) - Static method in class org.elasticsearch.index.mapper.Uid
- createUidTerm(String, String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Return a term that uniquely identifies the document, or
null
if the type is not allowed. - createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceRangeAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- createUnmapped(Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- createVerifyingOutput(String, StoreFileMetaData, IOContext) - Method in class org.elasticsearch.index.store.Store
-
The returned IndexOutput validates the files checksum.
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.MinDocQuery
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.SearchAfterSortedDocQuery
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- createWeight(IndexSearcher, boolean, float) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
- createWeight(IndexSearcher, boolean, float) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- createWeight(IndexSearcher, boolean, float) - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- createWeight(IndexSearcher, boolean, float) - Method in class org.elasticsearch.search.slice.DocValuesSliceQuery
- createWeight(IndexSearcher, boolean, float) - Method in class org.elasticsearch.search.slice.TermsSliceQuery
- createWeight(Query, boolean, float) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- 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
- 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
- cumulativeSum(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- CumulativeSumPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.cumulativesum
- CumulativeSumPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- CumulativeSumPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
-
Read from a stream.
- CumulativeSumPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.cumulativesum
- CumulativeSumPipelineAggregator(String, String[], DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
- CumulativeSumPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.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
- currentEngineReference - Variable in class org.elasticsearch.index.shard.IndexShard
- 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(String) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Returns a list of currently running snapshots from repository sorted by snapshot creation date
- currentSnapshots(String, List<String>) - 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
- currentTime() - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- currentTimeInNanos() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- currentTimeInNanos() - Method in class org.elasticsearch.cluster.service.MasterService
- 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
- CustomAnalyzer - Class in org.elasticsearch.index.analysis
- CustomAnalyzer(String, TokenizerFactory, CharFilterFactory[], TokenFilterFactory[]) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzer
- CustomAnalyzer(String, 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, Environment) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzerProvider
- CustomBinaryDocValuesField(String, byte[]) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- 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
- customHeaders - Variable in class org.elasticsearch.rest.RestResponse
- customMetaDataUpgraders - Variable in class org.elasticsearch.plugins.MetaDataUpgrader
- 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
- cutoffFrequency() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- 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
-
Sets the cutoff document frequency for high / low frequent terms.
- cutoffFrequency(float) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Set a cutoff value in [0..1] (or absolute number >=1) representing the maximum threshold of a terms document frequency to be considered a low frequency term.
- cutoffFrequency(float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Set a cutoff value in [0..1] (or absolute number >=1) representing the maximum threshold of a terms document frequency to be considered a low frequency term.
- cutoffFrequency(Float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Set a cutoff value in [0..1] (or absolute number >=1) representing the maximum threshold of a terms document frequency to be considered a low frequency term.
- cutoffScore - Variable in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker.Result
- 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.
- 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(Settings, NodeEnvironment, MetaStateService, LocalAllocateDangledIndices, ClusterService) - Constructor for class org.elasticsearch.gateway.DanglingIndicesState
- DATA - org.elasticsearch.cluster.node.DiscoveryNode.Role
- 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
- 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.RangeFieldMapper.RangeType
- DATE - org.elasticsearch.search.aggregations.support.ValueType
- 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_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_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
- 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 ip addresses. - 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.TypeParser - Class in org.elasticsearch.index.mapper
- 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
- DateHistogramAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.histogram
- DateHistogramAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, long, BucketOrder, boolean, long, Rounding, Rounding, ExtendedBounds, SearchContext, 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
-
Returns the date interval that is set on this source
- dateHistogramInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Get the current date interval that is set on this builder.
- dateHistogramInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- dateHistogramInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set the interval on this builder, and return the builder so that calls can be chained.
- 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).
- DATELINE - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- 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.
- 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<ValuesSource.Numeric>, RangeAggregator.Range[], boolean, InternalRange.Factory<?, ?>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregatorFactory
- Dates(SortedNumericDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
-
Standard constructor.
- 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, DateTimeZone) - 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
- dateTimeFormatter(DateFormatter) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- dateTimeFormatter(DateFormatter) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- 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
- days(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- deactivate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
Deactivate throttling, which switches the lock to be an always-acquirable NoOpLock
- 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
- 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
- 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.
- 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.
- decideUnassignedShardAllocation(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
-
Computes and returns the design for allocating a single unassigned shard.
- 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(ObjectParser<? extends ParsedAggregation, Void>) - Static method in class org.elasticsearch.search.aggregations.ParsedAggregation
- declareAnyFields(AbstractObjectParser<? extends ValuesSourceAggregationBuilder<ValuesSource, ?>, T>, boolean, boolean) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParserHelper
- declareBroadcastFields(ConstructingObjectParser<T, Void>) - Static method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
- declareBytesFields(AbstractObjectParser<? extends ValuesSourceAggregationBuilder<ValuesSource.Bytes, ?>, T>, boolean, boolean) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParserHelper
- declareCommon(AbstractObjectParser<? extends MultiValuesSourceAggregationBuilder<VS, ?>, 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.stats.extended.ParsedExtendedStats
- declareField(String, AbstractObjectParser<? extends MultiValuesSourceAggregationBuilder<VS, ?>, T>, boolean, boolean) - Static method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceParseHelper
- declareFields(ConstructingObjectParser<T, Void>) - Static method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- declareFields(ObjectParser<? extends BulkByScrollTask.StatusBuilder, Void>) - Static method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- declareGeoFields(AbstractObjectParser<? extends ValuesSourceAggregationBuilder<ValuesSource.GeoPoint, ?>, T>, boolean, boolean) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParserHelper
- declareInnerHitsParseFields(ObjectParser<Map<String, Object>, Void>) - Static method in class org.elasticsearch.search.SearchHit
- declareMultiBucketAggregationFields(ObjectParser<? extends ParsedMultiBucketAggregation, Void>, CheckedFunction<XContentParser, ParsedMultiBucketAggregation.ParsedBucket, IOException>, CheckedFunction<XContentParser, ParsedMultiBucketAggregation.ParsedBucket, IOException>) - Static method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- declareNumericFields(AbstractObjectParser<? extends ValuesSourceAggregationBuilder<ValuesSource.Numeric, ?>, T>, boolean, boolean, boolean) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParserHelper
- 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
- declarePercentilesFields(ObjectParser<? extends ParsedPercentiles, Void>) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.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
- declareSingleValueFields(ObjectParser<? extends ParsedSingleValueNumericMetricsAggregation, Void>, double) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- declareStandardFields(AbstractObjectParser<? extends QueryBuilder, ?>) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
- declareStatsFields(ObjectParser<? extends ParsedStats, Void>) - Static method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- decode(String) - Method in interface org.elasticsearch.common.path.PathTrie.Decoder
- decodeComponent(String) - Static method in class org.elasticsearch.rest.RestUtils
-
Decodes a bit of an URL encoded by a browser.
- decodeComponent(String, Charset) - 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.common.geo.GeoHashUtils
-
decode latitude value from morton encoded geo point
- decodeLatitude(long) - Static method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- decodeLatitude(String) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
returns the latitude value from the string based geohash
- decodeLongitude(long) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
decode longitude value from morton encoded geo point
- decodeLongitude(long) - Static method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- decodeLongitude(String) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
returns the latitude value from the string based geohash
- decodeQueryString(String, int, Map<String, String>) - Static method in class org.elasticsearch.rest.RestUtils
- decodeWeight(long) - Static method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
cost -> weight
- decorate(CompoundProcessor, List<SimulateProcessorResult>) - Static method in class org.elasticsearch.ingest.TrackingResultProcessor
- decRef() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
- decRef() - Method in interface org.elasticsearch.common.util.concurrent.RefCounted
-
Decreases the refCount of this instance.
- 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.
- 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
- 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_ALPHA - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- DEFAULT_ALPHA - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- DEFAULT_ALPHA - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- DEFAULT_ANALYZE_WILDCARD - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for wildcard analysis.
- 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_BETA - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- DEFAULT_BETA - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- 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
- 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
- DEFAULT_DISTANCE_UNIT - Static variable in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Default for distance unit computation.
- 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_SETTING_KEY - Static variable in class org.elasticsearch.index.IndexSettings
- DEFAULT_FLAGS - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for search flags to use.
- DEFAULT_FLAGS_VALUE - Static variable in class org.elasticsearch.index.query.RegexpQueryBuilder
- DEFAULT_FLOOR_SEGMENT - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_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_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_GAMMA - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- 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
- 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.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.GeoShapeQueryBuilder
-
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.search.SearchRequest
- DEFAULT_INNER_HIT_QUERY - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- 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_LIMIT_MAX_BUCKETS - Static variable in class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- DEFAULT_LOW_FREQ_OCCUR - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- 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_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.apache.lucene.search.suggest.analyzing.XFuzzySuggester
-
The default maximum number of edits for fuzzy suggestions.
- 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.GeoGridAggregationBuilder
- 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_FUZZY_LENGTH - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
-
The default minimum length of the key passed to
XAnalyzingSuggester.lookup(java.lang.CharSequence, java.util.Set<org.apache.lucene.util.BytesRef>, boolean, int)
before any edits are allowed. - 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_NON_FUZZY_PREFIX - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
-
The default prefix length where edits are not allowed.
- 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_PAD - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- DEFAULT_PERIOD - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- 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.GeoGridAggregationBuilder
- DEFAULT_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.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_RECOVER_AFTER_TIME_IF_EXPECTED_NODES_IS_SET - Static variable in class org.elasticsearch.gateway.GatewayService
- 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.AbstractAtomicOrdinalsFieldData
- 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_TIMEOUT_SETTING - Static variable in class org.elasticsearch.search.SearchService
- DEFAULT_SEASONALITY_TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- DEFAULT_SEGMENTS_PER_TIER - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_SHAPE_FIELD_NAME - Static variable in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- DEFAULT_SHAPE_INDEX_NAME - Static variable in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- DEFAULT_SHAPE_RELATION - Static variable in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- 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_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_TOKEN_LIMIT - Static variable in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
- DEFAULT_TRANSPOSITIONS - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
-
The default transposition value passed to
LevenshteinAutomata
- 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_UNICODE_AWARE - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
-
Measure maxEdits, minFuzzyLength, transpositions and nonFuzzyPrefix parameters in Unicode code points (actual letters) instead of bytes.
- 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_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
- defaultDocValues(Version) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- defaultDocValues(Version) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- 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
- defaultFieldType - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- defaultFieldType - Variable in class org.elasticsearch.index.mapper.FieldMapper
- defaultFormat() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- 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.
- defaultReuseAddress() - Static method in class org.elasticsearch.common.network.NetworkUtils
-
Returns system default for SO_REUSEADDR
- Defaults() - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest.Defaults
- Defaults() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.AllFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper.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.GeoPointFieldMapper.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.ParentFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.RootObjectMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.RoutingFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.SourceFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.TypeFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.UidFieldMapper.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(ElasticsearchException) - Constructor for class org.elasticsearch.action.support.DefaultShardOperationFailedException
- defaultStoreType(boolean) - Static method in class org.elasticsearch.index.IndexModule
- defaultValue - Variable in class org.elasticsearch.common.settings.Setting
- DeferableBucketAggregator - Class in org.elasticsearch.search.aggregations.bucket
- DeferableBucketAggregator(String, AggregatorFactories, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- DeferredTokenFilterRegistry(AnalysisRegistry, IndexSettings) - Constructor for class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction.DeferredTokenFilterRegistry
- 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
- definition - Variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest.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
- 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_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, TimeValue, 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
- DelegatingRoutingChangesObserver(RoutingChangesObserver...) - Constructor for class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- 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(BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
-
Deletes obj in the blob container
- delete(BlobPath) - Method in interface org.elasticsearch.common.blobstore.BlobStore
-
Delete the blob store at the given
BlobPath
. - delete(BlobPath) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- 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, VersionType) - 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
- deleteAny(String, String) - Static method in class org.elasticsearch.common.Strings
-
Delete any character in a given String.
- deleteBlob(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Deletes a blob with giving name, if the blob exists.
- deleteBlob(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- deleteBlobIgnoringIfNotExists(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Deletes a blob with giving name, ignoring if the blob does not exist.
- 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, Action<DeleteByQueryRequest, BulkByScrollResponse, DeleteByQueryRequestBuilder>) - Constructor for class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- 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
- DeleteFailedEngineException - Exception in org.elasticsearch.index.engine
-
Deprecated.
- DeleteFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.DeleteFailedEngineException
-
Deprecated.
- 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.
- 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.
- 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
- 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(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IngestService) - 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.
- 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, String) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
-
Constructs a new delete request against the specified index with the type and id.
- 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() - 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.Builder - Class in org.elasticsearch.action.delete
-
Builder class for
DeleteResponse
. - 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(String, String, ActionListener<Void>, boolean) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Deletes a snapshot from the repository, looking up the
Snapshot
reference before deleting. - deleteSnapshot(DeleteSnapshotRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete snapshot.
- deleteSnapshot(DeleteSnapshotRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete snapshot.
- deleteSnapshot(SnapshotId, long) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- deleteSnapshot(SnapshotId, long) - Method in class org.elasticsearch.repositories.FilterRepository
- deleteSnapshot(SnapshotId, long) - Method in interface org.elasticsearch.repositories.Repository
-
Deletes 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 a snapshot
- 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 name
- 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
- 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
- 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.index.mapper.Uid
- DELIMITER_BYTE - Static variable in class org.elasticsearch.index.mapper.Uid
- 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(String, Object...) - Method in class org.elasticsearch.common.logging.DeprecationLogger
-
Logs a deprecation message, adding a formatted warning message as a response header on the thread context.
- deprecated(String, Object...) - Method in class org.elasticsearch.common.xcontent.LoggingDeprecationHandler
- deprecated(String, String) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
-
Log a deprecation log, with the server's permissions and not the permissions of the script calling this method.
- Deprecated - org.elasticsearch.common.settings.Setting.Property
-
mark this setting as deprecated
- 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.
- DeprecatedParameters() - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- deprecationLogger - Variable in class org.elasticsearch.index.AbstractIndexComponent
- deprecationLogger - Static variable in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- deprecationLogger - Static variable in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- deprecationLogger - Static variable in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- deprecationLogger - Static variable in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- deprecationLogger - Static variable in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- deprecationLogger - Static variable in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
- deprecationLogger - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- 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.
- DeprecationMap - Class in org.elasticsearch.script
- DeprecationMap(Map<String, Object>, Map<String, String>) - Constructor for class org.elasticsearch.script.DeprecationMap
- 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.pipeline.PipelineAggregatorBuilders
- Derivative - Interface in org.elasticsearch.search.aggregations.pipeline.derivative
- DerivativePipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.derivative
- DerivativePipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- DerivativePipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
-
Read from a stream.
- DerivativePipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.derivative
- DerivativePipelineAggregator(String, String[], DocValueFormat, BucketHelpers.GapPolicy, Long, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
- DerivativePipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
-
Read from a stream.
- DESC - org.elasticsearch.search.sort.SortOrder
-
Descending order.
- descendsFromBucketAggregator(Aggregator) - Static method in class org.elasticsearch.search.aggregations.Aggregator
-
Returns whether one of the parents is a
BucketsAggregator
. - descendsFromGlobalAggregator(Aggregator) - Static method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- 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() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- 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
- detail() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- DetailAnalyzeResponse - Class in org.elasticsearch.action.admin.indices.analyze
- DetailAnalyzeResponse(boolean, DetailAnalyzeResponse.AnalyzeTokenList, DetailAnalyzeResponse.CharFilteredText[], DetailAnalyzeResponse.AnalyzeTokenList, DetailAnalyzeResponse.AnalyzeTokenList[]) - Constructor for class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- DetailAnalyzeResponse(DetailAnalyzeResponse.AnalyzeTokenList) - Constructor for class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- DetailAnalyzeResponse(DetailAnalyzeResponse.CharFilteredText[], DetailAnalyzeResponse.AnalyzeTokenList, DetailAnalyzeResponse.AnalyzeTokenList[]) - Constructor for class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- DetailAnalyzeResponse.AnalyzeTokenList - Class in org.elasticsearch.action.admin.indices.analyze
- DetailAnalyzeResponse.CharFilteredText - Class in org.elasticsearch.action.admin.indices.analyze
- 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 - Variable in class org.elasticsearch.rest.AbstractRestChannel
- 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(SearchContext, String) - Constructor for exception org.elasticsearch.search.dfs.DfsPhaseExecutionException
- DfsPhaseExecutionException(SearchContext, 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() - Constructor for class org.elasticsearch.search.dfs.DfsSearchResult
- DfsSearchResult(long, SearchShardTarget) - Constructor for class org.elasticsearch.search.dfs.DfsSearchResult
- DfsSearchResult(StreamInput) - Constructor for class org.elasticsearch.search.dfs.DfsSearchResult
- diff(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.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.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
- DirectoryService - Class in org.elasticsearch.index.store
- DirectoryService(ShardId, IndexSettings) - Constructor for class org.elasticsearch.index.store.DirectoryService
- DirectSpellcheckerSettings - Class in org.elasticsearch.search.suggest
- DirectSpellcheckerSettings() - Constructor for class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- 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.ConnectionManager
-
Disconnected from the given node, if not connected, will do nothing.
- disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
- disconnectFromNodesExcept(DiscoveryNodes) - Method in class org.elasticsearch.cluster.NodeConnectionsService
-
Disconnects from all nodes except the ones provided as parameter
- discovery() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- discovery(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node's discovery stats be returned.
- 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_HOSTS_PROVIDER_SETTING - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- 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_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
- DISCOVERY_ZEN_PING_UNICAST_CONCURRENT_CONNECTS_SETTING - Static variable in class org.elasticsearch.discovery.zen.UnicastZenPing
- DISCOVERY_ZEN_PING_UNICAST_HOSTS_RESOLVE_TIMEOUT - Static variable in class org.elasticsearch.discovery.zen.UnicastZenPing
- DISCOVERY_ZEN_PING_UNICAST_HOSTS_SETTING - Static variable in class org.elasticsearch.discovery.zen.SettingsBasedHostsProvider
- Discovery.AckListener - Interface in org.elasticsearch.discovery
- Discovery.FailedToCommitClusterStateException - Exception in org.elasticsearch.discovery
- 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) - 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<DiscoveryNode.Role>, Version) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
. - DiscoveryNode(String, String, TransportAddress, Map<String, String>, Set<DiscoveryNode.Role>, Version) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
- DiscoveryNode(String, TransportAddress, Map<String, String>, Set<DiscoveryNode.Role>, 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 - DiscoveryNode.Role - Enum in org.elasticsearch.cluster.node
-
Enum that holds all the possible roles that that a node can fulfill in a cluster.
- DiscoveryNodeFilters - Class in org.elasticsearch.cluster.node
- DiscoveryNodeFilters.OpType - Enum in org.elasticsearch.cluster.node
- 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
- DISJOINT - org.elasticsearch.common.geo.ShapeRelation
- DISJOINT - org.elasticsearch.index.mapper.MappedFieldType.Relation
- 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) - 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(RestRequest, RestChannel, ThreadContext, Throwable) - Method in interface org.elasticsearch.http.HttpServerTransport.Dispatcher
-
Dispatches a bad request.
- dispatchBadRequest(RestRequest, RestChannel, ThreadContext, Throwable) - Method in class org.elasticsearch.rest.RestController
- 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
- displayVersion(Version, boolean) - Static method in class org.elasticsearch.Version
- 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(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.
- 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
- 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(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- doBuild(SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- doBuild(SearchContext, 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) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(Map, 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.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.RestRecoveryAction
- 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
- docCount - Variable in class org.elasticsearch.index.engine.Segment
- 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
- 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.apache.lucene.search.XFilteredDocIdSetIterator
- 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.NodeConnectionsService
- doClose() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- doClose() - Method in class org.elasticsearch.cluster.routing.RoutingService
- 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.single.SingleNodeDiscovery
- doClose() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- doClose() - Method in class org.elasticsearch.gateway.GatewayService
- 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.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.search.aggregations.AggregatorBase
-
Release instance-specific data.
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
- 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.significant.GlobalOrdinalsSignificantTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregator
- 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
- doClose() - Method in class org.elasticsearch.watcher.ResourceWatcherService
- 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
- docMappers(boolean) - Method in class org.elasticsearch.index.mapper.MapperService
-
returns an immutable iterator over current document mappers.
- 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(Map<String, ValuesSourceConfig<ValuesSource.Numeric>>, DocValueFormat, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregatorFactory
- doCreateInternal(Map<String, ValuesSourceConfig<VS>>, DocValueFormat, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- doCreateInternal(ValuesSource.Bytes, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- doCreateInternal(ValuesSource.GeoPoint, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregatorFactory
- doCreateInternal(ValuesSource.GeoPoint, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceRangeAggregatorFactory
- doCreateInternal(ValuesSource.GeoPoint, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregatorFactory
- doCreateInternal(ValuesSource.Numeric, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregatorFactory
- doCreateInternal(ValuesSource, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- doCreateInternal(ValuesSource, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregatorFactory
- doCreateInternal(ValuesSource, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
- doCreateInternal(ValuesSource, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- doCreateInternal(ValuesSource, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregatorFactory
- doCreateInternal(ValuesSource, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregatorFactory
- doCreateInternal(VS, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- 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
- 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
- docStats() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the
DocsStats
for this engine - docStats() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- 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(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() - 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.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.RestRecoveryAction
- 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
- DocumentFieldMappers - Class in org.elasticsearch.index.mapper
- DocumentFieldMappers(Collection<FieldMapper>, Collection<FieldAliasMapper>, Analyzer, Analyzer, Analyzer) - Constructor for class org.elasticsearch.index.mapper.DocumentFieldMappers
- 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, IndexAnalyzers, 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_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.tophits.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.tophits.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.
- docValueFieldsContext() - Method in class org.elasticsearch.search.internal.SearchContext
- docValueFieldsContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- docValueFieldsContext(DocValueFieldsContext) - Method in class org.elasticsearch.search.internal.SearchContext
- docValueFieldsContext(DocValueFieldsContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- DocValueFieldsContext - Class in org.elasticsearch.search.fetch.subphase
-
All the required context to pull a field from the doc values.
- DocValueFieldsContext(List<DocValueFieldsContext.FieldAndFormat>) - Constructor for class org.elasticsearch.search.fetch.subphase.DocValueFieldsContext
- DocValueFieldsContext.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.
- DocValueFieldsFetchSubPhase - Class in org.elasticsearch.search.fetch.subphase
-
Query sub phase which pulls data from doc values Specifying
"docvalue_fields": ["field1", "field2"]
- DocValueFieldsFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.DocValueFieldsFetchSubPhase
- docValueFormat(String, DateTimeZone) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- docValueFormat(String, DateTimeZone) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- docValueFormat(String, DateTimeZone) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- docValueFormat(String, DateTimeZone) - 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, DateTimeZone) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- 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.RangeFieldMapper.Builder
- docValues(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- DocValuesIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
IndexFieldData
impl based on Lucene's doc values. - DocValuesIndexFieldData(Index, String) - Constructor for class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
- DocValuesIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- docValuesSet - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- 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() - Constructor for class org.elasticsearch.action.DocWriteResponse
- DocWriteResponse(ShardId, String, String, long, long, long, DocWriteResponse.Result) - 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(Object) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Opportunity for subclasses to add criteria to the
InternalAggregation.equals(Object)
method for this class. - doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- 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(BaseTermQueryBuilder) - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
- 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
- doEquals(ConstantScoreQueryBuilder) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doEquals(DisMaxQueryBuilder) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- 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(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(MatchAllQueryBuilder) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- 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(T) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Indicates whether some other
SuggestionBuilder
of the same type is "equal to" this one. - doExecute(NodesRequest, ActionListener<NodesResponse>) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- doExecute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.FilterClient
- doExecute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeClient
- doExecute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.OriginSettingClient
- doExecute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.ParentTaskAssigningClient
- doExecute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.support.AbstractClient
- doExecute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.TransportClient
- doExecute(GetTaskRequest, ActionListener<GetTaskResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.TransportGetTaskAction
- doExecute(RemoteInfoRequest, ActionListener<RemoteInfoResponse>) - Method in class org.elasticsearch.action.admin.cluster.remote.TransportRemoteInfoAction
- doExecute(SyncedFlushRequest, ActionListener<SyncedFlushResponse>) - Method in class org.elasticsearch.action.admin.indices.flush.TransportSyncedFlushAction
- doExecute(GetFieldMappingsRequest, ActionListener<GetFieldMappingsResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsAction
- doExecute(BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.TransportBulkAction
- doExecute(ExplainRequest, ActionListener<ExplainResponse>) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- doExecute(FieldCapabilitiesRequest, ActionListener<FieldCapabilitiesResponse>) - Method in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesAction
- doExecute(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in class org.elasticsearch.action.get.TransportMultiGetAction
- doExecute(SimulatePipelineRequest, ActionListener<SimulatePipelineResponse>) - Method in class org.elasticsearch.action.ingest.SimulatePipelineTransportAction
- doExecute(MainRequest, ActionListener<MainResponse>) - Method in class org.elasticsearch.action.main.TransportMainAction
- doExecute(ClearScrollRequest, ActionListener<ClearScrollResponse>) - Method in class org.elasticsearch.action.search.TransportClearScrollAction
- doExecute(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.action.search.TransportMultiSearchAction
- doExecute(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.TransportSearchAction
- doExecute(SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.TransportSearchScrollAction
- doExecute(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in class org.elasticsearch.action.termvectors.TransportMultiTermVectorsAction
- doExecute(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- doExecute(Task, NodesRequest, ActionListener<NodesResponse>) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- doExecute(Task, GetTaskRequest, ActionListener<GetTaskResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.TransportGetTaskAction
- doExecute(Task, CloseIndexRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- doExecute(Task, DeleteIndexRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- doExecute(Task, OpenIndexRequest, ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- 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, 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, 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.TransportAction
- doExecute(Task, TasksRequest, ActionListener<TasksResponse>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
- doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.TransportAction
- doExecute(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
- 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.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
- 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.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.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.MatchAllQueryBuilder
- 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.aggregations.AbstractAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- doHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- doHashCode() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Opportunity for subclasses to the
InternalAggregation.hashCode()
for this class. - doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- doHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- doHashCode() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- 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
- 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(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.AllFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Merge changes coming from
mergeWith
in place. - doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.IdFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.UidFieldMapper
- doMerge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- doMerge(ObjectMapper, boolean) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- doMerge(ObjectMapper, boolean) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- done() - Method in class org.elasticsearch.action.support.PlainListenableActionFuture
- done() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- done() - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
- 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.cardinality.CardinalityAggregator
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
- 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.movavg.models.EwmaModel
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.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.movavg.models.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.movavg.models.LinearModel
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Calls to the model-specific implementation which actually generates the predictions
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.InternalExtendedStatsBucket
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
- doReduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- doReduce(Aggregations, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
- doReduce(Aggregations, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- 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.RangeQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Rewrites this aggregation builder into its primitive form.
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- 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
- doStart() - Method in class org.elasticsearch.cluster.NodeConnectionsService
- doStart() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- doStart() - Method in class org.elasticsearch.cluster.routing.RoutingService
- 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.single.SingleNodeDiscovery
- 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.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.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() - Method in class org.elasticsearch.watcher.ResourceWatcherService
- doStart(Consumer<? super ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ClientScrollableHitSource
- doStart(Consumer<? super ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- doStartNextScroll(String, TimeValue, Consumer<? super ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ClientScrollableHitSource
- doStartNextScroll(String, TimeValue, Consumer<? super ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- doStop() - Method in class org.elasticsearch.cluster.NodeConnectionsService
- doStop() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- doStop() - Method in class org.elasticsearch.cluster.routing.RoutingService
- 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.single.SingleNodeDiscovery
- doStop() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- doStop() - Method in class org.elasticsearch.gateway.GatewayService
- 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.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.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
- doStop() - Method in class org.elasticsearch.watcher.ResourceWatcherService
- 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.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
- 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.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.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.GeoShapeQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doToQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- 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.RangeFieldMapper.RangeType
- DOUBLE - org.elasticsearch.search.aggregations.support.ValueType
- DoubleArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of double values.
- doubleField(FieldInfo, double) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- Doubles(SortedNumericDoubleValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- Doubles(SortedNumericDoubleValues, BiConsumer<String, String>) - 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, List<PipelineAggregator>, 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.
- DoubleTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
- doubleToBytes(double) - Static method in class org.elasticsearch.common.Numbers
-
Converts a double to a byte array.
- doubleValue() - Method in class org.elasticsearch.script.ScoreAccessor
- doubleValue() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
- 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
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- doValidate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
- 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
- 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.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.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.MatchAllQueryBuilder
- 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.InternalGeoHashGrid
- 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.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.significant.InternalSignificantTerms
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.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.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
- 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.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.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.GeoShapeQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- 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.BaseGeoShapeFieldMapper
- doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper
- 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.GeoPointFieldMapper
- 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.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.InternalGeoHashGrid
- 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.ParsedAutoDateHistogram
- 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.significant.InternalMappedSignificantTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- 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.ParsedTerms
- 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.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.avg.AvgAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.avg.ParsedAvg
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.ParsedCardinality
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.ParsedGeoBounds
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.ParsedGeoCentroid
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.mad.ParsedMedianAbsoluteDeviation
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.max.ParsedMax
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.min.ParsedMin
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentiles
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ParsedScriptedMetric
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.sum.ParsedSum
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.ParsedTopHits
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ParsedValueCount
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.ParsedWeightedAvg
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.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.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.ParsedBucketMetricValue
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.ParsedPercentilesBucket
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.ParsedDerivative
- 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.ParsedSimpleValue
- 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
- doXContentDocValues(XContentBuilder, boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper
- 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.RangeFieldMapper.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
- 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(Collection<DynamicTemplate>) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
E
- EAGER_SINGLETON - Static variable in class org.elasticsearch.common.inject.internal.Scoping
- eagerGlobalOrdinals() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- eagerGlobalOrdinals(boolean) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- eagerGlobalOrdinals(boolean) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper.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
- 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, 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>, Function<Version, TokenFilterFactory>) - 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. - 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.index.fielddata.plain.AbstractAtomicOrdinalsFieldData
- 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(int) - Static method in class org.elasticsearch.index.fielddata.plain.AbstractAtomicGeoPointFieldData
- empty(int) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- empty(int) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- Empty() - Constructor for class org.elasticsearch.transport.TransportRequest.Empty
- Empty() - Constructor for class org.elasticsearch.transport.TransportResponse.Empty
- EMPTY - org.elasticsearch.index.query.RegexpFlag
-
Enables empty language expression:
#
- EMPTY - Static variable in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- 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.metadata.MappingMetaData.Routing
- 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.seqno.RetentionLeases
-
Represents an empty an un-versioned retention lease collection.
- EMPTY - Static variable in interface org.elasticsearch.index.seqno.RetentionLeaseSyncer
- 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.RepositoryData
-
An instance initialized for an empty repository.
- EMPTY - Static variable in class org.elasticsearch.search.aggregations.AggregatorFactories
- EMPTY - Static variable in class org.elasticsearch.search.aggregations.InternalAggregations
- 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.search.suggest.phrase.NoisyChannelSpellChecker.Result
- 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_FIELDS - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.SourceSimpleFragmentsBuilder
- EMPTY_META_DATA - 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_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
- 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.movavg.models.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
- EmptyTransportResponseHandler - Class in org.elasticsearch.transport
- EmptyTransportResponseHandler(String) - Constructor for class org.elasticsearch.transport.EmptyTransportResponseHandler
- 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. - 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.AllFieldMapper
- enabled() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- enabled(boolean) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Builder
- enabled(boolean) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- enabled(boolean) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- enabled(EnabledAttributeMapper) - Method in class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- ENABLED - org.elasticsearch.index.mapper.EnabledAttributeMapper
- ENABLED - Static variable in class org.elasticsearch.Assertions
- ENABLED - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper.Defaults
- 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_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. - 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.common.geo.GeoHashUtils
-
31 bit encoding utils *
- encodeLatLon(double, double) - Static method in class org.elasticsearch.search.aggregations.metrics.geocentroid.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.RangeFieldMapper.RangeType
- Encoders() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils.Encoders
- encodeWeight(long) - Static method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
weight -> cost
- end() - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- end() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- END_BYTE - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Marks end of the analyzed input and start of dedup byte.
- 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.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 searcher 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.
- EngineSearcherFactory - Class in org.elasticsearch.index.engine
-
Basic Searcher factory that allows returning an
IndexSearcher
given anIndexReader
- EngineSearcherFactory(EngineConfig) - Constructor for class org.elasticsearch.index.engine.EngineSearcherFactory
- 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.
- ensureAtomicMoveSupported() - Method in class org.elasticsearch.env.NodeEnvironment
-
This method tries to write an empty file and moves it using an atomic move operation.
- 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. - ensureClusterStateVersion(long) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- ensureClusterStateVersion(long) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Blockingly waits for cluster state with at least clusterStateVersion to be available
- ensureClusterStateVersion(long) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- 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 - ensureIndexHas6xCommitTags() - Method in class org.elasticsearch.index.store.Store
-
A 5.x index does not have either historyUUDID or sequence number markers as these markers are introduced in 6.0+.
- 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) - Static method in class org.elasticsearch.common.util.CollectionUtils
- 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() - Method in class org.elasticsearch.transport.TcpTransport
-
Ensures this transport is still started / open
- 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.suggest.Suggest.Suggestion
- entries() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- entries() - Method in class org.elasticsearch.common.lucene.all.AllEntries
- 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, String, float) - Constructor for class org.elasticsearch.common.lucene.all.AllEntries.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(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(Text, int, int) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.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>) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(Snapshot, boolean, boolean, SnapshotsInProgress.State, List<IndexId>, long, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, String) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(Snapshot, long, long) - Constructor for class org.elasticsearch.cluster.SnapshotDeletionsInProgress.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.DeprecationMap
- 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 - Variable in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- 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
- 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
- EpochTimePrinter(boolean) - Constructor for class org.elasticsearch.common.joda.Joda.EpochTimePrinter
- equals(long, HyperLogLogPlusPlus) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.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.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.ClusterStatsNodes.JvmVersion
- 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.AnalyzeResponse.AnalyzeToken
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- 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.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.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.GenericAction
- 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.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.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.ClusterName
- 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.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.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.node.DiscoveryNode
- 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.BytesReference
- 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.GeoPoint
- 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.lucene.all.AllTermQuery
- 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.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.Rounding
- 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.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.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.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- equals(Object) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- equals(Object) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- equals(Object) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- equals(Object) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- equals(Object) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- equals(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- equals(Object) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- equals(Object) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- equals(Object) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- 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.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.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.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.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.RepositoryData
- 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.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.AdjacencyMatrixAggregator.KeyedFilter
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- 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.InternalBucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- 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.significant.heuristics.ChiSquare
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.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.StringTerms.Bucket
- 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.CompoundOrder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.InternalOrder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.Percentile
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- 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.DocValueFieldsContext.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.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.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.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.SmoothingModel
- 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.SuggestBuilder
- equals(Object) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- 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.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.RemoteConnectionInfo
- 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
- 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
- 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
- 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
- ESSolrSynonymParser - Class in org.elasticsearch.index.analysis
- ESSolrSynonymParser(boolean, boolean, boolean, Analyzer) - Constructor for class org.elasticsearch.index.analysis.ESSolrSynonymParser
- 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
- 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
- estimatedTimeInMillisCounter() - Method in class org.elasticsearch.threadpool.ThreadPool
- estimateNumberOfHistoryOperations(String, 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, 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, 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, MapperService, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- estimateParsedLength() - Method in class org.elasticsearch.common.joda.Joda.EpochTimeParser
- estimatePrintedLength() - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
- 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
- ESWordnetSynonymParser - Class in org.elasticsearch.index.analysis
- ESWordnetSynonymParser(boolean, boolean, boolean, Analyzer) - Constructor for class org.elasticsearch.index.analysis.ESWordnetSynonymParser
- 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
- 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.movfn.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.movavg.models
-
Calculate a exponentially weighted moving average
- EwmaModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- EwmaModel(double) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- EwmaModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
-
Read from a stream.
- EwmaModel.EWMAModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
- EWMAModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel.EWMAModelBuilder
- EXACT_FIRST - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Include this flag in the options parameter to
#XAnalyzingSuggester(Analyzer,Analyzer,int,int,int,boolean,FST,boolean,int,int,int,int,int)
to always return the exact match first, regardless of score. - 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. - 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() - Method in class org.elasticsearch.action.ActionRequestBuilder
- execute() - Method in class org.elasticsearch.action.support.replication.ReplicationOperation
- execute() - Method in class org.elasticsearch.script.BucketAggregationScript
- execute() - Method in class org.elasticsearch.script.BucketAggregationSelectorScript
- 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.ScoreScript
- 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.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.movfn.MovingFunctionScript
- execute(Action<Request, Response, RequestBuilder>, Request) - Method in interface org.elasticsearch.client.ElasticsearchClient
-
Executes a generic action, denoted by an
Action
. - execute(Action<Request, Response, RequestBuilder>, Request) - Method in class org.elasticsearch.client.support.AbstractClient
- execute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in interface org.elasticsearch.client.ElasticsearchClient
-
Executes a generic action, denoted by an
Action
. - execute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.support.AbstractClient
-
This is the single execution point of *all* clients.
- execute(ActionListener<Response>) - Method in class org.elasticsearch.action.ActionRequestBuilder
- 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.common.settings.UpgradeKeyStoreCommand
- execute(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- execute(Terminal, ShardPath, Directory) - Method in class org.elasticsearch.index.translog.TruncateTranslogAction
- execute(Terminal, ShardPath, Directory, Lock, PrintStream, boolean) - Method in class org.elasticsearch.index.shard.RemoveCorruptedLuceneSegmentsAction
- 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<LocalClusterUpdateTask>) - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- execute(ClusterState, List<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.NodeJoinController.JoinTaskExecutor
- execute(ClusterState, List<ZenDiscovery.NodeRemovalClusterStateTaskExecutor.Task>) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.NodeRemovalClusterStateTaskExecutor
- 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(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.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) - 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(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) - Method in class org.elasticsearch.action.support.TransportAction
- 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(Iterable<DocWriteRequest<?>>, BiConsumer<IndexRequest, Exception>, Consumer<Exception>, Consumer<IndexRequest>) - Method in class org.elasticsearch.ingest.IngestService
- executeDfsPhase(ShardSearchRequest, SearchTask, ActionListener<SearchPhaseResult>) - Method in class org.elasticsearch.search.SearchService
- executeFetchPhase(ShardFetchRequest, SearchTask, ActionListener<FetchSearchResult>) - Method in class org.elasticsearch.search.SearchService
- executeFetchPhase(InternalScrollSearchRequest, SearchTask, 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(GenericAction<Request, Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeClient
- executeLocally(GenericAction<Request, 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) - 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, SearchTask, ActionListener<ScrollQuerySearchResult>) - Method in class org.elasticsearch.search.SearchService
- executeQueryPhase(ShardSearchRequest, SearchTask, ActionListener<SearchPhaseResult>) - Method in class org.elasticsearch.search.SearchService
- executeQueryPhase(QuerySearchRequest, SearchTask, 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. - executeTask(Params, PersistentTaskState, AllocatedPersistentTask, PersistentTasksExecutor<Params>) - Method in class org.elasticsearch.persistent.NodePersistentTasksExecutor
- executeTasks(MasterService.TaskInputs, long, ClusterState) - Method in class org.elasticsearch.cluster.service.MasterService
- 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.significant.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.significant.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 - Variable in class org.elasticsearch.cluster.service.MasterService.TaskInputs
- 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.health.TransportClusterHealthAction
- 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.TransportCreateIndexAction
- 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.get.TransportGetIndexAction
- executor() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
- 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.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.TransportDeleteIndexTemplateAction
- executor() - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- 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 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 class org.elasticsearch.transport.TransportChannelResponseHandler
- 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_STORE - org.elasticsearch.cluster.routing.RecoverySource.Type
- 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(BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
-
Checks obj in the blob container
- 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.
- 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.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- 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.GeoPointFieldMapper.GeoPointFieldType
- 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
- 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 - Variable in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- 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
- 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.AnalyzeRequest
- 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.tophits.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.AnalyzeRequest
- 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.tophits.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.ExplainableSearchScript
-
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(Query, int) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- 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
- ExplainableSearchScript - Interface in org.elasticsearch.script
-
To be implemented by
SearchScript
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.
- ExplainFetchSubPhase - Class in org.elasticsearch.search.fetch.subphase
-
Explains the scoring calculations for the top hits.
- ExplainFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.ExplainFetchSubPhase
- 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
- 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, String) - Constructor for class org.elasticsearch.action.explain.ExplainRequest
- 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
- explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.LeafScoreFunction
- explainShard(ShardRouting, RoutingAllocation, ClusterInfo, boolean, GatewayAllocator, ShardsAllocator) - Static method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- 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
- 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
- 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
-
Extended version of
CommonTermsQuery
that allows to pass in aminimumNumberShouldMatch
specification that uses the actual num of high frequent terms to calculate the minimum matching terms. - ExtendedCommonTermsQuery(BooleanClause.Occur, BooleanClause.Occur, float) - Constructor for class org.apache.lucene.queries.ExtendedCommonTermsQuery
- 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.stats.extended
-
Statistics over a set of values (either aggregated over field data or scripts)
- ExtendedStats.Bounds - Enum in org.elasticsearch.search.aggregations.metrics.stats.extended
- ExtendedStatsAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
- ExtendedStatsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- ExtendedStatsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
-
Read from a stream.
- ExtendedStatsAggregationBuilder(ExtendedStatsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- ExtendedStatsAggregator - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
- ExtendedStatsAggregator(String, ValuesSource.Numeric, DocValueFormat, SearchContext, Aggregator, double, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- ExtendedStatsAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
- ExtendedStatsAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, double, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregatorFactory
- extendedStatsBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- ExtendedStatsBucket - Interface in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended
-
Extended Statistics over a set of buckets
- ExtendedStatsBucketParser - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended
- ExtendedStatsBucketParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketParser
- ExtendedStatsBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended
- ExtendedStatsBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- ExtendedStatsBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
-
Read from a stream.
- ExtendedStatsBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended
- ExtendedStatsBucketPipelineAggregator(String, String[], double, BucketHelpers.GapPolicy, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
- ExtendedStatsBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
-
Read from a stream.
- ExtensiblePlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to be themselves extensible. - 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
- 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.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
- extractTerms(IndexSearcher, RescoreContext, Set<Term>) - Method in class org.elasticsearch.search.rescore.QueryRescorer
- extractTerms(IndexSearcher, RescoreContext, Set<Term>) - Method in interface org.elasticsearch.search.rescore.Rescorer
-
Extracts all terms needed to execute this
Rescorer
. - extractValue(String) - Method in class org.elasticsearch.search.lookup.SourceLookup
- extractValue(String, Map<?, ?>) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- extractWarningValueFromWarningHeader(String) - 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.State
- failed() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- failed() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
- 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
- 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(String, Object...) - Constructor for exception org.elasticsearch.discovery.Discovery.FailedToCommitClusterStateException
- FailedToCommitClusterStateException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.discovery.Discovery.FailedToCommitClusterStateException
- FailedToCommitClusterStateException(StreamInput) - Constructor for exception org.elasticsearch.discovery.Discovery.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, 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, 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, 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) - 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(String, String, String, Exception, RestStatus, long, boolean) - 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(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.action.bulk.TransportShardBulkAction.ReplicaItemExecutionMode
-
When primary execution failed after sequence no was generated
- 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.
- failureDescription() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
- 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() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
- failures(Iterable<T>, Exception) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- FAILURES_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- FALSE - org.elasticsearch.index.mapper.ObjectMapper.Dynamic
- FALSE - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper.Values
- 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
- 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(SearchContext, String) - Constructor for exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
- FetchPhaseExecutionException(SearchContext, 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
- FetchSearchResult - Class in org.elasticsearch.search.fetch
- FetchSearchResult() - Constructor for class org.elasticsearch.search.fetch.FetchSearchResult
- FetchSearchResult(long, SearchShardTarget) - Constructor for class org.elasticsearch.search.fetch.FetchSearchResult
- FetchSearchResult(StreamInput) - 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.tophits.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.tophits.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.tophits.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.tophits.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.tophits.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
- FetchSourceSubPhase - Class in org.elasticsearch.search.fetch.subphase
- FetchSourceSubPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.FetchSourceSubPhase
- 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
- 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.DocValueFieldsContext.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.AnalyzeRequest
- 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.AnalyzeRequest
- 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.AllFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.BinaryFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.IndexFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.ParentFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SeqNoDefaults
- 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.UidFieldMapper.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.DocValueFieldsContext.FieldAndFormat
-
Sole constructor.
- FieldAndFormat(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.DocValueFieldsContext.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) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Constructor
- FieldCapabilities(String, String, boolean, boolean, String[], String[], String[]) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Constructor
- FieldCapabilities(StreamInput) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilities
- FieldCapabilitiesAction - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesIndexRequest - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesIndexResponse - Class in org.elasticsearch.action.fieldcaps
-
Response for
FieldCapabilitiesIndexRequest
requests. - FieldCapabilitiesRequest - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesRequest() - 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. - 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(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 - Static variable in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction.Fields
- 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.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.TextFieldMapper.TextFieldType
- 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.tophits.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
- 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, MappedFieldType, MappedFieldType, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.FieldMapper
- FieldMapper.Builder<T extends FieldMapper.Builder,Y extends FieldMapper> - 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.plain.DocValuesIndexFieldData
- 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.BaseTermQueryBuilder
-
Returns the field name used in this query.
- fieldName() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- 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.GeoShapeQueryBuilder
- 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.significant.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.aggregations.support.MultiValuesSource
- 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.Builder - Class in org.elasticsearch.index.mapper
- 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
- FieldNamesFieldType(FieldNamesFieldMapper.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.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.fetchSource()
instead - 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.aggregations.support.MultiValuesSourceAggregationBuilder
- fields() - Method in class org.elasticsearch.search.fetch.subphase.DocValueFieldsContext
-
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.action.search.SearchRequestBuilder
-
Deprecated.Use
SearchRequestBuilder.storedFields(String...)
instead. - fields(String...) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.fetchSource(String[], String[])
instead - 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(Map<String, DocumentField>) - Method in class org.elasticsearch.search.SearchHit
- 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.rest.action.admin.indices.RestClearIndicesCacheAction.Fields
- Fields() - Constructor for class org.elasticsearch.search.SearchHit.Fields
- Fields() - Constructor for class org.elasticsearch.search.SearchHits.Fields
- FIELDS - Static variable in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction.Fields
- FIELDS_FIELD - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- 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
- FieldsLookup - Class in org.elasticsearch.search.lookup
- fieldsOrNull() - Method in class org.elasticsearch.search.SearchHit
- 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.search.fetch.subphase.highlight.HighlighterContext
- fieldType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.SimpleFragmentsBuilder
- 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.Builder
- fieldType() - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- 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.GeoShapeFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- fieldType() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.Builder
-
Deprecated.
- 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.Builder
- fieldType() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- 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.lookup.FieldLookup
- 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() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.File
- 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_CHUNK - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- FileBasedUnicastHostsProvider - Class in org.elasticsearch.discovery.zen
-
An implementation of
UnicastHostsProvider
that reads hosts/ports fromFileBasedUnicastHostsProvider.UNICAST_HOSTS_FILE
. - FileBasedUnicastHostsProvider(Path) - Constructor for class org.elasticsearch.discovery.zen.FileBasedUnicastHostsProvider
- 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
- fileInputStream(BlobStoreIndexShardSnapshot.FileInfo) - Method in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- 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, IndexShard, SnapshotId, RecoveryState, int) - 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
- filesInDirectory(Path) - Static method in class org.elasticsearch.index.translog.TruncateTranslogAction
-
Return a Set of all files in a given directory
- 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.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
- 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(CompressedXContent) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- filter(Settings) - Method in class org.elasticsearch.common.settings.SettingsFilter
- filter(XContentBuilder) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- 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_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, List<PipelineAggregator>, 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, SearchContext, 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
- 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.significant.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
-
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, List<PipelineAggregator>, 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, SearchContext, 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.
- 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, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- finalizeRecovery(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, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- finalizeSnapshot(SnapshotId, List<IndexId>, long, String, int, List<SnapshotShardFailure>, long, boolean) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Finalizes snapshotting process
- finalizeSnapshot(SnapshotId, List<IndexId>, long, String, int, List<SnapshotShardFailure>, long, boolean) - Method in class org.elasticsearch.repositories.FilterRepository
- finalizeSnapshot(SnapshotId, List<IndexId>, long, String, int, List<SnapshotShardFailure>, long, boolean) - 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(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(String[], 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 or match partially 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, 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
- findDeadlocks() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer
- 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
- findLeafMaxValue(LeafReader, String, Function<byte[], Number>) - Static method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
-
Returns the maximum value indexed in the
fieldName
field ornull
if the value cannot be inferred from the indexedPointValues
. - findLeafMinValue(LeafReader, String, Function<byte[], Number>) - Static method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
-
Returns the minimum value indexed in the
fieldName
field ornull
if the value cannot be inferred from the indexedPointValues
. - 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. - 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.
- 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
- findTemplates(MetaData, String) - Static method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService
-
Finds index templates whose index pattern matched with the given index name.
- FINISH_ELECTION_TASK - Static variable in class org.elasticsearch.discovery.zen.NodeJoinController
-
a task that is used to signal the election is stopped and we should process pending joins.
- finishConstruction() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- 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.
- finishTerm(long) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
- finishVerification(ActionListener<RepositoriesService.VerifyResponse>, List<DiscoveryNode>, CopyOnWriteArrayList<VerificationFailure>) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
- first() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- FIRST - org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- FIXED - org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- FIXED_16 - org.apache.lucene.queries.BinaryDocValuesRangeQuery.LengthType
- FIXED_4 - org.apache.lucene.queries.BinaryDocValuesRangeQuery.LengthType
- FIXED_8 - org.apache.lucene.queries.BinaryDocValuesRangeQuery.LengthType
- FIXED_AUTO_QUEUE_SIZE - org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- 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.
- fixNegativeQueryIfNeeded(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
- 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.index.query.RegexpQueryBuilder
- flags(int) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- 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
. - 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.RangeFieldMapper.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
- 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
- floatToBytes(float) - Static method in class org.elasticsearch.common.Numbers
-
Converts a float to a byte array.
- floatValue() - Method in class org.elasticsearch.script.ScoreAccessor
- floatValue() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.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.
- flushAndCloseEngine() - Method in class org.elasticsearch.index.shard.IndexShard
- 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.
- 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
- fmix(long) - Static method in enum org.elasticsearch.common.hash.MurmurHash3
- FOLDER_FOUND_CAN_DELETE - org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
- 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 - org.elasticsearch.index.VersionType
-
Deprecated.this will be removed in 7.0 and should not be used! It is *ONLY* for backward compatibility with 5.0 indices
- FORCE_LOCAL_SETTING - Static variable in class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- FORCE_MERGE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- 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) - Method in class org.elasticsearch.index.engine.Engine
-
Force merges to 1 segment
- forceMerge(boolean, int, boolean, boolean, boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Triggers a forced merge on this engine
- forceMerge(boolean, int, boolean, boolean, boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- forceMerge(boolean, int, boolean, boolean, boolean) - 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() - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- ForceMergeRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Constructs a merge request over one or more indices.
- 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.
- 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.
- 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
. - forEach(T) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- forEach(T) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- forFields(Collection<DateTimeFieldType>, boolean, boolean) - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that outputs only those fields specified.
- forInjectionPoints(Set<InjectionPoint>) - Static method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns the dependencies from the given injection points.
- 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
. - format - Variable in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- 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.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.significant.InternalMappedSignificantTerms
- format - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- 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.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- format - Variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
- format - Variable in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- format - Variable in class org.elasticsearch.search.fetch.subphase.DocValueFieldsContext.FieldAndFormat
-
The format of the field, or
null
if defaults should be used. - format - Variable in class org.elasticsearch.search.sort.SortFieldAndFormat
- format() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the format field to parse the from/to fields
- format() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the format to use for the output of the aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Gets the format to use for the output of the 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.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.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.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(InetSocketAddress) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address and port for display purposes.
- 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.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.aggregations.support.ValuesSourceConfig
- 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.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.bucketmetrics.BucketMetricsParser
- FORMAT - Static variable in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
- FORMAT_2_X - Static variable in class org.elasticsearch.index.translog.Translog.Index
- FORMAT_5_0 - Static variable in class org.elasticsearch.index.translog.Translog.Delete
- FORMAT_AUTO_GENERATED_IDS - Static variable in class org.elasticsearch.index.translog.Translog.Index
- FORMAT_PARAMS - Static variable in class org.elasticsearch.common.settings.Settings
- FORMAT_SEQ_NO - Static variable in class org.elasticsearch.index.translog.Translog.Index
- 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.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.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
- 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.
- forPattern(String) - Static method in class org.elasticsearch.common.joda.Joda
-
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
- forPattern(String) - Static method in class org.elasticsearch.common.time.DateFormatters
- 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. - forType(Class<?>) - Static method in class org.elasticsearch.common.inject.internal.StackTraceElements
- forwardIngestRequest(Action<?, ?, ?>, 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(long) - 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.significant.heuristics.NXYSignificanceHeuristic.Frequencies
- frequency - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- frequency() - Method in class org.elasticsearch.watcher.WatcherHandle
- frequency(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- frequency(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- frequency(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
- 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.tophits.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(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.tophits.TopHitsAggregationBuilder
-
From index to start the search from.
- from(int) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.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(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 - 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
- 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
- fromList(List<String>) - Static method in class org.elasticsearch.search.fetch.StoredFieldsContext
- 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
- fromMorton(long, int) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Convert from a morton encoded long from a geohash encoded long
- 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, 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, 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
- fromSettingsKey(String) - Static method in enum org.elasticsearch.index.IndexModule.Type
- fromStream(StreamInput) - Static method in enum org.elasticsearch.search.aggregations.support.ValuesSourceType
- 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.sampler.SamplerAggregator.ExecutionMode
- fromString(String) - Static method in enum org.elasticsearch.search.aggregations.support.ValuesSourceType
- 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.significant.SignificantTermsAggregatorFactory.ExecutionMode
- fromString(String, DeprecationLogger) - Static method in enum org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.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.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.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.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.analyze.AnalyzeResponse.AnalyzeToken
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- 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.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.IndexGraveyard
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- 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.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) - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand.Parser
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Reads
AllocationCommands
from aXContentParser
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.AllocationId
- fromXContent(XContentParser) - Static method in class org.elasticsearch.common.document.DocumentField
- fromXContent(XContentParser) - Static method in class org.elasticsearch.common.settings.Settings
-
Parsers the generated xcontent from
Settings.toXContent(XContentBuilder, Params)
into a new Settings object. - fromXContent(XContentParser) - Static method in exception org.elasticsearch.ElasticsearchException
-
Generate a
ElasticsearchException
from aXContentParser
. - fromXContent(XContentParser) - Method in class org.elasticsearch.gateway.MetaDataStateFormat
-
Reads a new instance of the state from the given XContentParser Subclasses need to implement this class for theirs specific state.
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.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
- 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.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.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.MatchAllQueryBuilder
- 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.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.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.aggregations.bucket.range.RangeAggregator.Range
- 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.DocValueFieldsContext.FieldAndFormat
-
Parse a
DocValueFieldsContext.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.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.Entry
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- 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.SnapshotId
- 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.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.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.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.significant.ParsedSignificantLongTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantStringTerms
- 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.ParsedStringTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.avg.ParsedAvg
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.ParsedCardinality
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.geobounds.ParsedGeoBounds
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.geocentroid.ParsedGeoCentroid
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.mad.ParsedMedianAbsoluteDeviation
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.max.ParsedMax
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.min.ParsedMin
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentileRanks
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentiles
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentileRanks
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentiles
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.scripted.ParsedScriptedMetric
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.sum.ParsedSum
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.tophits.ParsedTopHits
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.valuecount.ParsedValueCount
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.ParsedWeightedAvg
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.ParsedBucketMetricValue
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.ParsedPercentilesBucket
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ParsedExtendedStatsBucket
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.ParsedStatsBucket
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.derivative.ParsedDerivative
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.ParsedSimpleValue
- 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() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node file system stats be returned.
- fs(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node file system stats be returned.
- 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(Settings, Path, boolean) - Constructor for class org.elasticsearch.common.blobstore.fs.FsBlobStore
- FsDirectoryService - Class in org.elasticsearch.index.store
- FsDirectoryService(IndexSettings, ShardPath) - Constructor for class org.elasticsearch.index.store.FsDirectoryService
- 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) - 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
- fullName() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
- fullName(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Returns the
MappedFieldType
for the give fullName. - 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.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.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 - 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) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- fuzzyQuery(Object, Fuzziness, int, int, boolean) - 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.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.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.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.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.movavg.models.HoltWintersModel.HoltWintersModelBuilder
- GAP_POLICY - Static variable in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
- gapPolicy - Variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
-
Gets the gap policy to use for this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
-
Gets the gap policy to use for this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
-
Gets the gap policy to use for this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Gets the GapPolicy to use on the output of this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
-
Gets the gap policy to use for this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
-
Gets the GapPolicy to use on the output of this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
-
Sets the gap policy to use for this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
-
Sets the gap policy to use for this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
-
Sets the gap policy to use for this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Sets the GapPolicy to use on the output of this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
-
Sets the gap policy to use for this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.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, IndicesService) - 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(ClusterService, RoutingService, TransportNodesListGatewayStartedShards, TransportNodesListShardStoreMetaData) - Constructor for class org.elasticsearch.gateway.GatewayAllocator
- GatewayException - Exception in org.elasticsearch.gateway
- GatewayException(String) - Constructor for exception org.elasticsearch.gateway.GatewayException
- GatewayException(String, Throwable) - Constructor for exception org.elasticsearch.gateway.GatewayException
- GatewayException(StreamInput) - Constructor for exception org.elasticsearch.gateway.GatewayException
- GatewayMetaState - Class in org.elasticsearch.gateway
- GatewayMetaState(Settings, NodeEnvironment, MetaStateService, MetaDataIndexUpgradeService, MetaDataUpgrader) - Constructor for class org.elasticsearch.gateway.GatewayMetaState
- GatewayMetaState.IndexMetaWriteInfo - Class in org.elasticsearch.gateway
- 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, GatewayMetaState, TransportNodesListGatewayMetaState, IndicesService) - 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.
- 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
- generic() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Get the generic
ExecutorService
. - GENERIC - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- GenericAction<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action
-
A generic action.
- GenericAction(String) - Constructor for class org.elasticsearch.action.GenericAction
- GenericArrayTypeImpl(Type) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- 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
- 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.geobounds
-
An aggregation that computes a bounding box in which all documents of the current bucket are.
- GeoBoundsAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.geobounds
- GeoBoundsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- GeoBoundsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
-
Read from a stream.
- GeoBoundsAggregationBuilder(GeoBoundsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- GeoBoundsAggregator - Class in org.elasticsearch.search.aggregations.metrics.geobounds
- GeoBoundsAggregator(String, SearchContext, Aggregator, ValuesSource.GeoPoint, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
- GeoBoundsAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.geobounds
- GeoBoundsAggregatorFactory(String, ValuesSourceConfig<ValuesSource.GeoPoint>, boolean, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregatorFactory
- 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.geocentroid
-
Interface for
GeoCentroidAggregator
- GeoCentroidAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.geocentroid
- GeoCentroidAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- GeoCentroidAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
-
Read from a stream.
- GeoCentroidAggregationBuilder(GeoCentroidAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.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, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- geoDisjointQuery(String, ShapeBuilder) - 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
- 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<ValuesSource.GeoPoint>, GeoPoint, GeoDistanceAggregationBuilder.Range[], DistanceUnit, GeoDistance, boolean, SearchContext, 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.
- 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
- 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
- geohashes(String...) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.
- geohashGrid(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
GeoHashGrid
aggregation with the given name. - GeoHashGrid - Interface in org.elasticsearch.search.aggregations.bucket.geogrid
-
A
geohash_grid
aggregation. - GeoHashGrid.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.geogrid
-
A bucket that is associated with a
geohash_grid
cell. - 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.
- 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.
- GeoHashUtils - Class in org.elasticsearch.common.geo
-
Utilities for converting to/from the GeoHash standard The geohash long format is represented as lon/lat (x/y) interleaved with the 4 least significant bits representing the level (1-12) [xyxy...xyxyllll] This differs from a morton encoded value which interleaves lat/lon (y/x).*
- geoIntersectionQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- geoIntersectionQuery(String, ShapeBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter indexed shapes intersecting with shapes
- 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.
- 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.ValuesSourceType
- GEOPOINT - org.elasticsearch.search.aggregations.support.ValueType
- GeoPointFieldMapper - Class in org.elasticsearch.index.mapper
-
Field Mapper for geo_point types.
- GeoPointFieldMapper(String, MappedFieldType, MappedFieldType, Settings, FieldMapper.MultiFields, Explicit<Boolean>, Explicit<Boolean>, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper
- GeoPointFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.GeoPointFieldType - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.Names - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- GeoPointFieldType() - 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
- GeoPointValuesSource(Map<String, ValuesSourceConfig<ValuesSource.GeoPoint>>, QueryShardContext) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSource.GeoPointValuesSource
- 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, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Explicit<Boolean>, Settings, 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
- GeoShapeFieldType() - Constructor for class org.elasticsearch.index.mapper.GeoShapeFieldMapper.GeoShapeFieldType
- GeoShapeFieldType() - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- GeoShapeFieldType(GeoShapeFieldMapper.GeoShapeFieldType) - Constructor for class org.elasticsearch.index.mapper.GeoShapeFieldMapper.GeoShapeFieldType
- GeoShapeFieldType(LegacyGeoShapeFieldMapper.GeoShapeFieldType) - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- geoShapeQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- geoShapeQuery(String, ShapeBuilder) - 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
-
QueryBuilder
that builds a GeoShape Query - GeoShapeQueryBuilder(String, 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 in the given type
- GeoShapeQueryBuilder(String, ShapeBuilder) - 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
-
Read from a stream.
- GeoShapeType - Enum in org.elasticsearch.common.geo
-
Enumeration that lists all
GeoShapeType
s that can be parsed and indexed - GeoUtils - Class in org.elasticsearch.common.geo
- 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, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- geoWithinQuery(String, ShapeBuilder) - 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.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.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.engine.RecoveryCounter
- get() - Method in class org.elasticsearch.index.similarity.SimilarityProvider
-
Return the wrapped
Similarity
. - get() - Method in class org.elasticsearch.index.translog.TragicExceptionHolder
- get(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- get(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 class 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.collect.ImmutableOpenIntMap.Builder
- get(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- get(int) - Method in class org.elasticsearch.common.util.BitArray
- 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(CharSequence) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Returns the weight associated with an input string, or null if it does not exist.
- 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.DeprecationMap
- 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.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(Future<T>) - Static method in class org.elasticsearch.common.util.concurrent.FutureUtils
-
Calls
Future.get()
without the checked exceptions. - get(Future<T>, long, TimeUnit) - Static method in class org.elasticsearch.common.util.concurrent.FutureUtils
-
Calls
Future.get(long, TimeUnit)
without the checked exceptions. - get(K) - Method in class org.elasticsearch.common.cache.Cache
-
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
- get(K) - Method in class org.elasticsearch.common.collect.MapBuilder
- get(K, Errors) - Method in class org.elasticsearch.common.inject.internal.FailableCache
- get(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- get(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- get(GetRequest) - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type and id.
- get(GetRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- get(GetRequest, ActionListener<GetResponse>) - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type and id.
- get(GetRequest, ActionListener<GetResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- get(Errors, InternalContext, Dependency<?>) - Method in interface org.elasticsearch.common.inject.internal.InternalFactory
-
Creates an object to be injected.
- get(Errors, InternalContext, Dependency<?>) - Method in class org.elasticsearch.common.inject.internal.InternalFactory.Instance
- get(Key<T>) - Static method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns a new dependency that is not attached to an injection point.
- get(TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type.
- get(TypeLiteral<T>, Annotation) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation.
- get(TypeLiteral<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation type.
- get(Setting<T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns the value for the given setting.
- get(Settings) - Method in class org.elasticsearch.common.settings.SecureSetting
- get(Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
- get(Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns the settings value.
- get(Settings, Setting<Long>) - Static method in class org.elasticsearch.common.Randomness
-
Provides a reproducible source of randomness seeded by a long seed in the settings with the key setting.
- get(Settings, Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns the value for this setting but falls back to the second provided settings object
- get(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.ScoreScript
- get_score() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- getAbbreviation() - Method in enum org.elasticsearch.cluster.node.DiscoveryNode.Role
- 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
-
Action filters added by this plugin.
- 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
- 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.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 - 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.filter.InternalFilters.InternalBucket
- 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.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 class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- getAggregations() - Method in interface org.elasticsearch.search.aggregations.bucket.SingleBucketAggregation
- 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
- 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
-
The reader for the
PipelineAggregator
. - getAlias() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- getAlias() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- 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
- getAliasAndIndexLookup() - Method in class org.elasticsearch.cluster.metadata.MetaData
- 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.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
- 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
- getAliasFilter() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- getAliasFilter() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- getAliasFilter() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- getAliasMap() - Method in class org.elasticsearch.common.Table
- getAliasName() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
- 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.
- 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 - getAllMetaFields() - Static method in class org.elasticsearch.index.mapper.MapperService
- 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.
- getAllSnapshotIds() - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns an immutable collection of all the snapshot ids in the repository, both active and incompatible snapshots.
- 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.indices.IndicesService
- 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, MappedFieldType, 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 interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional
Analyzer
s. - 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
- 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(ShapeBuilder, ShapeRelation) - Static method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- getAsBoolean(String, Boolean) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as boolean) associated with the setting key.
- getAsBooleanLenientForPreEs6Indices(Version, String, Boolean, DeprecationLogger) - Method in class org.elasticsearch.common.settings.Settings
-
Deprecated.Only used to provide automatic upgrades for pre 6.0 indices.
- getAsBytesSize(String, ByteSizeValue) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as size) associated with the setting key.
- getAsDouble(String, Double) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as double) associated with the setting key.
- 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.
- getAssignedShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of assigned shards - 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.AnalyzeResponse.AnalyzeToken
- 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, DiscoveryNodes) - Static method in class org.elasticsearch.cluster.metadata.AutoExpandReplicas
-
Checks if the 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 -1 if the document has no auto generated timestamp.
- getAvailable() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- 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.stats.InternalStats
- getAvg() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getAvg() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
- getAvgAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- getAvgAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getAvgAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.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
- getBackgroundFrequency(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
- getBackgroundFrequency(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
- getBackgroundFrequency(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregatorFactory
- getBanCount() - Method in class org.elasticsearch.tasks.TaskManager
-
Returns the number of currently banned tasks.
- getBatchedReduceSize() - Method in class org.elasticsearch.action.search.SearchRequest
-
Returns the number of shard results that should be reduced at once on the coordinating node.
- getBatches() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getBatches() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of scan responses this request has processed.
- getBatchSize() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Gets the batch size for this request
- getBatchSize() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Gets the batch size for this request
- getBigArrays() - Method in class org.elasticsearch.index.IndexService
-
The
BigArrays
to use for this index. - getBigArrays() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns a BigArrays instance for this engine
- getBigramLambda() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- getBinaryValue(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- getBinding() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- getBitsetMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getBitsetMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of how much the cached bit sets are taking.
- getBitSetProducer(Query) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- getBlobStore() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getblock(byte[], int, int) - Static method in enum org.elasticsearch.common.hash.MurmurHash3
- 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.
- 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.significant.InternalMappedSignificantTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms
-
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.significant.UnmappedSignificantTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- 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.UnmappedTerms
- getBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- getBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.significant.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.GeoHashGrid
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid
- 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.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 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.significant.InternalMappedSignificantTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- 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.UnmappedTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- 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.
- 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
- getBytesValues() - Method in interface org.elasticsearch.index.fielddata.AtomicFieldData
-
Return a String representation of the values.
- getBytesValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractAtomicGeoPointFieldData
- getBytesValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractAtomicOrdinalsFieldData
- getBytesValues() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVAtomicFieldData
- getBytesWanted() - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- 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.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
- 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
- getCategoryClass() - Method in exception org.elasticsearch.common.xcontent.UnknownNamedObjectException
-
Category class that was missing a parser.
- 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 class org.elasticsearch.index.analysis.SynonymGraphTokenFilterFactory
- getChainAwareTokenFilterFactory(TokenizerFactory, List<CharFilterFactory>, List<TokenFilterFactory>, Function<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- 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
- getCharFilterProvider(String) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Returns a registered
CharFilterFactory
provider by name ornull
if the char filter was not registered - getCharFilterProvider(String, IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Returns a registered
CharFilterFactory
provider byIndexSettings
or a registeredCharFilterFactory
provider by predefined name ornull
if the charFilter was not registered - 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[].
- getCheckpoint() - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
The current checkpoint which can be advanced by
LocalCheckpointTracker.markSeqNoAsCompleted(long)
. - 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
- 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.BinaryDVAtomicFieldData
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVBytesAtomicFieldData
- getChildTasks() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- getChunkSize() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- 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(ShardPath, Directory) - Method in class org.elasticsearch.index.translog.TruncateTranslogAction
- getCleanStatus(ShardPath, Directory, Lock, PrintStream, boolean) - Method in class org.elasticsearch.index.shard.RemoveCorruptedLuceneSegmentsAction
- 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.SearchShardIterator
-
Returns the alias of the cluster where the shard is located.
- getClusterAlias() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- getClusterAlias() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the cluster alias in case the request is part of a cross-cluster search request,
null
otherwise. - getClusterAlias() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- 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
-
The latest cluster information
- 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.repositories.verify.VerifyRepositoryResponse
- 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
- getClusterStateCustomSuppliers(List<ClusterPlugin>) - Static method in class org.elasticsearch.cluster.ClusterModule
- 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
- 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
- getCompoundProcessor() - Method in class org.elasticsearch.ingest.Pipeline
-
Get the underlying
CompoundProcessor
containing the Pipeline's processors - 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. - 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
- getConcreteAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Returns all the concrete indices.
- getConcreteAllOpenIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
- 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.AliasOrIndex.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.
- 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
- getConfig() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- 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.ConnectionManager
-
Returns a connection for the given node if the node is connected.
- 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
- getConnectionsPerCluster() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- 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. - 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.
- getContentType() - Method in class org.elasticsearch.action.index.IndexRequest
-
The content type.
- 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
- 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 - getCopySettings() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- getCoreCacheHelper() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
- getCoreKeysForIndex(String) - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Get the set of core cache keys associated with the given index.
- getCorrections(Analyzer, BytesRef, CandidateGenerator, float, int, IndexReader, String, WordScorer, float, int) - Method in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
- getCorrections(TokenStream, CandidateGenerator, float, int, WordScorer, float, int) - Method in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
- getCount() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- 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.stats.InternalStats
- getCount() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getCount() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.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
- 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
- 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.
- getCurrentCapacity() - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
-
Returns the current queue capacity
- 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
- 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
- getCurrentSize() - Method in class org.elasticsearch.index.merge.MergeStats
- getCurrentSizeInBytes() - Method in class org.elasticsearch.index.merge.MergeStats
- getCustom(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- getCustomData(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getCustomMetaDataUpgrader() - Method in class org.elasticsearch.plugins.Plugin
-
Provides a function to modify global custom meta data on startup.
- 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
- 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. - getDate() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
-
Deprecated.
- getDate() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
-
Deprecated.
- getDates() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
-
Deprecated.
- getDates() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
-
Deprecated.
- 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
- 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.ParentFieldMapper.TypeParser
- 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.UidFieldMapper.TypeParser
- getDefault(MappedFieldType, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper.TypeParser
- 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
- getDefaultIndexOption() - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- 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
- 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.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
- 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.apache.lucene.search.XFilteredDocIdSetIterator
-
Return the wrapped
DocIdSetIterator
. - 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. - 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.
- getDependency() - Method in class org.elasticsearch.common.inject.internal.InternalContext
- 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.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.ingest.Pipeline
-
An optional description of what this pipeline is doing to the data gets processed by this pipeline.
- getDescription() - Method in class org.elasticsearch.plugins.PluginInfo
-
The description of the plugin.
- 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.ShardSearchTransportRequest
- getDescription() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- getDescription() - Method in class org.elasticsearch.tasks.Task
-
Generates task description
- getDescription() - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Returns optional description of the request to be displayed by the task manager
- getDescription() - Method in class org.elasticsearch.tasks.TaskInfo
- getDescription(PersistentTasksCustomMetaData.PersistentTask<Params>) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Returns task description that will be available via task manager
- getDescriptionFromElement(E) - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
- getDescriptionFromElement(Aggregator) - Method in class org.elasticsearch.search.profile.aggregation.InternalAggregationProfileTree
- getDestination() - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Gets the target for this reindex request in the for of an
IndexRequest
- getDetailed() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Should the detailed task information be returned.
- getDetailedMessage() - Method in exception org.elasticsearch.ElasticsearchException
-
Return the detail message, including the message from the nested exception if there is one.
- getDetails() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Builds a string representation of the message and the failure if exists.
- getDevicesStats() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getDictionary(String) - Method in class org.elasticsearch.indices.analysis.HunspellService
-
Returns the hunspell dictionary for the given locale.
- getDiffs() - Method in class org.elasticsearch.cluster.DiffableUtils.MapDiff
-
Map entries that, when this diff is applied to a map, should be incrementally updated.
- getDiffs() - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- getDirectMemoryMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getDirectoryReader() - Method in class org.elasticsearch.index.engine.Engine.Searcher
- getDirectoryReader() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- getDiscount() - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- getDiscovery() - Method in class org.elasticsearch.discovery.DiscoveryModule
- getDiscoveryNode() - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- getDiscoveryNode() - Method in class org.elasticsearch.transport.TransportService.HandshakeResponse
- getDiscoverySettings() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- getDiscoveryStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getDiscoveryTypes(ThreadPool, TransportService, NamedWriteableRegistry, MasterService, ClusterApplier, ClusterSettings, UnicastHostsProvider, AllocationService) - Method in interface org.elasticsearch.plugins.DiscoveryPlugin
-
Deprecated.Future versions will not support pluggable discovery implementations.
- getDistancePerDegree() - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Measures a longitude in this unit
- getDistanceString(LeafReaderContext, int) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- getDoc() - Method in class org.elasticsearch.script.FilterScript
-
The doc lookup for the Lucene segment this script was created for.
- getDoc() - Method in class org.elasticsearch.script.ScoreScript
-
The doc lookup for the Lucene segment this script was created for.
- getDoc() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- getDoc() - Method in class org.elasticsearch.script.SearchScript
-
The doc lookup for the Lucene segment this script was created for.
- getDoc() - Method in class org.elasticsearch.script.TermsSetQueryScript
-
The doc lookup for the Lucene segment this script was created for.
- getDoc() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- getDocCount() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Field
-
Return the number of documents that have a value for this field.
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- getDocCount() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- getDocCount() - Method in interface org.elasticsearch.search.aggregations.bucket.SingleBucketAggregation
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- getDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms.ParsedBucket
- getDocCountError() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms.Bucket
- getDocCountError() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms
-
Get an upper bound of the error on document counts in this aggregation.
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- getDocFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Term
-
Return the number of documents that contain this term in the index.
- getDocs() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getDocs() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getDocs() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getDocTypes() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Gets the document types on which this request would be executed.
- getDocTypes() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Gets the document types on which this request would be executed.
- getDocumentMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapperForType
- getDocValueFields() - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Gets the docvalue fields.
- getDocValuesMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getDocValuesMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the doc values memory usage by a segment.
- getDoneShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with completed snapshot
- getDoubleValues() - Method in interface org.elasticsearch.index.fielddata.AtomicNumericFieldData
-
Return a floating-point view of the values in this segment.
- getDynamicMappers() - Method in class org.elasticsearch.index.mapper.ParseContext
-
Get dynamic mappers created while parsing.
- getDynamicMappers() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- getEarliestLastModifiedAge() - Method in class org.elasticsearch.index.translog.TranslogStats
- getEarthCircumference() - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Measures the circumference of earth in this unit
- getEarthRadius() - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Measures the radius of earth in this unit
- getEditDistance() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns the maximum number of edits
- getElasticsearchDirectoryReader(DirectoryReader) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Tries to unwrap the given reader until the first
ElasticsearchDirectoryReader
instance is found ornull
if no instance is found. - getElasticsearchLeafReader(LeafReader) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
- getElasticsearchVersion() - Method in class org.elasticsearch.plugins.PluginInfo
-
The version of Elasticsearch the plugin was built for.
- getElements() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getElements() - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns the configuration information in this private environment.
- getElements(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Records the elements executed by
modules
. - getElements(Module...) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Records the elements executed by
modules
. - getElements(Stage, Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Records the elements executed by
modules
. - getElementsMutable() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getEndOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- getEngineFactories() - Method in class org.elasticsearch.indices.IndicesModule
- getEngineFactory() - Method in class org.elasticsearch.index.IndexService
- getEngineFactory(IndexSettings) - Method in interface org.elasticsearch.plugins.EnginePlugin
-
When an index is created this method is invoked for each engine plugin.
- getEngineOrNull() - Method in class org.elasticsearch.index.shard.IndexShard
-
NOTE: returns null if engine is not yet started (e.g.
- getEngineSearcher() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- getEntries() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns an unmodifiable list of snapshot deletion entries.
- getEntries() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- getEnvironment() - Method in class org.elasticsearch.node.Node
-
Returns the environment of the node
- getEphemeralId() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The unique ephemeral id of the node.
- getEra() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getError() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- getError() - Method in class org.elasticsearch.tasks.TaskResult
-
Get the error that finished this task.
- getErrorAsMap() - Method in class org.elasticsearch.tasks.TaskResult
-
Convert
TaskResult.getError()
from XContent to a Map for easy processing. - getErrorMessages() - Method in exception org.elasticsearch.common.inject.ConfigurationException
-
Returns messages for the errors that caused this exception.
- getErrorMessages() - Method in exception org.elasticsearch.common.inject.CreationException
-
Returns messages for the errors that caused this exception.
- getErrorMessages() - Method in exception org.elasticsearch.common.inject.ProvisionException
-
Returns messages for the errors that caused this exception.
- getErrors() - Method in exception org.elasticsearch.common.inject.internal.ErrorsException
- getEstimated() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getEstimatedSizeInBytes() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- getEventListener() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a listener that should be called on engine failure
- getEvictions() - Method in class org.elasticsearch.common.cache.Cache.CacheStats
- getEvictions() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of
DocIdSet
s that have been evicted from the cache. - getEvictions() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getEvictions() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- getException() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- getExceptionName() - Method in exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- getExceptionName() - Method in exception org.elasticsearch.ElasticsearchException
- getExceptionName(Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns a underscore case name for the given exception.
- getExceptionTypes(Member) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic exception types thrown by
constructor
. - getExecutor() - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
- getExecutor() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- getExecutor(ExplainRequest, ShardId) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- getExecutor(GetRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportGetAction
- getExecutor(MultiGetShardRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- getExecutor(MultiTermVectorsShardRequest, ShardId) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- getExecutor(TermVectorsRequest, ShardId) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- getExecutor(Request, ShardId) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- getExecutor(ShardRequest) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- getExecutorBuilders(Settings) - Method in class org.elasticsearch.plugins.Plugin
-
Provides the list of this plugin's custom thread pools, empty if none.
- getExecutorBuilders(Settings) - Method in class org.elasticsearch.plugins.PluginsService
- getExecutorNode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Assignment
- getExecutorNode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- getExistsCount() - Method in class org.elasticsearch.index.get.GetStats
- getExistsTime() - Method in class org.elasticsearch.index.get.GetStats
- getExistsTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
- getExpectedShardSize() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns the expected shard size for
ShardRoutingState.RELOCATING
andShardRoutingState.INITIALIZING
shards. - getExpectedShardSize(ShardRouting, RoutingAllocation, long) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Returns the expected shard size for the given shard or the default value provided if not enough information are available to estimate the shards size.
- getExplanation() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainResponse
-
Return the explanation for shard allocation in the cluster
- getExplanation() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- getExplanation() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Gets the explanation for the decision.
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Get the explanation for this decision.
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
-
Returns the explanation string, fully formatted.
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- getExplanation() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Assignment
- getExplanation() - Method in class org.elasticsearch.search.SearchHit
-
If enabled, the explanation of the search hit.
- getExplanations() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
- getExposedKeys() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getExposedKeys() - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns the unique exposed keys for these private elements.
- getExposedSource(Key<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getExposedSource(Key<?>) - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns an arbitrary object containing information about the "place" where this key was exposed.
- getExtendedPlugins() - Method in class org.elasticsearch.plugins.PluginInfo
-
Other plugins this plugin extends through SPI.
- getExternalRefreshListener() - Method in class org.elasticsearch.index.engine.EngineConfig
-
The refresh listeners to add to Lucene for externally visible refreshes
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- getFailed() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- getFailedDeleteResult(Exception, long) - Method in class org.elasticsearch.index.shard.IndexShard
- getFailedIndexResult(Exception, long) - Method in class org.elasticsearch.index.shard.IndexShard
- getFailedNodes() - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
returns a set of nodes for which publication has failed.
- getFailedShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with failed snapshot
- getFailedShards() - Method in class org.elasticsearch.action.search.SearchResponse
-
The failed number of shards the search was executed on.
- getFailedShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The failed shards this request was executed on.
- getFailure() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns reason for snapshot failure
- getFailure() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The actual failure object if there was a failure.
- getFailure() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The failure if relevant.
- getFailure() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
- getFailure() - Method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- getFailure() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getFailure() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
- getFailure() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The failure if relevant.
- getFailure() - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
- getFailure() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
-
The exception, if present, causing the shard to fail.
- getFailure() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns additional failure exception details if exists.
- getFailure() - Method in class org.elasticsearch.index.engine.Engine.Result
-
get document failure while executing the operation
null
in case of no failure - getFailure() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getFailure() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- getFailureMessage() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The failure message,
null
if it did not fail. - getFailureMessage() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
-
The actual failure message, null if its not a failure.
- getFailures() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
-
Returns node
IndicesShardStoresResponse.Failure
s encountered while executing the request - getFailures() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- getFailures() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
Where there any search failures?
- getFeature() - Method in class org.elasticsearch.plugins.Plugin
-
A feature exposed by the plugin.
- getFetchCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getFetchCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getFetchPhase() - Method in class org.elasticsearch.search.SearchModule
- getFetchSourceContext() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getFetchSubPhases(SearchPlugin.FetchPhaseConstructionContext) - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
FetchSubPhase
s defined by this plugin. - getFetchTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getFetchTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getField() - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- getField() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- getField() - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
Get the field to use for random number generation.
- getField() - Method in class org.elasticsearch.search.collapse.CollapseBuilder
-
The name of the field to collapse against
- getField() - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
-
Returns the nested field in the source this hit originates from
- getField() - Method in class org.elasticsearch.search.slice.SliceBuilder
-
The name of the field to slice against
- getField() - Method in class org.elasticsearch.search.slice.SliceQuery
- getField() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- getField() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getField(String) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
-
Get the field capabilities for the provided
field
- getField(String) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
-
Get the field capabilities per type for the provided
field
. - getField(String) - Method in class org.elasticsearch.action.get.GetResponse
- getField(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- getField(String, LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource.BytesMultiValuesSource
- getField(String, LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource.NumericMultiValuesSource
- getFieldData() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getFieldData() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getFieldData() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getFieldFilter() - Method in class org.elasticsearch.indices.IndicesService
-
Returns a function which given an index name, returns a predicate which fields must match in order to be returned by get mappings, get index, get field mappings and field capabilities API.
- getFieldFilter() - Method in class org.elasticsearch.indices.mapper.MapperRegistry
-
Returns a function that given an index name, returns a predicate that fields must match in order to be returned by get mappings, get index, get field mappings and field capabilities API.
- getFieldFilter() - Method in interface org.elasticsearch.plugins.MapperPlugin
-
Returns a function that given an index name returns a predicate which fields must match in order to be returned by get mappings, get index, get field mappings and field capabilities API.
- getFieldHighlighter(String, Query, Set<Term>, int) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- getFieldMappings(GetFieldMappingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the mappings of specific fields
- getFieldMappings(GetFieldMappingsRequest, ActionListener<GetFieldMappingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the mappings of specific fields
- GetFieldMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetFieldMappingsIndexRequest - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetFieldMappingsIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- GetFieldMappingsRequest - Class in org.elasticsearch.action.admin.indices.mapping.get
-
Request the mappings of specific fields Note: there is a new class with the same name for the Java HLRC that uses a typeless format.
- GetFieldMappingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- GetFieldMappingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.get
-
A helper class to build
GetFieldMappingsRequest
objects - GetFieldMappingsRequestBuilder(ElasticsearchClient, GetFieldMappingsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- GetFieldMappingsResponse - Class in org.elasticsearch.action.admin.indices.mapping.get
-
Response object for
GetFieldMappingsRequest
API Note: there is a new class with the same name for the Java HLRC that uses a typeless format. - GetFieldMappingsResponse.FieldMappingMetaData - Class in org.elasticsearch.action.admin.indices.mapping.get
- getFieldName() - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
The field name.
- getFieldName() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.UidIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- getFieldName() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- getFieldName() - Method in enum org.elasticsearch.ingest.IngestDocument.MetaData
- getFieldName() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getFieldName() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getFieldName() - Method in class org.elasticsearch.search.collapse.CollapseContext
-
The requested field name to collapse on.
- getFieldName() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the document field this sort should be based on.
- getFieldName() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
-
Name of the field to get contexts from at index-time
- getFieldName() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- getFieldNames() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the field names that will be used when generating the 'More Like This' query.
- getFieldNames() - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Deprecated.Use
InnerHitBuilder.getStoredFieldsContext()
instead. - getFieldQuery(String, String, boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getFieldQuery(String, String, int) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getFields() - Method in class org.elasticsearch.action.get.GetResponse
- getFields() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getFields() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- getFields() - Method in class org.elasticsearch.index.get.GetResult
- getFields() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- getFields() - Method in class org.elasticsearch.search.SearchHit
-
A map of hit fields (from field name to hit fields) if additional fields were required to be loaded.
- getFields() - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- getFields(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- getFields(IndexReader, int, String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SourceScoreOrderFragmentsBuilder
- getFields(IndexReader, int, String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SourceSimpleFragmentsBuilder
- getFieldType() - Method in class org.elasticsearch.search.collapse.CollapseContext
-
The field type used for collapsing
- getFieldType(Field) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic type of
field
. - getFieldValue(String, Class<T>) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document for the provided path
- getFieldValue(String, Class<T>, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document for the provided path
- getFieldValue(TemplateScript.Factory, Class<T>) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document with the provided templated path
- getFieldValueAsBytes(String) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document for the provided path as a byte array.
- getFieldValueAsBytes(String, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document for the provided path as a byte array.
- getFile(String) - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
- getFile(String) - Method in interface org.elasticsearch.common.settings.SecureSettings
-
Return a file setting.
- getFileDetails(String) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- getFilename(long) - Static method in class org.elasticsearch.index.translog.Translog
-
package private for testing
- getFilePointer() - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- getFilePointer() - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- getFileSizes() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getFileStore(Path) - Static method in class org.elasticsearch.env.Environment
- getFilter() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- getFilter() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- getFilter() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- getFilter() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
-
Returns a filter function that expects the source map as an input and returns the filtered map.
- getFilter() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- getFinalizingShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with the snapshot in the finalizing stage
- getFirst(Iterable<T>, T) - Static method in class org.elasticsearch.common.util.iterable.Iterables
- getFirstAliasMetaData() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
- getFirstOperationOffset() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- getFirstOrdinals() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Return a
PackedInts.Reader
instance mapping every doc ID to its first ordinal + 1 if it exists and 0 otherwise. - getFlags() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- getFlags() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- getFlagsValue() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
-
Returns internal regular expression syntax flag value see
RegexpFlag.value()
- getFloodStageRaw() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFlush() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getFlush() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getFlushMergesAfter() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a
TimeValue
at what time interval after the last write modification to the engine finished merges should be automatically flushed. - getFlushThresholdSize() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the transaction log threshold size when to forcefully flush the index and clear the transaction log.
- getForField(MappedFieldType) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
- getForField(MappedFieldType) - Method in class org.elasticsearch.index.query.QueryShardContext
- getForField(MappedFieldType) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getForField(MappedFieldType) - Method in class org.elasticsearch.search.internal.SearchContext
- getForField(MappedFieldType) - Method in class org.elasticsearch.search.lookup.DocLookup
- getForField(MappedFieldType) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- getForField(MappedFieldType, String) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
- getFormat() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getFormattedSortValues() - Method in class org.elasticsearch.search.SearchSortValues
-
Returns the formatted version of the values that sorting was performed against
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getFormatter(String) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- getFormatVersion() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Get the metadata format version for the keystore
- getForUpdate(String, String, long, VersionType, long, long) - Method in class org.elasticsearch.index.get.ShardGetService
- getFragments() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
-
The highlighted fragments.
- getFree() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getFree() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getFree() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- getFreeBytes() - Method in class org.elasticsearch.cluster.DiskUsage
- getFreeBytesThresholdFloodStage() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeBytesThresholdHigh() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeBytesThresholdLow() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeDiskAsPercentage() - Method in class org.elasticsearch.cluster.DiskUsage
- getFreeDiskThresholdFloodStage() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeDiskThresholdHigh() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeDiskThresholdLow() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreePercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getFreePhysicalMemorySize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the amount of free physical memory in bytes.
- getFreeSwapSpaceSize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the amount of free swap space in bytes.
- getFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Doc
-
Return the number of occurrences of the term in the current document for the considered field.
- getFreq() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- getFrom() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange.ParsedBucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getFrom() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getFromAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getFromContext(String) - Method in class org.elasticsearch.search.internal.ScrollContext
-
Returns the object or
null
if the given key does not have a value in the context - getFromSearcher(Engine.Get, BiFunction<String, Engine.SearcherScope, Engine.Searcher>, Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.Engine
- getFs() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
File system level stats.
- getFs() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getFSInfo(NodeEnvironment.NodePath) - Static method in class org.elasticsearch.monitor.fs.FsProbe
- getFullPrefixPaths(List<FSTUtil.Path<PairOutputs.Pair<Long, BytesRef>>>, Automaton, FST<PairOutputs.Pair<Long, BytesRef>>) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Returns all completion paths to initialize the search.
- getFullPrefixPaths(List<FSTUtil.Path<PairOutputs.Pair<Long, BytesRef>>>, Automaton, FST<PairOutputs.Pair<Long, BytesRef>>) - Method in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
- getFullyQualifiedIndex() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Returns the fully qualified index including a remote cluster alias if applicable, and the index uuid
- getFullyQualifiedIndexName() - Method in class org.elasticsearch.search.SearchShardTarget
-
Returns the fully qualified index name, including the index prefix that indicates which cluster results come from.
- getFunctionBytes() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- getFunctions() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- getFuzzyMinLength() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns the length of input prefix after which edits are applied
- getFuzzyOptions() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- getFuzzyPrefixLength() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns the minimum length of the input prefix required to apply any edits
- getFuzzyQuery(String, String, float) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getGb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getGbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getGc() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getGcCollectors() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getGcDeletesInMillis() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the GC deletes cycle in milliseconds.
- getGeneration() - Method in class org.elasticsearch.index.engine.CommitStats
- getGeneration() - Method in class org.elasticsearch.index.engine.Segment
- getGeneration() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- getGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the current generation of this translog.
- getGenerationThresholdSize() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the generation threshold size.
- getGenericComponentType() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- getGenericSupertype(Type, Class<?>, Class<?>) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns the generic supertype for
supertype
. - getGenId() - Method in class org.elasticsearch.repositories.RepositoryData
-
Gets the generational index file id from which this instance was read.
- getGeohash() - Method in class org.elasticsearch.common.geo.GeoPoint
- getGeoPoint() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
-
Returns the geo point of the context
- getGeoPointValues() - Method in interface org.elasticsearch.index.fielddata.AtomicGeoPointFieldData
-
Return geo-point values.
- getGet() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getGet() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getGetResult() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getGetResult() - Method in class org.elasticsearch.action.update.UpdateResponse
- getGiga() - Method in class org.elasticsearch.common.unit.SizeValue
- getGigaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getGlobalCheckpoint() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- getGlobalCheckpoint() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- getGlobalCheckpoint() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns the global checkpoint for the shard.
- getGlobalCheckpoint() - Method in class org.elasticsearch.index.seqno.SeqNoStats
- getGlobalCheckpoint() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the global checkpoint for the shard.
- getGlobalCheckpointSupplier() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the global checkpoint tracker
- getGlobalText() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Gets the global suggest text
- getGroups() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- getGroups(String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns group settings for the given setting prefix.
- getGroups(String, boolean) - Method in class org.elasticsearch.common.settings.Settings
-
Returns group settings for the given setting prefix.
- getGroupStats() - Method in class org.elasticsearch.index.search.stats.SearchStats
- getGuiceServiceClasses() - Method in class org.elasticsearch.plugins.Plugin
-
Node level services that will be automatically started/stopped/closed.
- getGuiceServiceClasses() - Method in class org.elasticsearch.plugins.PluginsService
-
Returns all classes injected into guice by plugins which extend
LifecycleComponent
. - getHandshakeTimeout() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the handshake timeout or
null
if no explicit timeout is set on this profile. - getHeader(String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns the header for the given key or
null
if not present - getHeader(String) - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the list of header values for the given key or
null
if no header for the given key exists. - getHeader(String) - Method in class org.elasticsearch.tasks.Task
-
Returns stored task header associated with the task
- getHeaderKeys() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns a set of all header keys on this exception
- getHeaderMap() - Method in class org.elasticsearch.common.Table
- getHeaders() - Method in class org.elasticsearch.common.Table
- getHeaders() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns all of the request contexts headers
- getHeaders() - Method in exception org.elasticsearch.ElasticsearchException
- getHeaders() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getHeaders() - Method in class org.elasticsearch.rest.RestRequest
-
Get all of the headers and values associated with the headers.
- getHeaders() - Method in class org.elasticsearch.rest.RestResponse
-
Returns custom headers that have been added, or null if none have been set.
- getHeaders() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns the task headers
- getHeapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- getHeapInit() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getHeapMax() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
Maximum total heap available to the cluster
- getHeapMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getHeapMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
-
returns the maximum heap size.
- getHeapUsed() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
Total heap used in the cluster
- getHeapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- getHeapUsedPercent() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
-
returns the heap usage in percent.
- getHighFreqMinimumNumberShouldMatchSpec() - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
- getHighlightBuilder() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getHighlighted() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- getHighlighters() - Method in class org.elasticsearch.plugins.SearchPlugin.FetchPhaseConstructionContext
- getHighlighters() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
Get the
Highlighter
s defined by this plugin. - getHighlighters() - Method in class org.elasticsearch.search.SearchModule
-
Returns the
Highlighter
registry - getHighlightFields() - Method in class org.elasticsearch.search.SearchHit
-
A map of highlighted fields.
- getHighlightMaxAnalyzedOffset() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of chars that will be analyzed in a highlight request
- getHighWatermarkRaw() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
-
Gets the raw (uninterpreted) high watermark value as found in the settings.
- getHistoryOperations(String, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Creates a new history snapshot for reading operations since the provided starting seqno (inclusive).
- getHistoryUUID() - Method in class org.elasticsearch.index.engine.Engine
-
returns the history uuid for the engine
- getHistoryUUID() - Method in class org.elasticsearch.index.engine.InternalEngine
- getHistoryUUID() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getHistoryUUID() - Method in class org.elasticsearch.index.shard.IndexShard
- getHistoryUUID() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
returns the history uuid the store points at, or null if nonexistent.
- getHit() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- getHitCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of successful lookups in the cache.
- getHitCount() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getHits() - Method in class org.elasticsearch.action.search.SearchResponse
-
The search hits.
- getHits() - Method in class org.elasticsearch.common.cache.Cache.CacheStats
- getHits() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
The documents returned in this batch.
- getHits() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- getHits() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.ParsedTopHits
- getHits() - Method in interface org.elasticsearch.search.aggregations.metrics.tophits.TopHits
- getHits() - Method in class org.elasticsearch.search.SearchHits
-
The hits of the search request (based on the search type, and from / size provided).
- getHost() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getHostAddress() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- getHostname() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
System's hostname.
- getHostname() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getHostName() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- getHotThreads() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- getHour() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getHourOfDay() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getHttp() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- getHttp() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getHttpServerTransportSupplier() - Method in class org.elasticsearch.common.network.NetworkModule
- getHttpTransports(Settings, ThreadPool, BigArrays, CircuitBreakerService, NamedWriteableRegistry, NamedXContentRegistry, NetworkService, HttpServerTransport.Dispatcher) - Method in interface org.elasticsearch.plugins.NetworkPlugin
-
Returns a map of
HttpServerTransport
suppliers. - getHunspellDictionaries() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional hunspell
Dictionary
s. - getId() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- getId() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The id of the action.
- getId() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The id of the action.
- getId() - Method in enum org.elasticsearch.action.DocWriteRequest.OpType
- getId() - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- getId() - Method in class org.elasticsearch.action.DocWriteResponse
-
The id of the document changed.
- getId() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getId() - Method in class org.elasticsearch.action.get.GetResponse
-
The id of the document.
- getId() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The id of the document.
- getId() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The id of the action.
- getId() - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- getId() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- getId() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- getId() - Method in exception org.elasticsearch.action.RoutingMissingException
- getId() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The id of the document.
- getId() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
-
The id of the action.
- getId() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getId() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The unique id of the node.
- getId() - Method in class org.elasticsearch.cluster.routing.AllocationId
-
The allocation id uniquely identifying an allocation, note, if it is relocation the
AllocationId.getRelocationId()
need to be taken into account as well. - getId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard id.
- getId() - Method in class org.elasticsearch.index.engine.CommitStats
-
base64 version of the commit id (see
SegmentInfos.getId()
- getId() - Method in class org.elasticsearch.index.get.GetResult
-
The id of the document.
- getId() - Method in class org.elasticsearch.index.merge.OnGoingMerge
-
A unique id for the merge.
- getId() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getId() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The document id of the hit.
- getId() - Method in class org.elasticsearch.index.shard.ShardId
- getId() - Method in class org.elasticsearch.ingest.Pipeline
-
The unique id of this pipeline
- getId() - Method in class org.elasticsearch.ingest.PipelineConfiguration
- getId() - Method in class org.elasticsearch.monitor.process.ProcessInfo
-
The process id.
- getId() - Method in enum org.elasticsearch.persistent.decider.AssignmentDecision.Type
- getId() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- getId() - Method in class org.elasticsearch.repositories.IndexId
-
The unique ID for the index within the repository.
- getId() - Method in enum org.elasticsearch.script.ScriptType
- getId() - Method in class org.elasticsearch.search.SearchHit
-
The id of the document.
- getId() - Method in class org.elasticsearch.search.slice.SliceBuilder
-
The id of the slice.
- getId() - Method in class org.elasticsearch.search.slice.SliceQuery
- getId() - Method in class org.elasticsearch.tasks.Task
-
Returns task id
- getId() - Method in class org.elasticsearch.tasks.TaskId
- getId() - Method in class org.elasticsearch.tasks.TaskInfo
- getId(Class<? extends ElasticsearchException>) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns the serialization id the given exception.
- getIdOrCode() - Method in class org.elasticsearch.script.Script
- getIds() - Method in class org.elasticsearch.action.ingest.GetPipelineRequest
- getIfPrimaryTerm() - Method in class org.elasticsearch.index.engine.Engine.Delete
- getIfPrimaryTerm() - Method in class org.elasticsearch.index.engine.Engine.Get
- getIfPrimaryTerm() - Method in class org.elasticsearch.index.engine.Engine.Index
- getIfSeqNo() - Method in class org.elasticsearch.index.engine.Engine.Delete
- getIfSeqNo() - Method in class org.elasticsearch.index.engine.Engine.Get
- getIfSeqNo() - Method in class org.elasticsearch.index.engine.Engine.Index
- getIgnoredFields() - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return the collection of fields that have been ignored so far.
- getIgnoredFields() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- getIgnoreNodes(ShardId) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- getInactivePrimaryHealth(ShardRouting) - Static method in class org.elasticsearch.cluster.health.ClusterShardHealth
-
Checks if an inactive primary shard should cause the cluster health to go RED.
- getIncludeInAllDefault() - Method in class org.elasticsearch.index.mapper.ParseContext
-
Whether field values should be added to the _all field by default.
- getIncomingRecoveries(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getIncompatibleSnapshotIds() - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns an immutable collection of the snapshot ids in the repository that are incompatible with the current ES version.
- getIncrementalFileCount() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns incremental file count of the snapshot
- getIncrementalFileCount() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getIncrementalSize() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Return incremental files size of the snapshot
- getIncrementalSize() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getIndex() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns the index name of the shard to explain, or
null
to use any unassigned shard (seeClusterAllocationExplainRequest.useAnyUnassignedShard()
). - getIndex() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
Returns the index name
- getIndex() - Method in class org.elasticsearch.action.admin.indices.segments.IndexSegments
- getIndex() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getIndex() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- getIndex() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- getIndex() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The index name of the action.
- getIndex() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The index name of the action.
- getIndex() - Method in class org.elasticsearch.action.DocWriteResponse
-
The index the document was changed in.
- getIndex() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getIndex() - Method in class org.elasticsearch.action.get.GetResponse
-
The index the document was fetched from.
- getIndex() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The index name of the document.
- getIndex() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The index name of the action.
- getIndex() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- getIndex() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The index name of the document.
- getIndex() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
-
The index name of the action.
- getIndex() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getIndex() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getIndex() - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
Get the index on which the operation should act.
- getIndex() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Index
- getIndex() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
-
The deleted index.
- getIndex() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getIndex() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Return the index id
- getIndex() - Method in exception org.elasticsearch.ElasticsearchException
- getIndex() - Method in class org.elasticsearch.index.get.GetResult
-
The index the document was fetched from.
- getIndex() - Method in class org.elasticsearch.index.IndexModule
-
Returns the index this module is associated with
- getIndex() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the index this settings object belongs to
- getIndex() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getIndex() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The index in which the hit is stored.
- getIndex() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getIndex() - Method in class org.elasticsearch.index.shard.ShardId
- getIndex() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getIndex() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- getIndex() - Method in class org.elasticsearch.search.SearchHit
-
The index of the hit.
- getIndex() - Method in class org.elasticsearch.search.SearchShardTarget
- getIndex(String) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getIndex(GetIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get index metadata for particular indices.
- getIndex(GetIndexRequest, ActionListener<GetIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get index metadata for particular indices.
- GetIndexAction - Class in org.elasticsearch.action.admin.indices.get
- getIndexAnalyzers() - Method in class org.elasticsearch.index.IndexService
- getIndexAnalyzers() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- getIndexAnalyzers() - Method in class org.elasticsearch.index.mapper.MapperService
- getIndexAnalyzers() - Method in class org.elasticsearch.index.query.QueryShardContext
- getIndexBalance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
Returns the index related weight factor.
- getIndexBlockWithId(String, int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- getIndexBufferRAMBytesUsed() - Method in class org.elasticsearch.index.engine.Engine
-
How much heap is used that would be freed by a refresh.
- getIndexBufferRAMBytesUsed() - Method in class org.elasticsearch.index.engine.InternalEngine
- getIndexBufferRAMBytesUsed() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getIndexBufferRAMBytesUsed() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns number of heap bytes used by the indexing buffer for this shard, or 0 if the shard is closed
- getIndexBufferRAMBytesUsed(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
returns how much heap this shard is using for its indexing buffer
- getIndexCommit() - Method in class org.elasticsearch.index.engine.Engine.IndexCommitRef
- getIndexCommit(SegmentInfos, Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns an index commit for the given
SegmentInfos
in the given directory. - getIndexCount() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getIndexCount() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
The total number of indexing operations
- getIndexCurrent() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
Returns the currently in-flight indexing operations.
- getIndexEventListener() - Method in class org.elasticsearch.index.IndexService
- getIndexEventListener() - Method in class org.elasticsearch.index.shard.IndexShard
- getIndexFailedCount() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
The number of failed indexing operations
- getIndexing() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getIndexing() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getIndexingBufferSize() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the initial index buffer size.
- getIndexMetaData() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the current IndexMetaData for this index
- getIndexMetaDataUpgrader() - Method in class org.elasticsearch.plugins.Plugin
-
Provides a function to modify index meta data when an index is introduced into the cluster state for the first time.
- getIndexName() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
-
Get the index name
- getIndexName() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The index name.
- getIndexName() - Method in class org.elasticsearch.index.shard.ShardId
- getIndexNameExpressionResolver() - Method in class org.elasticsearch.cluster.ClusterModule
- getIndexReader() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Return the current
IndexReader
, ornull
if no index reader is available, for instance if this rewrite context is used to index queries (percolation). - GetIndexRequest - Class in org.elasticsearch.action.admin.indices.get
-
A request to retrieve information about an index.
- GetIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- GetIndexRequest.Feature - Enum in org.elasticsearch.action.admin.indices.get
- GetIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.get
- GetIndexRequestBuilder(ElasticsearchClient, GetIndexAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
- GetIndexResponse - Class in org.elasticsearch.action.admin.indices.get
-
A response for a get index action.
- GetIndexResponse(String[], ImmutableOpenMap<String, ImmutableOpenMap<String, MappingMetaData>>, ImmutableOpenMap<String, List<AliasMetaData>>, ImmutableOpenMap<String, Settings>, ImmutableOpenMap<String, Settings>) - Constructor for class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getIndexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- getIndexSafe(Index) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Returns the
IndexMetaData
for this index. - getIndexScopedSettings() - Method in class org.elasticsearch.common.settings.SettingsModule
- getIndexSettings() - Method in class org.elasticsearch.index.AbstractIndexComponent
- getIndexSettings() - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns the indices settings
- getIndexSettings() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the index settings for this index.
- getIndexSettings() - Method in class org.elasticsearch.index.IndexService
- getIndexSettings() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Returns the index settings for this context.
- getIndexSettings() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the index indexSettings
- getIndexSettings() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Returns the index settings of this index.
- getIndexSettings(Index) - Method in class org.elasticsearch.gateway.PriorityComparator
- getIndexShard(ShardId) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- getIndexShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getIndexSort() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Return the sort order of this index, or null if the index has no sort.
- getIndexSort() - Method in class org.elasticsearch.index.shard.IndexShard
-
Return the sort order of this index, or null if the index has no sort.
- getIndexSortConfig() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the index sort config that should be used for this index.
- getIndexSortSupplier() - Method in class org.elasticsearch.index.IndexService
- getIndexStoreFactories() - Method in interface org.elasticsearch.plugins.IndexStorePlugin
-
The index store factories for this plugin.
- getIndexTemplateMetaDataUpgrader() - Method in class org.elasticsearch.plugins.Plugin
-
Provides a function to modify index template meta data on startup.
- getIndexTemplates() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- GetIndexTemplatesAction - Class in org.elasticsearch.action.admin.indices.template.get
- GetIndexTemplatesAction() - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
- GetIndexTemplatesRequest - Class in org.elasticsearch.action.admin.indices.template.get
-
Request that allows to retrieve index templates
- GetIndexTemplatesRequest() - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- GetIndexTemplatesRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- GetIndexTemplatesRequestBuilder - Class in org.elasticsearch.action.admin.indices.template.get
- GetIndexTemplatesRequestBuilder(ElasticsearchClient, GetIndexTemplatesAction) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequestBuilder
- GetIndexTemplatesRequestBuilder(ElasticsearchClient, GetIndexTemplatesAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequestBuilder
- GetIndexTemplatesResponse - Class in org.elasticsearch.action.admin.indices.template.get
- GetIndexTemplatesResponse(List<IndexTemplateMetaData>) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- getIndexThrottleTimeInMillis() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the number of milliseconds this engine was under index throttling.
- getIndexThrottleTimeInMillis() - Method in class org.elasticsearch.index.engine.InternalEngine
- getIndexThrottleTimeInMillis() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getIndexTime() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
The total amount of time spend on executing index operations.
- getIndexToDefaultSettings() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
If the originating
GetSettingsRequest
object was configured to include defaults, this will contain a mapping of index name toSettings
objects. - getIndexToSettings() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
Returns a map of index name to
Settings
object. - getIndexUUID() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getIndexVersion() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getIndexVersionCreated() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the version the index was created on.
- getIndexWriteRequest(DocWriteRequest) - Static method in class org.elasticsearch.action.bulk.TransportBulkAction
-
Retrieves the
IndexRequest
from the providedDocWriteRequest
for index or upsert actions. - getIndexWriterMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getIndexWriterMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the memory usage by index writer
- getIndices() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getIndices() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
Indices level stats.
- getIndices() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns list of snapshot indices
- getIndices() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
number of indices in the cluster
- getIndices() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getIndices() - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- getIndices() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getIndices() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- getIndices() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getIndices() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
- getIndices() - Method in interface org.elasticsearch.cluster.metadata.AliasOrIndex
- getIndices() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Index
- getIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
- getIndices() - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns an unmodifiable map of the index names to
IndexId
in the repository. - getIndicesAndFilters() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- getIndicesFieldDataCache() - Method in class org.elasticsearch.indices.IndicesService
- getIndicesQueryCache() - Method in class org.elasticsearch.indices.IndicesService
- getIndicesRouting() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- getIndicesService() - Method in class org.elasticsearch.search.SearchService
- getIndicesStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getInflightOpsCount(ShardId, ClusterState, IndexShardRoutingTable, ActionListener<SyncedFlushService.InFlightOpsResponse>) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
-
returns the number of in flight operations on primary.
- getInFlightRequestBreaker() - Method in class org.elasticsearch.transport.TcpTransport
- getInFlightRequestBreaker() - Method in interface org.elasticsearch.transport.Transport
- getInfos() - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoResponse
- getIngest() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- getIngestCount() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- getIngestCurrent() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- getIngestDocument() - Method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- getIngestDocument() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getIngestFailedCount() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- getIngestMetadata() - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the available ingest metadata fields, by default only timestamp, but it is possible to set additional ones.
- getIngestNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- getIngestService() - Method in class org.elasticsearch.node.NodeService
- getIngestStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getIngestTimeInMillis() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- getIngestTook() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
If ingest is enabled returns the bulk ingest preprocessing time, otherwise 0 is returned.
- getIngestTookInMillis() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
If ingest is enabled returns the bulk ingest preprocessing time.
- getInitialClusterStateCustomSupplier() - Method in interface org.elasticsearch.plugins.ClusterPlugin
-
Returns a map of
ClusterState.Custom
supplier that should be invoked to initialize the initial clusterstate. - getInitialConnectionTimeout() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- getInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with the snapshot in the initializing stage
- getInitializingShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getInitializingShards() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getInitializingShards() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getInitialRecoveryFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getInjectableMembers() - Method in interface org.elasticsearch.common.inject.spi.ConstructorBinding
-
Returns all instance method and field injection points on
type
. - getInjectionPoint() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns the injection point to which this dependency belongs, or null if this dependency isn't attached to a particular injection point.
- getInjectionPoints() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- getInjectionPoints() - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- getInjectionPoints() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
-
Returns the instance methods and fields of
instance
that will be injected to fulfill this request. - getInjectionPoints() - Method in interface org.elasticsearch.common.inject.spi.InstanceBinding
-
Returns the field and method injection points of the instance, injected at injector-creation time only.
- getInjectionPoints() - Method in interface org.elasticsearch.common.inject.spi.ProviderInstanceBinding
-
Returns the field and method injection points of the provider, injected at injector-creation time only.
- getInjectionPoints() - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
-
Returns the static methods and fields of
type
that will be injected to fulfill this request. - getInjector() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getInjector() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getInjector() - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns the child injector that hosts these private elements, or null if the elements haven't been used to create an injector.
- getInnerCollapseBuilder() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getInnerFactory() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
- getInnerHit() - Method in class org.elasticsearch.search.collapse.CollapseContext
-
The inner hit options to expand the collapsed results
- getInnerHits() - Method in class org.elasticsearch.search.collapse.CollapseBuilder
-
The inner hit options to expand the collapsed results
- getInnerHits() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext
- getInnerHits() - Method in class org.elasticsearch.search.SearchHit
- getInnerQuery() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
- getInputArguments() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getInsertOrder() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getInstance() - Static method in class org.elasticsearch.cluster.DiffableUtils.StringSetValueSerializer
- getInstance() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- getInstance() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- getInstance() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- getInstance() - Method in interface org.elasticsearch.common.inject.spi.InstanceBinding
-
Returns the user-supplied instance.
- getInstance() - Static method in class org.elasticsearch.monitor.os.OsProbe
- getInstance() - Static method in class org.elasticsearch.monitor.process.ProcessProbe
- getInstance(Class<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the appropriate instance for the given injection type; equivalent to
getProvider(type).get()
. - getInstance(Key<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the appropriate instance for the given injection key; equivalent to
getProvider(key).get()
. - getInSyncAllocationIds() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getInSyncAllocationIds() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- getInSyncAllocationIds(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- getInSyncGlobalCheckpoints() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Get the local knowledge of the global checkpoints for all in-sync allocation IDs.
- getInSyncGlobalCheckpoints() - Method in class org.elasticsearch.index.shard.IndexShard
-
Get the local knowledge of the global checkpoints for all in-sync allocation IDs.
- getInternalFactory() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getInternalRefreshListener() - Method in class org.elasticsearch.index.engine.EngineConfig
-
The refresh listeners to add to Lucene for internally visible refreshes.
- getInternalRepositories(Environment, NamedXContentRegistry) - Method in interface org.elasticsearch.plugins.RepositoryPlugin
-
Returns internal repository types added by this plugin.
- getInternalValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- getInternalValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- getInterval() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- getInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- getIntKeySerializer() - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Returns a map key serializer for Integer keys.
- getIoStats() - Method in class org.elasticsearch.monitor.fs.FsInfo
- getItemId() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The numeric order of the item matching the same request order in the bulk request.
- getItems() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
The items representing each action performed in the bulk operation (in the same order!).
- getItems() - Method in class org.elasticsearch.action.get.MultiGetRequest
- getJavaVersion() - Method in class org.elasticsearch.plugins.PluginInfo
-
The version of Java the plugin was built with.
- getJoinValidator() - Method in interface org.elasticsearch.plugins.DiscoveryPlugin
-
Returns a consumer that validate the initial join cluster state.
- getJvm() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
JVM level information.
- getJvm() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
JVM level statistics.
- getJvm() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getKb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getKbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getKeepAlive() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getKey() - Method in class org.elasticsearch.common.cache.RemovalNotification
- getKey() - Method in interface org.elasticsearch.common.inject.Binding
-
Returns the key for this binding.
- getKey() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getKey() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- getKey() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- getKey() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns the key to the binding that satisfies this dependency.
- getKey() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- getKey() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup.ProviderImpl
- getKey() - Method in class org.elasticsearch.common.settings.Setting
-
Returns the settings key or a prefix if this setting is a group setting.
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix.ParsedBucket
- getKey() - Method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram.ParsedBucket
- getKey() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantLongTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantStringTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- getKey(String) - Method in interface org.elasticsearch.common.settings.SettingUpgrader
-
The logic to upgrade the setting key, for example by mapping the old setting key to the new setting key.
- getKey(TypeLiteral<?>, Member, Annotation[], Errors) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Gets a key for the given type, member and annotations.
- getKey(MultiBucketsAggregation.Bucket) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.HistogramFactory
-
Get the key for the given bucket.
- getKey(MultiBucketsAggregation.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getKey(MultiBucketsAggregation.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- getKey(MultiBucketsAggregation.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantLongTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantStringTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- getKeyAsNumber() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- getKeyAsNumber() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram.ParsedBucket
- getKeyAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantLongTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantStringTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- getKeyed() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getKeyed() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getKeyed() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getKilo() - Method in class org.elasticsearch.common.unit.SizeValue
- getKiloFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getLang() - Method in class org.elasticsearch.script.Script
- getLang() - Method in exception org.elasticsearch.script.ScriptException
-
Returns the language of the script.
- getLang() - Method in class org.elasticsearch.script.StoredScriptSource
- getLargest() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getLargestNonClientNodeVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the youngest version in the cluster that is not a client node.
- getLastAllocationId() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
- getLastAllocationStatus() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Get the status for the last allocation attempt for this shard.
- getLastCommittedSegmentInfos() - Method in class org.elasticsearch.index.engine.Engine
- getLastCommittedSegmentInfos() - Method in class org.elasticsearch.index.engine.InternalEngine
- getLastCommittedSegmentInfos() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getLastEmittedDocPerShard(SearchPhaseController.ReducedQueryPhase, int) - Method in class org.elasticsearch.action.search.SearchPhaseController
- getLastModifiedTime() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the latest global checkpoint value that has been persisted in the underlying storage (i.e.
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.engine.InternalEngine
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the latest global checkpoint value that has been persisted in the underlying storage (i.e.
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.translog.Translog
-
The last synced checkpoint for this translog.
- getLastWriteLocation() - Method in class org.elasticsearch.index.translog.Translog
-
The a Translog.Location that will sort after the Translog.Location returned by the last write but before any locations which can be returned by the next write.
- getLastWriteNanos() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the timestamp of the last write in nanoseconds.
- getLat() - Method in class org.elasticsearch.common.geo.GeoPoint
- getLat() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getLats() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getLeaderState() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Returns the object that tracks the state of sliced subtasks.
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.BucketCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.query.CancellableCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.query.EarlyTerminatingCollector
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Get a
LeafBucketCollector
for the given ctx, which should delegate to the given collector. - getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
- getLeafDocLookup(LeafReaderContext) - Method in class org.elasticsearch.search.lookup.DocLookup
- getLeafFieldsLookup(LeafReaderContext) - Method in class org.elasticsearch.search.lookup.FieldsLookup
- getLeafLookup() - Method in class org.elasticsearch.script.SearchScript
-
The leaf lookup for the Lucene segment this script was created for.
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- getLeafSearchLookup(LeafReaderContext) - Method in class org.elasticsearch.search.lookup.SearchLookup
- getLeastDiskEstimate() - Method in class org.elasticsearch.monitor.fs.FsInfo
- getLegacyFieldValues() - Method in interface org.elasticsearch.index.fielddata.AtomicFieldData
-
Returns field values for use by returned hits.
- getLength() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Doc
-
Return the number of tokens that the current document has in the considered field.
- getLength() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- getLikeFields() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getLikeText() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getLikeTexts() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getLimit() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getLimit() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getLimit() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getLimit() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getLimit() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getLimit() - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- getLineNumber() - Method in exception org.elasticsearch.common.ParsingException
-
Line number of the location of the error
- getLineNumber() - Method in exception org.elasticsearch.search.SearchParseException
-
Line number of the location of the error
- getLinkedKey() - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- getLinkedKey() - Method in interface org.elasticsearch.common.inject.spi.LinkedKeyBinding
-
Returns the linked key used to resolve injections.
- getListener() - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
-
Returns the registered listener.
- getListeners() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The number of waiting refresh listeners.
- getListValue(List<String>) - Method in interface org.elasticsearch.common.settings.SettingUpgrader
- getLoadAndScaleToPercent(Method, OperatingSystemMXBean) - Static method in class org.elasticsearch.monitor.Probes
- getLoadAverage() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
- getLoadedClassCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
- getLocalAddress() - Method in class org.elasticsearch.rest.RestRequest
- getLocalAddress() - Method in interface org.elasticsearch.transport.TcpChannel
-
Returns the local address for this channel.
- getLocalAddress() - Method in interface org.elasticsearch.transport.TcpServerChannel
-
Returns the local address for this channel.
- getLocalAddresses() - Method in class org.elasticsearch.transport.TcpTransport
- getLocalAddresses() - Method in interface org.elasticsearch.transport.Transport
-
Returns a list of all local adresses for this transport
- getLocalAddresses() - Method in class org.elasticsearch.transport.TransportService
- getLocalCheckpoint() - Method in class org.elasticsearch.index.engine.Engine
- getLocalCheckpoint() - Method in class org.elasticsearch.index.engine.InternalEngine
- getLocalCheckpoint() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getLocalCheckpoint() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- getLocalCheckpoint() - Method in class org.elasticsearch.index.seqno.SeqNoStats
-
the maximum sequence number for which all previous operations (including) have been completed
- getLocalCheckpoint() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the local checkpoint for the shard.
- getLocalNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the local node
- getLocalNode() - Method in class org.elasticsearch.transport.TransportService
- getLocalNodeId() - Method in class org.elasticsearch.client.node.NodeClient
-
The id of the local
DiscoveryNode
. - getLocalNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the id of the local node
- getLocation(String) - Method in class org.elasticsearch.action.DocWriteResponse
-
Return the relative URI for the location of the document suitable for use in the
Location
header. - getLogger() - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- getLogger() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- getLogger(Class<?>, String...) - Static method in class org.elasticsearch.common.logging.Loggers
- getLogger(Class<?>, Index, String...) - Static method in class org.elasticsearch.common.logging.Loggers
- getLogger(Class<?>, ShardId, String...) - Static method in class org.elasticsearch.common.logging.Loggers
- getLogger(String, ShardId) - Static method in class org.elasticsearch.common.logging.Loggers
-
Just like
Loggers.getLogger(Class, ShardId, String...)
but String loggerName instead of Class and no extra prefixes. - getLogger(Logger, String) - Static method in class org.elasticsearch.common.logging.Loggers
- getLon() - Method in class org.elasticsearch.common.geo.GeoPoint
- getLon() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getLongValues() - Method in interface org.elasticsearch.index.fielddata.AtomicNumericFieldData
-
Get an integer view of the values of this segment.
- getLons() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getLowerBounds() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- getLowercase() - Method in enum org.elasticsearch.action.DocWriteRequest.OpType
- getLowercase() - Method in enum org.elasticsearch.action.DocWriteResponse.Result
- getLowercase() - Method in enum org.elasticsearch.index.engine.Engine.Operation.TYPE
- getLowFreqMinimumNumberShouldMatchSpec() - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
- getLowWatermarkRaw() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
-
Gets the raw (uninterpreted) low watermark value as found in the settings.
- getLuceneDescription() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Retrieve the lucene description of this query (e.g.
- getLuceneRelation() - Method in enum org.elasticsearch.common.geo.ShapeRelation
-
Maps ShapeRelation to Lucene's LatLonShapeRelation
- getMapper(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
-
Returns the leaf mapper associated with this field name.
- getMapper(String) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- getMapperParsers() - Method in class org.elasticsearch.indices.mapper.MapperRegistry
-
Return a map of the mappers that have been registered.
- getMapperRegistry() - Method in class org.elasticsearch.indices.IndicesModule
-
A registry for all field mappers.
- getMappers() - Method in interface org.elasticsearch.plugins.MapperPlugin
-
Returns additional mapper implementations added by this plugin.
- getMapperService() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Return the MapperService.
- getMapping() - Method in class org.elasticsearch.index.mapper.DocumentMapperForType
- getMappings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getMappings() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- getMappings(GetMappingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- getMappings(GetMappingsRequest, ActionListener<GetMappingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- GetMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetMappingsRequest - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetMappingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequest
- GetMappingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetMappingsRequestBuilder(ElasticsearchClient, GetMappingsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequestBuilder
- GetMappingsResponse - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetMappingsResponse(ImmutableOpenMap<String, ImmutableOpenMap<String, MappingMetaData>>) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- getMappingVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getMasterActionName(DiscoveryNode) - Method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- getMasterActionName(DiscoveryNode) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
-
Allows to conditionally return a different master node action name in the case an action gets renamed.
- getMasterAndDataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the discovered master and data nodes arranged by their ids - getMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the master node
- getMasterNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the id of the master node
- getMasterNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the discovered master nodes arranged by their ids - getMasterService() - Method in class org.elasticsearch.cluster.service.ClusterService
- getMatchedQueries() - Method in class org.elasticsearch.search.SearchHit
-
The set of query and filter names the query matched with.
- getMatchingBytes() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Gets the number of matching bytes the shard copy has with the primary shard.
- getMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getMax() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
- getMax() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- getMax() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getMax() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
- getMax() - Method in class org.elasticsearch.search.slice.SliceBuilder
-
The maximum number of slices.
- getMax() - Method in class org.elasticsearch.search.slice.SliceQuery
- getMax() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getMaxAdjacencyMatrixFilters() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the max number of filters in adjacency_matrix aggregation search requests
- getMaxAnalyzedPathsForOneInput() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- getMaxAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- getMaxAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getMaxAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
- getMaxBuckets() - Method in exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- getMaxChildren() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- getMaxConcurrentFileChunks() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- getMaxConcurrentGroupRequests() - Method in class org.elasticsearch.search.collapse.CollapseBuilder
-
Returns the amount of group requests that are allowed to be ran concurrently in the inner_hits phase.
- getMaxConcurrentShardRequests() - Method in class org.elasticsearch.action.search.SearchRequest
-
Returns the number of shard requests that should be executed concurrently.
- getMaxContentLength() - Method in class org.elasticsearch.http.HttpInfo
- getMaxDeterminizedStates() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns the maximum automaton states allowed for fuzzy expansion
- getMaxDeterminizedStates() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
-
Returns the maximum automaton states allowed for fuzzy expansion
- getMaxDocFreq() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMaxDocFreq() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMaxDocFreq() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the maximum frequency in which words may still appear.
- getMaxDocvalueFields() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of allowed docvalue_fields to retrieve in a search request
- getMaxExpansions() - Method in class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- getMaxFileDescriptorCount() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the maximum number of file descriptors allowed on the system, or -1 if not supported.
- getMaxFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getMaximumInnerInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- getMaxIndexPrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the maximum number of primary shards an index has
- getMaxIndexReplication() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
maximum replication factor across the indices.
- getMaxIndexShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the maximum number of shards (primary+replicas) an index has
- getMaxInnerResultWindow() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the max result window for an individual inner hit definition or top hits aggregation.
- getMaxMergeCount() - Method in class org.elasticsearch.index.MergeSchedulerConfig
-
Returns
maxMergeCount
. - getMaxNgramDiff() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum allowed difference between max and min length of ngram
- getMaxNodeVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the youngest version in the cluster
- getMaxNumTerms() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMaxNumTokensParsed() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- getMaxOpenFileDescriptors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
- getMaxQueryTerms() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMaxQueryTerms() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the maximum number of query terms that will be included in any generated query.
- getMaxRefreshListeners() - Method in class org.elasticsearch.index.IndexSettings
-
The maximum number of refresh listeners allows on this shard.
- getMaxRegexLength() - Method in class org.elasticsearch.index.IndexSettings
-
The maximum length of regex string allowed in a regexp query.
- getMaxRescoreWindow() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum rescore window for search requests.
- getMaxResultWindow() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the max result window for search requests, describing the maximum value of from + size on a query.
- getMaxRetries() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Total number of retries attempted for rejections.
- getMaxScore() - Method in class org.elasticsearch.search.query.QuerySearchResult
- getMaxScore() - Method in class org.elasticsearch.search.SearchHits
-
The maximum score of this query.
- getMaxScriptFields() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of allowed script_fields to retrieve in a search request
- getMaxSeenAutoIdTimestamp() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the maximum auto_id_timestamp of all append-only index requests have been processed by this engine or the auto_id_timestamp received from its primary shard via
Engine.updateMaxUnsafeAutoIdTimestamp(long)
. - getMaxSeenAutoIdTimestamp() - Method in class org.elasticsearch.index.engine.InternalEngine
- getMaxSeenAutoIdTimestamp() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the maximum auto_id_timestamp of all append-only requests have been processed by this shard or the auto_id_timestamp received from the primary via
IndexShard.updateMaxUnsafeAutoIdTimestamp(long)
at the beginning of a peer-recovery or a primary-replica resync. - getMaxSeenAutoIdTimestampOnPrimary() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- getMaxSeqNo() - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
The maximum sequence number issued so far.
- getMaxSeqNo() - Method in class org.elasticsearch.index.seqno.SeqNoStats
-
the maximum sequence number seen so far
- getMaxSeqNo() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the max seq_no of translog operations found in this translog.
- getMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- getMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the maximum sequence number of either update or delete operations have been processed in this engine or the sequence number from
Engine.advanceMaxSeqNoOfUpdatesOrDeletes(long)
. - getMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the maximum sequence number of either update or delete operations have been processed in this shard or the sequence number from
IndexShard.advanceMaxSeqNoOfUpdatesOrDeletes(long)
. - getMaxShingleDiff() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum allowed difference between max and min shingle_size
- getMaxShingleSize() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- getMaxSlicesPerScroll() - Method in class org.elasticsearch.index.IndexSettings
-
The maximum number of slices allowed in a scroll request.
- getMaxTaskWaitTime() - Method in class org.elasticsearch.cluster.service.MasterService
-
Returns the maximum wait time for tasks in the queue
- getMaxTaskWaitTime() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
-
Returns the waiting time of the first task in the queue
- getMaxTermFreq() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMaxTermFrequency() - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
- getMaxTermsCount() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of terms that can be used in a Terms Query request
- getMaxThreadCount() - Method in class org.elasticsearch.index.MergeSchedulerConfig
-
Returns
maxThreadCount
. - getMaxUnsafeAutoIdTimestamp() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Returns the max timestamp that is used to de-optimize documents with auto-generated IDs in the engine.
- getMaxUpTime() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
The maximum uptime of a node in the cluster
- getMaxWordLen() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMaxWordLen() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the maximum word length above which words will be ignored.
- getMaxWordLength() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getMbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getMbPerSec(Thread, MergePolicy.OneMerge) - Static method in class org.apache.lucene.index.OneMergeHelper
-
The current MB per second rate limit for this merge.
- getMedianAbsoluteDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- getMedianAbsoluteDeviation() - Method in interface org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviation
-
Returns the median absolute deviation statistic computed for this aggregation
- getMedianAbsoluteDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.mad.ParsedMedianAbsoluteDeviation
- getMega() - Method in class org.elasticsearch.common.unit.SizeValue
- getMegaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getMem() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
- getMem() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getMem() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getMem() - Method in class org.elasticsearch.monitor.os.OsStats
- getMem() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getMember() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns the injected constructor, field, or method.
- getMembersInjector() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
-
Returns the looked up members injector.
- getMembersInjector(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- getMembersInjector(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(Class<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- getMembersInjector(Class<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- getMembersInjector(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- getMembersInjector(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getMemoryControlGroup() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The control group for the
memory
subsystem. - getMemoryInBytes() - Method in class org.elasticsearch.index.engine.Segment
-
Estimation of the memory usage used by a segment.
- getMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the memory usage used by a segment.
- getMemoryLimitInBytes() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The maximum amount of user memory (including file cache).
- getMemoryPools() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getMemorySize() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- getMemorySize() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getMemorySize() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- getMemoryUsageInBytes() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The total current memory usage by processes in the cgroup (in bytes).
- getMerge() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getMerge() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getMergedSegments() - Method in class org.elasticsearch.index.merge.OnGoingMerge
-
The list of segments that are being merged.
- getMergeId() - Method in class org.elasticsearch.index.engine.Segment
-
If set, a string representing that the segment is part of a merge, with the value representing the group of segments that represent this merge.
- getMergePolicy() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the
MergePolicy
for the enginesIndexWriter
- getMergePolicy() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the merge policy that should be used for this index.
- getMergeSchedulerConfig() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the
MergeSchedulerConfig
- getMergeStats() - Method in class org.elasticsearch.index.engine.Engine
- getMergeStats() - Method in class org.elasticsearch.index.engine.InternalEngine
- getMessage() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The failure message.
- getMessage() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The failure message.
- getMessage() - Method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- getMessage() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- getMessage() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- getMessage() - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
-
Returns any feedback the command wants to provide for logging.
- getMessage() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
-
The failure message, if available, explaining why the shard failed.
- getMessage() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns optional details explaining the reasons.
- getMessage() - Method in exception org.elasticsearch.common.inject.ConfigurationException
- getMessage() - Method in exception org.elasticsearch.common.inject.CreationException
- getMessage() - Method in exception org.elasticsearch.common.inject.ProvisionException
- getMessage() - Method in class org.elasticsearch.common.inject.spi.Message
-
Gets the error message text.
- getMessage() - Method in exception org.elasticsearch.common.ValidationException
- getMessage() - Method in enum org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- getMessages() - Method in class org.elasticsearch.common.inject.internal.Errors
- getMessagesFromThrowable(Throwable) - Static method in class org.elasticsearch.common.inject.internal.Errors
- getMetadata() - Method in exception org.elasticsearch.ElasticsearchException
- getMetadata() - Method in class org.elasticsearch.ingest.IngestDocument
-
Does the same thing as
IngestDocument.extractMetadata()
but does not mutate the map. - getMetadata() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getMetadata() - Method in class org.elasticsearch.repositories.FilterRepository
- getMetadata() - Method in interface org.elasticsearch.repositories.Repository
-
Returns metadata about this repository.
- getMetadata(String) - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the list of metadata values for the given key or
null
if no metadata for the given key exists. - getMetadata(IndexCommit) - Method in class org.elasticsearch.index.store.Store
-
Returns a new MetadataSnapshot for the given commit.
- getMetadata(IndexCommit, boolean) - Method in class org.elasticsearch.index.store.Store
-
Returns a new MetadataSnapshot for the given commit.
- getMetaData() - Method in class org.elasticsearch.cluster.ClusterState
- getMetaData() - Method in class org.elasticsearch.index.IndexService
- getMetaData() - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- getMetaData() - Method in interface org.elasticsearch.search.aggregations.Aggregation
-
Get the optional byte array metadata that was set on the aggregation
- getMetaData() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return any associated metadata with this
AggregationBuilder
. - getMetaData() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- getMetaData() - Method in class org.elasticsearch.search.aggregations.ParsedAggregation
- getMetadataKeys() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns a set of all metadata keys on this exception
- getMetadataMapperParsers() - Method in class org.elasticsearch.indices.mapper.MapperRegistry
-
Return a map of the meta mappers that have been registered.
- getMetadataMappers() - Method in interface org.elasticsearch.plugins.MapperPlugin
-
Returns additional metadata mapper implementations added by this plugin.
- getMetConditions() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- getMethod() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- getMetrics() - Method in class org.elasticsearch.ingest.Pipeline
-
The metrics associated with this pipeline.
- getMillis() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMillisOfDay() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMillisOfSecond() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMin() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
- getMin() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- getMin() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getMin() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
- getMin() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getMinAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- getMinAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getMinAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
- getMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- getMinDocFreq() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMinDocFreq() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMinDocFreq() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the frequency at which words will be ignored which do not occur in at least this many docs.
- getMinFileGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the minimum file generation referenced by the translog
- getMinGenerationForSeqNo(long) - Method in class org.elasticsearch.index.translog.Translog
-
Gets the minimum generation that could contain any sequence number after the specified sequence number, or the current generation if there is no generation that could any such sequence number.
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- getMinimalSupportedVersion() - Method in interface org.elasticsearch.cluster.NamedDiff
-
The minimal version of the recipient this custom object can be sent to
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.RestoreInProgress
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- getMinimalSupportedVersion() - Method in interface org.elasticsearch.common.io.stream.VersionedNamedWriteable
-
The minimal version of the recipient this object can be sent to
- getMinimalSupportedVersion() - Method in class org.elasticsearch.ingest.IngestMetadata
- getMinimalSupportedVersion() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- getMinimalSupportedVersion() - Method in class org.elasticsearch.script.ScriptMetaData
- getMinimumMasterNodesOnPublishingMaster() - Method in class org.elasticsearch.cluster.ClusterState
-
The node-level `discovery.zen.minimum_master_nodes` setting on the master node that published this cluster state, for use in rolling upgrades from 6.x to 7.x.
- getMinimumShouldMatch() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
- getMinimumShouldMatchField() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- getMinimumShouldMatchScript() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- getMinIndexPrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the minimum number of primary shards an index has
- getMinIndexReplication() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
minimum replication factor across the indices.
- getMinIndexShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the minimum number of shards (primary+replicas) an index has
- getMinNodeVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the oldest version in the cluster.
- getMinOpenFileDescriptors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
- getMinRetainedSeqNo() - Method in class org.elasticsearch.index.engine.Engine
-
Gets the minimum retained sequence number for this engine.
- getMinRetainedSeqNo() - Method in class org.elasticsearch.index.engine.InternalEngine
-
Returns the minimum seqno that is retained in the Lucene index.
- getMinRetainedSeqNo() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getMinRetainedSeqNo() - Method in class org.elasticsearch.index.shard.IndexShard
-
Gets the minimum retained sequence number for this engine.
- getMinScore() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- getMinScore() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- getMinShingleSize() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- getMinTermFreq() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMinTermFreq() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the frequency below which terms will be ignored in the source doc.
- getMinTermFrequency() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMinTranslogGenerationForRecovery() - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
-
returns the translog generation that will be used as a basis of a future store/peer recovery
- getMinute() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getMinuteOfDay() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMinuteOfHour() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMinWordLen() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMinWordLen() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the minimum word length below which words will be ignored.
- getMinWordLength() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMissCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of lookups in the cache that failed to retrieve a
DocIdSet
. - getMissCount() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getMisses() - Method in class org.elasticsearch.common.cache.Cache.CacheStats
- getMissing() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getMissing() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getMissingCount() - Method in class org.elasticsearch.index.get.GetStats
- getMissingTime() - Method in class org.elasticsearch.index.get.GetStats
- getMissingTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
- getModifiers() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- getModule(Iterable<? extends Element>) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Returns the module composed of
elements
. - getModuleInfos() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
-
Returns an ordered list based on modules name
- getMonitorService() - Method in class org.elasticsearch.node.NodeService
- getMonth() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getMonthOfYear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMonthValue() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getMoreLikeFields() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMostDiskEstimate() - Method in class org.elasticsearch.monitor.fs.FsInfo
- getMount() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getMoveDecision() - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
-
Gets the move decision for the shard.
- getMovingAverageModelParserRegistry() - Method in class org.elasticsearch.search.SearchModule
-
The registry of
MovAvgModel
s. - getMovingAverageModels() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
MovAvgModel
s defined by this plugin. - getMultiTermComponent() - Method in interface org.elasticsearch.index.analysis.MultiTermAwareComponent
-
Returns an analysis component to handle analysis if multi-term queries.
- getMultiTermComponent(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
- getMultiValueMode() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- getName() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- getName() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- getName() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- getName() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The name of the field.
- getName() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- getName() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The name of the node.
- getName() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getName() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getName() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getName() - Method in class org.elasticsearch.common.document.DocumentField
-
The name of the field.
- getName() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- getName() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
-
gets the name of this instance
- getName() - Method in exception org.elasticsearch.common.xcontent.UnknownNamedObjectException
-
Name of the missing parser.
- getName() - Method in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
-
The name of the analysis component in the API.
- getName() - Method in class org.elasticsearch.index.engine.Segment
- getName() - Method in class org.elasticsearch.index.Index
- getName() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
The name of this score function.
- getName() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.WeightBuilder
- getName() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getName() - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Returns the name that identifies uniquely the query
- getName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- getName() - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- getName() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getName() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getName() - Method in class org.elasticsearch.ingest.IngestStats.ProcessorStat
- getName() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- getName() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
- getName() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getName() - Method in class org.elasticsearch.monitor.os.OsInfo
- getName() - Method in class org.elasticsearch.plugins.PluginInfo
-
The name of the plugin.
- getName() - Method in class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
The name of the thing being specified as a
ParseField
. - getName() - Method in class org.elasticsearch.repositories.IndexId
-
The name of the index.
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCancelTasksAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterSearchShardsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStatsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCreateSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteRepositoryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteStoredScriptAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetSnapshotsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetStoredScriptAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetTaskAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesUsageAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPendingClusterTasksAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutRepositoryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutStoredScriptAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestRemoteClusterInfoAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestRestoreSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestSnapshotsStatusAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestVerifyRepositoryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestCloseIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestCreateIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestFlushAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestForceMergeAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetAliasesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetAllAliasesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetFieldMappingAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetMappingAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexDeleteAliasesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexPutAliasAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesAliasesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesSegmentsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesShardStoresAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestOpenIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestRecoveryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestRefreshAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestShrinkIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestSplitIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestRolloverIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestSyncedFlushAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeStatusAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestValidateQueryAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestAliasAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestAllocationAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestCatAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestCountAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestFielddataAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestMasterAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestNodesAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestPluginsAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestRecoveryAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestSegmentsAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestTemplatesAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestBulkAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestCountAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestDeleteAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestGetAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestGetSourceAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestIndexAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestMultiGetAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestMultiTermVectorsAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestUpdateAction
- getName() - Method in class org.elasticsearch.rest.action.ingest.RestDeletePipelineAction
- getName() - Method in class org.elasticsearch.rest.action.ingest.RestGetPipelineAction
- getName() - Method in class org.elasticsearch.rest.action.ingest.RestPutPipelineAction
- getName() - Method in class org.elasticsearch.rest.action.ingest.RestSimulatePipelineAction
- getName() - Method in class org.elasticsearch.rest.action.RestFieldCapabilitiesAction
- getName() - Method in class org.elasticsearch.rest.action.RestMainAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestClearScrollAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestExplainAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestSearchAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
- getName() - Method in class org.elasticsearch.rest.BaseRestHandler
- getName() - Method in enum org.elasticsearch.script.ScriptType
- getName() - Method in interface org.elasticsearch.search.aggregations.Aggregation
- getName() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return this aggregation's name.
- getName() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- getName() - Method in class org.elasticsearch.search.aggregations.ParsedAggregation
- getName() - Method in enum org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Return the english-formatted name of the GapPolicy
- getName() - Method in enum org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.SeasonalityType
-
Return the english-formatted name of the SeasonalityType
- getName() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Return this aggregation's name.
- getName() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
-
The name of the field highlighted.
- getName() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- getName() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- getName() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getName() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- getName() - Method in class org.elasticsearch.snapshots.SnapshotId
-
Returns snapshot name
- getName() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getName() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getNamedAnalyzer(String) - Method in class org.elasticsearch.index.mapper.MapperService
- getNamedContexts(List<CharSequence>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Maps an output context list to a map of context mapping names and their values see
ContextMappings.TypedContextField
- getNamedWriteables() - Static method in class org.elasticsearch.cluster.ClusterModule
- getNamedWriteables() - Static method in class org.elasticsearch.common.network.NetworkModule
- getNamedWriteables() - Method in class org.elasticsearch.indices.IndicesModule
- getNamedWriteables() - Method in class org.elasticsearch.plugins.Plugin
-
Returns parsers for
NamedWriteable
this plugin will use over the transport protocol. - getNamedWriteables() - Method in class org.elasticsearch.search.SearchModule
- getNamedXContent() - Method in class org.elasticsearch.plugins.Plugin
-
Returns parsers for named objects this plugin will parse from
XContentParser.namedObject(Class, String, Object)
. - getNamedXContentParsers() - Method in interface org.elasticsearch.plugins.spi.NamedXContentProvider
- getNamedXContents() - Static method in class org.elasticsearch.common.network.NetworkModule
- getNamedXContents() - Method in class org.elasticsearch.indices.IndicesModule
- getNamedXContents() - Method in class org.elasticsearch.search.SearchModule
- getNamedXWriteables() - Static method in class org.elasticsearch.cluster.ClusterModule
- getNames() - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
All the names under which values are registered.
- getNamespace(Setting<T>) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
-
Returns the namespace for a concrete setting.
- getNamespaces(Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
-
Returns distinct namespaces for the given settings
- getNano() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getNeighbours() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
-
Returns the precision levels at which geohash cells neighbours are considered
- getNestedFilter() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Deprecated.set nested sort with
FieldSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withFieldSortBuilder.getNestedSort()
- getNestedFilter() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.set nested sort with
GeoDistanceSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withGeoDistanceSortBuilder.getNestedSort()
- getNestedFilter() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Deprecated.set nested sort with
ScriptSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withScriptSortBuilder.getNestedSort()
- getNestedIdentity() - Method in class org.elasticsearch.search.SearchHit
-
If this is a nested hit then nested reference information is returned otherwise
null
is returned. - getNestedPath() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Deprecated.set nested sort with
FieldSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withFieldSortBuilder.getNestedSort()
- getNestedPath() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.set nested sort with
GeoDistanceSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withGeoDistanceSortBuilder.getNestedSort()
- getNestedPath() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Deprecated.set nested sort with
ScriptSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withScriptSortBuilder.getNestedSort()
- getNestedSort() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
- getNestedSort() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the
NestedSortBuilder
- getNestedSort() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the
NestedSortBuilder
- getNestedSort() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- getNestedSort() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Returns the
NestedSortBuilder
- getNewIndex() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns the name of the index that the request alias currently points to
- getNewIndexName() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- getNewMetaData() - Method in class org.elasticsearch.gateway.GatewayMetaState.IndexMetaWriteInfo
- getNextClusterStateToProcess() - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
Gets the next committed state to process.
- getNode() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
Node the store belongs to
- getNode() - Method in class org.elasticsearch.action.support.nodes.BaseNodeResponse
-
The node this information relates to.
- getNode() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
Get the node that this decision is for.
- getNode() - Method in class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- getNode() - Method in class org.elasticsearch.discovery.zen.MembershipAction.JoinRequest
- getNode() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- getNode() - Method in interface org.elasticsearch.transport.Transport.Connection
-
The node this connection is associated with
- getNodeDecision() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
Gets the
AllocationDecision
for allocating to this node. - getNodeDecisions() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Gets the sorted list of individual node-level decisions that went into making the ultimate decision whether to allocate or move the shard.
- getNodeEnvironment() - Method in class org.elasticsearch.node.Node
-
Returns the
NodeEnvironment
instance of this node - getNodeFailures() - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
-
The list of node failures exception.
- getNodeId() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- getNodeId() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns node id of the node where snapshot is currently running
- getNodeId() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- getNodeId() - Method in class org.elasticsearch.action.TaskOperationFailure
- getNodeId() - Method in class org.elasticsearch.cluster.DiskUsage
- getNodeId() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getNodeId() - Method in class org.elasticsearch.search.SearchShardTarget
- getNodeId() - Method in class org.elasticsearch.tasks.TaskId
- getNodeIdText() - Method in class org.elasticsearch.search.SearchShardTarget
- getNodeLeastAvailableDiskUsages() - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns a node id to disk usage mapping for the path that has the least available space on the node.
- getNodeLockId() - Method in class org.elasticsearch.env.NodeEnvironment
- getNodeMostAvailableDiskUsages() - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns a node id to disk usage mapping for the path that has the most available space on the node.
- getNodeName() - Method in class org.elasticsearch.action.main.MainResponse
- getNodeName() - Method in class org.elasticsearch.cluster.DiskUsage
- getNodeName() - Method in class org.elasticsearch.cluster.service.ClusterService
-
The name of this node.
- getNodeName() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the current node name
- getNodePaths() - Method in class org.elasticsearch.env.NodeEnvironment.NodeLock
- getNodes() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- getNodes() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- getNodes() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Get the successful node responses.
- getNodes() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- getNodes() - Method in class org.elasticsearch.cluster.ClusterState
- getNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the discovered nodes arranged by their ids - getNodes() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
-
Gets the current set of nodes involved in node fault detection.
- getNodesAllocatedByDepth() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- getNodeSettings() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the node settings.
- getNodesMap() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Lazily build and get a map of Node ID to node response.
- getNodesResizedByDepth() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- getNodesStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getNodeStatistics(String) - Method in class org.elasticsearch.node.ResponseCollectorService
-
Optionally return a
NodeStatistics
for the given nodeid, if response information exists for the given node. - getNoMasterBlock() - Method in class org.elasticsearch.discovery.DiscoverySettings
- getNonFailedTasks(MasterService.TaskInputs, ClusterStateTaskExecutor.ClusterTasksResult<Object>) - Method in class org.elasticsearch.cluster.service.MasterService
- getNonHeapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- getNonHeapInit() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getNonHeapMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getNonHeapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- getNoops() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getNoops() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of noops (skipped bulk items) as part of this request.
- getNoopUpdateCount() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- getNoRefresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Return the potentially stale cached entry.
- getNormalizer(String) - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns a normalizer mapped to the given name or
null
if not present - getNormsMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getNormsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the norms memory usage by a segment.
- getNumberOfCommitted() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- getNumberOfDataNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getNumberOfDataNodes() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getNumberOfDelayedUnassigned(ClusterState) - Static method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns the number of shards that are unassigned and currently being delayed.
- getNumberOfElapsedPeriods() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
-
The number of elapsed periods.
- getNumberOfInFlightFetch() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getNumberOfInFlightFetch() - Method in class org.elasticsearch.gateway.GatewayAllocator
- getNumberOfInFlightFetches() - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
Returns the number of async fetches that are currently ongoing.
- getNumberOfNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getNumberOfNodes() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getNumberOfPendingTasks() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getNumberOfPendingTasks() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- getNumberOfReplicas() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getNumberOfReplicas() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getNumberOfReplicas() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the number of replicas this index has.
- getNumberOfSearch() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- getNumberOfShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Gets the number of primary shards from all indices, not including replicas.
- getNumberOfShards() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the number of shards this index has.
- getNumberOfTasksOnNode(String, String) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- getNumberOfTimesThrottled() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
-
The number of times tasks in the control group have been throttled.
- getNumBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- getNumConnections() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the total number of connections for this profile
- getNumConnectionsPerType(TransportRequestOptions.Type) - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the number of connections per type for this profile.
- getNumDocs() - Method in class org.elasticsearch.index.engine.CommitStats
-
Returns the number of documents in the in this commit
- getNumDocs() - Method in class org.elasticsearch.index.engine.Segment
- getNumDocs() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the number of documents in this store snapshot
- getNumDocs(SegmentInfos) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns the number of documents in the index referenced by this
SegmentInfos
- getNumericType() - Method in interface org.elasticsearch.index.fielddata.IndexNumericFieldData
- getNumericType() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
- getNumFailedAllocations() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns the number of previously failed allocations of this shard.
- getNumFreed() - Method in class org.elasticsearch.action.search.ClearScrollResponse
- getNumIgnoredPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns the number of temporarily marked as ignored unassigned primaries
- getNumMultiValuesDocs() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number distinct of document IDs associated with two or more values.
- getNumNodesConnected() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- getNumPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns the number of non-ignored unassigned primaries
- getNumPriorUsesInASequence() - Method in interface org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttribute
- getNumPriorUsesInASequence() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- getNumPurged() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
-
Get the number of tombstones that were purged.
- getNumReducePhases() - Method in class org.elasticsearch.action.search.SearchResponse
-
Returns the number of reduce phases applied to obtain this search response
- getNumReducePhases() - Method in class org.elasticsearch.action.search.SearchResponseSections
-
Returns the number of reduce phases applied to obtain this search response
- getObjectMapper() - Method in class org.elasticsearch.index.query.support.NestedScope
- getObjectMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
- getObjectMapper(String) - Method in class org.elasticsearch.index.query.QueryShardContext
- getObjectMapper(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getObjectMapper(String) - Method in class org.elasticsearch.search.internal.SearchContext
- getOffset() - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
-
Returns the offset in the nested array of objects in the source this hit
- getOffset() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- getOffsetGap(String) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- getOffsetSource(String) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
-
Forces the offset source for this highlighter
- getOffsetSource(MappedFieldType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- getOldIndex() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns the name of the index that the request alias was pointing to
- getOnFailureProcessors() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getOnFailureProcessors() - Method in class org.elasticsearch.ingest.Pipeline
-
Unmodifiable list containing each on_failure processor that operates on the data in case of exception thrown in pipeline processors
- getOnJoinValidators() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- getOnlyCause(Collection<Message>) - Static method in class org.elasticsearch.common.inject.internal.Errors
-
Returns the cause throwable if there is exactly one cause in
messages
. - getOp() - Method in enum org.elasticsearch.action.DocWriteResponse.Result
- getOpenContexts() - Method in class org.elasticsearch.index.search.stats.SearchStats
- getOpenFileDescriptorCount() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the number of opened file descriptors associated with the current process, or -1 if not supported.
- getOpenFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getOpenIndexOutput(String) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
- getOperationPrimaryTerm() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns the current operation primary term.
- getOperationPrimaryTerm() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the primary term that is currently being used to assign to operations
- getOperations() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- getOperationType() - Method in class org.elasticsearch.index.engine.Engine.Result
- getOptions() - Method in class org.elasticsearch.script.Script
- getOptions() - Method in class org.elasticsearch.script.StoredScriptSource
- getOptions() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- getOptions() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- getOpType() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The operation type ("index", "create" or "delete").
- getOrCompute() - Method in class org.elasticsearch.common.util.LazyInitializable
-
Returns a value that was created by
supplier
. - getOrConnect(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- getOrDefault(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- getOrDefault(String, PreBuiltAnalyzers) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
Get a pre built Analyzer by its name or fallback to the default one
- getOrDefault(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- getOrDefault(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- getOrder() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- getOrdinalMap() - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
-
Returns the underlying
OrdinalMap
for this fielddata or null if global ordinals are not needed (constant value or single segment). - getOrdinalMap() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- getOrdinalMap() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- getOrdinalMap() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
- getOrdinalsValues() - Method in interface org.elasticsearch.index.fielddata.AtomicOrdinalsFieldData
-
Return the ordinals values for the current atomic reader.
- getOrdinalsValues() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
- getOrdinalsValues() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVBytesAtomicFieldData
- getOriginalAliases() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
-
Returns the aliases as was originally specified by the user
- getOriginalIndices() - Method in class org.elasticsearch.action.search.SearchShardIterator
-
Returns the original indices associated with this shard iterator, specifically with the cluster that this shard belongs to.
- getOriginalIndices() - Method in class org.elasticsearch.search.SearchShardTarget
- getOriginNanoTime() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getOriginNanoTime() - Method in class org.elasticsearch.search.internal.SearchContext
- getOrRefresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Returns the currently cached object and potentially refreshes the cache before returning.
- getOs() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
Operating System level information.
- getOs() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
Operating System level statistics.
- getOs() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getOutgoingConnections() - Method in class org.elasticsearch.node.AdaptiveSelectionStats
-
Returns a map of node id to the outgoing search requests to that node
- getOutgoingRecoveries(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getOutputUnigrams() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- getOutputUnigramsIfNoShingles() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- getOverhead() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getOverhead() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getOverhead() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getOverhead() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getOverhead() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getOwnerType() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- getPackageName(Class<?>) - Static method in class org.elasticsearch.common.Classes
-
Determine the name of the package of the given class: e.g.
- getParameterIndex() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns the index of this dependency in the injection point's parameter list, or
-1
if this dependency does not belong to a parameter list. - getParameterTypes(Member) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic parameter types of
methodOrConstructor
. - getParams() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- getParams() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- getParams() - Method in class org.elasticsearch.script.BucketAggregationScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.BucketAggregationSelectorScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.FilterScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.IngestConditionalScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.IngestScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.ScoreScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.Script
- getParams() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- getParams() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- getParams() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- getParams() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- getParams() - Method in class org.elasticsearch.script.SearchScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.TemplateScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.TermsSetQueryScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.UpdateScript
-
Return the parameters for this script.
- getParent() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
Return the parent document, or null if this is the root document.
- getParent() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getParent() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The document id of the parent of the hit if there is a parent or null if there isn't.
- getParent() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
- getParentId(ParentFieldMapper, LeafReader, int) - Static method in class org.elasticsearch.search.fetch.subphase.ParentFieldSubFetchPhase
- getParentJoinFieldType() - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- getParentObjectMapper(MapperService) - Method in class org.elasticsearch.index.mapper.ObjectMapper
-
Returns the parent
ObjectMapper
instance of the specified object mapper ornull
if there isn't any. - getParentTask() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getParentTask() - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Get a reference to the task that created this request.
- getParentTask() - Method in class org.elasticsearch.transport.TransportRequest
-
Get a reference to the task that created this request.
- getParentTaskId() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
Returns the parent task id that tasks should be filtered by
- getParentTaskId() - Method in class org.elasticsearch.tasks.Task
-
Returns id of the parent task or NO_PARENT_ID if the task doesn't have any parent tasks
- getParentTaskId() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns the parent task id
- getParentTypes() - Method in class org.elasticsearch.index.mapper.MapperService
- getParseField() - Method in enum org.elasticsearch.script.ScriptType
- getParseField() - Method in enum org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
- getParser() - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- getParser() - Static method in class org.elasticsearch.ingest.PipelineConfiguration
- getParser() - Method in class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
The parser responsible for converting
XContent
into the behavior. - getParser(ParseFieldRegistry<SignificanceHeuristicParser>) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- getParser(ParseFieldRegistry<SignificanceHeuristicParser>) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- getPartialValue() - Method in exception org.elasticsearch.common.inject.ConfigurationException
-
Returns a value that was only partially computed due to this exception.
- getPassageFormatter(FetchSubPhase.HitContext, SearchContextHighlight.Field, Encoder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- getPassword() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getPath() - Method in class org.elasticsearch.cluster.DiskUsage
- getPath() - Method in class org.elasticsearch.common.PidFile
-
Returns the process id file path
- getPath() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
Return the path associated with this document.
- getPath() - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
-
Return the path of results of this query, or
null
if matches are at the root level. - getPath() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getPath() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- getPath(String) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- getPathElements() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- getPathElementsAsStringList() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- getPathPrefix() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getPatterns() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- getPatterns() - Method in class org.elasticsearch.common.settings.SettingsFilter
-
Returns a set of patterns
- getPb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getPbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getPeakCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
- getPeakMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getPeakUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getPending() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- getPending() - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- getPendingPrimaryTerm() - Method in class org.elasticsearch.index.shard.IndexShard
-
USE THIS METHOD WITH CARE! Returns the primary term the index shard is supposed to be on.
- getPendingSearchRequests() - Method in class org.elasticsearch.action.search.SearchTransportService
-
Return a map of nodeId to pending number of search requests.
- getPendingTasks() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
-
The pending cluster tasks
- getPercent() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
- getPercent() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
-
Get the Process cpu usage.
- getPercent() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.Percentile
- getPercentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentiles
- getPercentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentiles
- getPeriodic() - Method in class org.elasticsearch.index.flush.FlushStats
-
The number of flushes that were periodically triggered when translog exceeded the flush threshold.
- getPerNodeTasks() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Returns the list of tasks by node
- getPersistentSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
-
Returns the persistent settings for the cluster
- getPersistentSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- getPersistentTaskExecutorSafe(String) - Method in class org.elasticsearch.persistent.PersistentTasksExecutorRegistry
- getPersistentTaskId() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- getPersistentTasksCustomMetaData(ClusterState) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- getPersistentTasksExecutor(ClusterService, ThreadPool, Client, SettingsModule) - Method in interface org.elasticsearch.plugins.PersistentTaskPlugin
-
Returns additional persistent tasks executors added by this plugin.
- getPeta() - Method in class org.elasticsearch.common.unit.SizeValue
- getPetaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getPhase() - Method in class org.elasticsearch.action.support.replication.ReplicationTask
-
Get the current phase of the task.
- getPhase() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
Get the current phase of the task.
- getPhaseName() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- getPid() - Method in class org.elasticsearch.common.PidFile
-
Returns the current process id
- getPid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
The process id.
- getPingInterval() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the ping interval or
null
if no explicit ping interval is set on this profile. - getPingResponseHandler(UnicastZenPing.PingingRound, DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- getPipeline() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns the ingest pipeline to be executed before indexing the document
- getPipeline() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Ingest pipeline to set on index requests made by this action.
- getPipeline(String) - Method in class org.elasticsearch.ingest.IngestService
-
Returns the pipeline by the specified id
- getPipeline(GetPipelineRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a stored ingest pipeline
- getPipeline(GetPipelineRequest, ActionListener<GetPipelineResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a stored ingest pipeline
- GetPipelineAction - Class in org.elasticsearch.action.ingest
- GetPipelineAction() - Constructor for class org.elasticsearch.action.ingest.GetPipelineAction
- getPipelineAggregations() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
PipelineAggregator
s added by this plugin. - getPipelineAggregations() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return the configured set of pipeline aggregations
- getPipelineAggregatorFactories() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- getPipelineId() - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- getPipelineId() - Method in class org.elasticsearch.ingest.IngestStats.PipelineStat
- GetPipelineRequest - Class in org.elasticsearch.action.ingest
- GetPipelineRequest(String...) - Constructor for class org.elasticsearch.action.ingest.GetPipelineRequest
- GetPipelineRequestBuilder - Class in org.elasticsearch.action.ingest
- GetPipelineRequestBuilder(ElasticsearchClient, GetPipelineAction) - Constructor for class org.elasticsearch.action.ingest.GetPipelineRequestBuilder
- GetPipelineRequestBuilder(ElasticsearchClient, GetPipelineAction, String[]) - Constructor for class org.elasticsearch.action.ingest.GetPipelineRequestBuilder
- GetPipelineResponse - Class in org.elasticsearch.action.ingest
- GetPipelineResponse() - Constructor for class org.elasticsearch.action.ingest.GetPipelineResponse
- GetPipelineResponse(List<PipelineConfiguration>) - Constructor for class org.elasticsearch.action.ingest.GetPipelineResponse
- getPipelines() - Method in class org.elasticsearch.ingest.IngestMetadata
- getPipelines(ClusterState, String...) - Static method in class org.elasticsearch.ingest.IngestService
- getPipelineStats() - Method in class org.elasticsearch.ingest.IngestStats
- GetPipelineTransportAction - Class in org.elasticsearch.action.ingest
- GetPipelineTransportAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.ingest.GetPipelineTransportAction
- getPluginInfos() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
-
Returns an ordered list based on plugins name
- getPlugins() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- getPlugins() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getPluginSettings() - Method in class org.elasticsearch.plugins.PluginsService
- getPluginSettingsFilter() - Method in class org.elasticsearch.plugins.PluginsService
- getPluginsService() - Method in class org.elasticsearch.node.Node
-
The
PluginsService
used to build this node's components. - getPointReaderOrNull(SearchContext, Aggregator, ValuesSourceConfig<ValuesSource.Numeric>) - Static method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
-
Returns a converter for point values if early termination is applicable to the context or
null
otherwise. - getPointsMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getPointsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the points memory usage by a segment.
- getPort() - Method in class org.elasticsearch.common.transport.TransportAddress
-
Returns the addresses port
- getPort() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getPortRangeString() - Method in class org.elasticsearch.common.transport.PortsRange
- getPosition() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- getPositionIncrementGap() - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- getPositionLength() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- getPositions() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Returns the relative positions of terms in this phrase.
- getPostingsFormatForField(String) - Method in class org.elasticsearch.index.codec.PerFieldMappingPostingFormatCodec
- getPreBuiltAnalyzerProviderFactories() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional pre-configured
Analyzer
s. - getPrecision() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- getPrecision() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
-
Returns the precision (length) for the geohash
- getPreConfiguredCharFilters() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional pre-configured
CharFilter
s. - getPreConfiguredTokenFilters() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional pre-configured
TokenFilter
s. - getPreConfiguredTokenizers() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional pre-configured
Tokenizer
. - getPreferredName() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- getPreferredTargetNode() - Method in interface org.elasticsearch.transport.RemoteClusterAwareRequest
-
Returns the preferred discovery node for this request.
- getPreFilterShardSize() - Method in class org.elasticsearch.action.search.SearchRequest
-
Returns a threshold that enforces a pre-filter roundtrip to pre-filter search shards based on query rewriting if the number of shards the search request expands to exceeds the threshold.
- getPrefix() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
Return a prefix that all fields in this document should have.
- getPrefix() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getPrefixFieldType() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- getPrefixQuery(String, String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getPrettyName() - Method in class org.elasticsearch.monitor.os.OsInfo
- getPrimaries() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
total number of primary shards in the cluster
- getPrimaries() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getPrimaries() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getPrimary() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getPrimary() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getPrimaryTerm() - Method in class org.elasticsearch.action.DocWriteResponse
-
The primary term for this change.
- getPrimaryTerm() - Method in class org.elasticsearch.action.get.GetResponse
-
The primary term of the last primary that has changed this document, if found.
- getPrimaryTerm() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getPrimaryTerm() - Method in class org.elasticsearch.index.get.GetResult
-
The primary term of the last primary that has changed this document, if found.
- getPrimaryTerm() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getPrimaryTerm() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The primary term of the match or
SequenceNumbers.UNASSIGNED_PRIMARY_TERM
if sequence numbers weren't requested. - getPrimaryTerm() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
-
Returns the primary term associated with this translog reader.
- getPrimaryTerm() - Method in class org.elasticsearch.search.SearchHit
-
returns the primary term of the last modification to the document, or
SequenceNumbers.UNASSIGNED_PRIMARY_TERM
if not requested. - getPrimaryTermSupplier() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a supplier that supplies the latest primary term value of the associated shard.
- getPriority() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getPrivateElements() - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- getPrivateElements() - Method in interface org.elasticsearch.common.inject.spi.ExposedBinding
-
Returns the enclosed environment that holds the original binding.
- getProcess() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
Process level information.
- getProcess() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
Process level statistics.
- getProcess() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getProcessCpuPercent() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the process CPU usage in percent
- getProcessCpuTotalTime() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the CPU time (in milliseconds) used by the process on which the Java virtual machine is running, or -1 if not supported.
- getProcessedFileCount() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns number of files in the snapshot that were processed so far
- getProcessedFileCount() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getProcessedSize() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns total size of files in the snapshot that were processed so far
- getProcessedSize() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getProcessorFactories() - Method in class org.elasticsearch.ingest.IngestService
- getProcessorResults() - Method in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- getProcessors() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getProcessors() - Method in class org.elasticsearch.ingest.IngestInfo
- getProcessors() - Method in class org.elasticsearch.ingest.Pipeline
-
Unmodifiable list containing each processor that operates on the data.
- getProcessors(Processor.Parameters) - Method in interface org.elasticsearch.plugins.IngestPlugin
-
Returns additional ingest processor types added by this plugin.
- getProcessorStats() - Method in class org.elasticsearch.ingest.IngestStats
- getProcessorTag() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getProfile() - Method in interface org.elasticsearch.transport.TcpChannel
-
This returns the profile for this channel.
- getProfile() - Method in interface org.elasticsearch.transport.TcpServerChannel
-
This returns the profile for this channel.
- getProfileAddresses() - Method in class org.elasticsearch.transport.TransportInfo
- getProfileBreakdown(E) - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
Returns a
QueryProfileBreakdown
for a scoring query. - getProfiledChildren() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Returns a list of all profiled children queries
- getProfiledChildren() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- getProfileName() - Method in class org.elasticsearch.transport.TaskTransportChannel
- getProfileName() - Method in class org.elasticsearch.transport.TcpTransportChannel
- getProfileName() - Method in interface org.elasticsearch.transport.TransportChannel
- getProfileResults() - Method in class org.elasticsearch.action.search.SearchResponse
-
If profiling was enabled, this returns an object containing the profile results from each shard.
- getProfileResults() - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- getProfilers() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getProfilers() - Method in class org.elasticsearch.search.internal.SearchContext
-
Return a handle over the profilers for the current search request, or
null
if profiling is not enabled. - getProfileSettings(Settings) - Static method in class org.elasticsearch.transport.TcpTransport
-
Returns all profile settings for the given settings object
- getProperties() - Method in class org.elasticsearch.common.settings.Setting
-
Returns the setting properties
- getProperty(String) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Get the value of specified path in the aggregation.
- getProperty(String, List<String>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation.InternalBucket
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
- getProvidedKey() - Method in interface org.elasticsearch.common.inject.spi.ProviderBinding
-
Returns the key whose binding is used to
provide instances
. - getProvidedName() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
The name that was provided by the user.
- getProvider() - Method in interface org.elasticsearch.common.inject.Binding
-
Returns the scoped provider guice uses to fulfill requests for this binding.
- getProvider() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getProvider() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- getProvider() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
-
Returns the looked up provider.
- getProvider(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- getProvider(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the provider used to obtain instances for the given injection type.
- getProvider(Class<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the provider used to obtain instances for the given type.
- getProvider(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- getProvider(Class<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the provider used to obtain instances for the given injection type.
- getProvider(Key<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- getProvider(Key<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the provider used to obtain instances for the given injection key.
- getProvider(Key<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the provider used to obtain instances for the given injection key.
- getProvider(Key<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- getProvider(Key<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the provider used to obtain instances for the given injection key.
- getProviderInstance() - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- getProviderInstance() - Method in interface org.elasticsearch.common.inject.spi.ProviderInstanceBinding
-
Returns the user-supplied, unscoped provider.
- getProviderKey() - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- getProviderKey() - Method in interface org.elasticsearch.common.inject.spi.ProviderKeyBinding
-
Returns the key used to resolve the provider's binding.
- getProviderMethods(Binder) - Method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
- getProxyAction(String) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Returns the corresponding proxy action for the given action
- getPublishDiff() - Method in class org.elasticsearch.discovery.DiscoverySettings
- getPublishStats() - Method in class org.elasticsearch.discovery.DiscoveryStats
- getPublishTimeout() - Method in class org.elasticsearch.discovery.DiscoverySettings
-
Returns the current publish timeout
- getQueries() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
Query
s defined by this plugin. - getQuery() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getQueryBreakdown(E) - Method in class org.elasticsearch.search.profile.AbstractProfiler
-
Get the
AbstractProfileBreakdown
for the given element in the tree, potentially creating it if it did not exist. - getQueryBreakdown(Aggregator) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfiler
- getQueryBuilder() - Method in class org.elasticsearch.search.internal.AliasFilter
-
Returns the alias filter
QueryBuilder
ornull
if there is no such filter - getQueryCache() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getQueryCache() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getQueryCache() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Return the cache to use for queries.
- getQueryCache() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getQueryCachingPolicy() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Return the policy to use when caching queries.
- getQueryCachingPolicy() - Method in class org.elasticsearch.index.shard.IndexShard
- getQueryContent(XContentParser) - Static method in class org.elasticsearch.rest.action.RestActions
- getQueryContexts() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- getQueryCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getQueryCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getQueryExplanation() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
-
The list of query explanations.
- getQueryName() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Retrieve the name of the query (e.g.
- getQueryProfileResults() - Method in class org.elasticsearch.search.profile.ProfileShardResult
- getQueryProfilers() - Method in class org.elasticsearch.search.profile.Profilers
-
Return the list of all created
QueryProfiler
s so far. - getQueryResults() - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- getQueryShardContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getQueryShardContext() - Method in class org.elasticsearch.search.internal.SearchContext
- getQueryTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getQueryTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getQueryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Gets the original query weight for rescoring.
- getQueue() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getQueueSize() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getQueueStats() - Method in class org.elasticsearch.discovery.DiscoveryStats
- getRangeField(String, RangeFieldMapper.Range) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- getRangeQuery(String, String, String, boolean, boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getRanges() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Get the current list or ranges that are configured on this aggregation.
- getRanks() - Method in class org.elasticsearch.node.AdaptiveSelectionStats
-
Returns a map of node id to the ranking of the nodes based on the adaptive replica formula
- getRaw(Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns the raw (string) settings value.
- getRawCommitId() - Method in class org.elasticsearch.index.engine.CommitStats
-
A raw version of the commit id (see
SegmentInfos.getId()
- getRawDoubleValues() - Method in class org.elasticsearch.index.fielddata.NumericDoubleValues
-
Returns numeric docvalues view of raw double bits
- getRawFloatValues() - Method in class org.elasticsearch.index.fielddata.NumericDoubleValues
-
Returns numeric docvalues view of raw float bits
- getRawKey() - Method in class org.elasticsearch.common.settings.Setting
-
Returns the original representation of a setting key.
- getRawSortValues() - Method in class org.elasticsearch.search.SearchHit
-
An array of the (raw) sort values used.
- getRawSortValues() - Method in class org.elasticsearch.search.SearchSortValues
-
Returns the raw version of the values that sorting was performed against
- getRawType() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- getRawType() - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the raw (non-generic) type for this type.
- getRawType(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
- getReader() - Method in class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
The reader responsible for reading the behavior from the internode protocol.
- getReader(Class<T>, String) - Method in class org.elasticsearch.common.io.stream.NamedWriteableRegistry
-
Returns a reader for a
NamedWriteable
object identified by the name provided as argument and its category. - getReaderCacheHelper() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
- getReaderCacheHelper() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
- getReaderFromFile(Environment, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
- getReason() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
-
The reason for canceling the task.
- getReason() - Method in class org.elasticsearch.action.TaskOperationFailure
- getReason() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
The reason why the shard is unassigned.
- getReason() - Method in class org.elasticsearch.gateway.GatewayMetaState.IndexMetaWriteInfo
- getReason() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getReason() - Method in class org.elasticsearch.persistent.decider.AssignmentDecision
- getReason() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- getReason() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getReasonCancelled() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
The reason that the request was canceled or null if it hasn't been.
- getReasonCancelled() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
The reason that the request was canceled or null if it hasn't been.
- getReasonCancelled() - Method in class org.elasticsearch.tasks.CancellableTask
-
The reason the task was cancelled or null if it hasn't been cancelled.
- getRecovery(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
gets the
RecoveryTarget
for a given id. - getRecoverySafe(long, ShardId) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
Similar to
RecoveriesCollection.getRecovery(long)
but throws an exception if no recovery is found - getRecoverySource() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getRecoveryStats() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getRecoveryStats() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getRecoveryTarget(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
- getReferenceManager(Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.Engine
- getReferenceManager(Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.InternalEngine
- getReferenceManager(Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getRefresh() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getRefresh() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getRefreshInterval() - Method in class org.elasticsearch.index.IndexSettings
-
Returns this interval in which the shards of this index are asynchronously refreshed.
- getRefreshInterval() - Method in class org.elasticsearch.monitor.os.OsInfo
- getRefreshInterval() - Method in class org.elasticsearch.monitor.process.ProcessInfo
- getRefreshPolicy() - Method in class org.elasticsearch.action.bulk.BulkRequest
- getRefreshPolicy() - Method in class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- getRefreshPolicy() - Method in interface org.elasticsearch.action.support.WriteRequest
-
Should this request trigger a refresh (WriteRequest.RefreshPolicy.IMMEDIATE), wait for a refresh ( WriteRequest.RefreshPolicy.WAIT_UNTIL), or proceed ignore refreshes entirely (WriteRequest.RefreshPolicy.NONE, the default).
- getRefreshPolicy() - Method in class org.elasticsearch.action.update.UpdateRequest
- getRegex() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getRegexOptions() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- getRegexpQuery(String, String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getRegisteredRemoteClusterNames() - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns the registered remote cluster names.
- getRegisteredSettings() - Method in class org.elasticsearch.threadpool.AutoQueueAdjustingExecutorBuilder
- getRegisteredSettings() - Method in class org.elasticsearch.threadpool.ExecutorBuilder
-
The list of settings this builder will register.
- getRegisteredSettings() - Method in class org.elasticsearch.threadpool.FixedExecutorBuilder
- getRegisteredSettings() - Method in class org.elasticsearch.threadpool.ScalingExecutorBuilder
- getRegistry() - Method in class org.elasticsearch.common.NamedRegistry
- getRejected() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getRelation(QueryRewriteContext) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- getRelationByName(String) - Static method in enum org.elasticsearch.common.geo.ShapeRelation
- getRelationName() - Method in enum org.elasticsearch.common.geo.ShapeRelation
- getRelevantIndices(ClusterState, ClusterState, Set<Index>) - Static method in class org.elasticsearch.gateway.GatewayMetaState
- getRelevantIndicesForMasterEligibleNode(ClusterState) - Static method in class org.elasticsearch.gateway.GatewayMetaState
- getRelevantIndicesOnDataOnlyNode(ClusterState, ClusterState, Set<Index>) - Static method in class org.elasticsearch.gateway.GatewayMetaState
- getRelocatingShardCount() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getRelocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getRelocatingShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getRelocatingShards() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getRelocatingShards() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getRelocationId() - Method in class org.elasticsearch.cluster.routing.AllocationId
-
The transient relocation id holding the unique id that is used for relocation.
- getRelocationTargetNode() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the relocating target node, or
null
if the shard is not in theShardRoutingState.RELOCATING
state. - getRemainingDelay(long, Settings) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Calculates the delay left based on current time (in nanoseconds) and the delay defined by the index settings.
- getRemainingDelayInMillis() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Gets the remaining delay for allocating the replica shard when a node holding the replica left the cluster and the deciders are waiting to see if the node returns before allocating the replica elsewhere.
- getRemoteAddress() - Method in class org.elasticsearch.rest.RestRequest
- getRemoteAddress() - Method in interface org.elasticsearch.transport.TcpChannel
-
Returns the remote address for this channel.
- getRemoteClusterClient(String) - Method in interface org.elasticsearch.client.Client
-
Returns a client to a remote cluster with the given cluster alias.
- getRemoteClusterClient(String) - Method in class org.elasticsearch.client.FilterClient
- getRemoteClusterClient(String) - Method in class org.elasticsearch.client.node.NodeClient
- getRemoteClusterClient(ThreadPool, String) - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns a client to the remote cluster if the given cluster alias exists.
- getRemoteClusterService() - Method in class org.elasticsearch.action.search.SearchTransportService
- getRemoteClusterService() - Method in class org.elasticsearch.transport.TransportService
- getRemoteConnectionInfos(ActionListener<Collection<RemoteConnectionInfo>>) - Method in class org.elasticsearch.transport.RemoteClusterService
- getRemoteInfo() - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Get the
RemoteInfo
if it was set for this request. - getRemovalReason() - Method in class org.elasticsearch.common.cache.RemovalNotification
- getRemovedCount() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
-
The number of index tombstones that were removed between two states
- getReplication() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
returns how many *redundant* copies of the data the cluster holds - running with no replicas will return 0
- getReplicationGroup() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the current replication group on the primary shard
- getReplicationGroup() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns the current replication group for the shard.
- getReplicationGroup() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the current replication group for the shard.
- getReplicationTargets() - Method in class org.elasticsearch.index.shard.ReplicationGroup
-
Returns the subset of shards in the routing table that should be replicated to.
- getRepositories(GetRepositoriesRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Gets repositories.
- getRepositories(GetRepositoriesRequest, ActionListener<GetRepositoriesResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Gets repositories.
- getRepositories(Environment, NamedXContentRegistry) - Method in interface org.elasticsearch.plugins.RepositoryPlugin
-
Returns repository types added by this plugin.
- GetRepositoriesAction - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Get repositories action
- GetRepositoriesRequest - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Get repository request
- GetRepositoriesRequest() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
- GetRepositoriesRequest(String[]) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
-
Constructs a new get repositories request with a list of repositories.
- GetRepositoriesRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Get repository request builder
- GetRepositoriesRequestBuilder(ElasticsearchClient, GetRepositoriesAction) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Creates new get repository request builder
- GetRepositoriesRequestBuilder(ElasticsearchClient, GetRepositoriesAction, String...) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Creates new get repository request builder
- GetRepositoriesResponse - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Get repositories response
- getRepositoriesService() - Method in class org.elasticsearch.snapshots.SnapshotsService
- getRepository() - Method in class org.elasticsearch.snapshots.Snapshot
-
Gets the repository name for the snapshot.
- getRepositoryData() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getRepositoryData() - Method in class org.elasticsearch.repositories.FilterRepository
- getRepositoryData() - Method in interface org.elasticsearch.repositories.Repository
-
Returns a
RepositoryData
to describe the data in the repository, including the snapshots and the indices across all snapshots found in the repository. - getRepositoryData(String) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Gets the
RepositoryData
for the given repository. - getRepositoryName() - Method in exception org.elasticsearch.snapshots.SnapshotException
- getRepositoryRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Gets snapshot repository
- getRepositoryStateId() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
-
The repository state id at the time the snapshot deletion began.
- getRepositoryStateId() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- getRequest() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getRequest() - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- getRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a get request to get the JSON source from an index based on a type and id.
- GetRequest - Class in org.elasticsearch.action.get
-
A request to get a document (its source) from an index based on its type (optional) and id.
- GetRequest() - Constructor for class org.elasticsearch.action.get.GetRequest
- GetRequest(String) - Constructor for class org.elasticsearch.action.get.GetRequest
-
Constructs a new get request against the specified index.
- GetRequest(String, String, String) - Constructor for class org.elasticsearch.action.get.GetRequest
-
Constructs a new get request against the specified index with the type and id.
- GetRequestBuilder - Class in org.elasticsearch.action.get
-
A get document action request builder.
- GetRequestBuilder(ElasticsearchClient, GetAction) - Constructor for class org.elasticsearch.action.get.GetRequestBuilder
- GetRequestBuilder(ElasticsearchClient, GetAction, String) - Constructor for class org.elasticsearch.action.get.GetRequestBuilder
- getRequestCache() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getRequestCache() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getRequestHandler(String) - Method in class org.elasticsearch.transport.TcpTransport
- getRequestHandler(String) - Method in interface org.elasticsearch.transport.Transport
-
Returns the registered request handler registry for the given action or
null
if it's not registered - getRequestHandler(String) - Method in class org.elasticsearch.transport.TransportService
- getRequestId() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- getRequestId() - Method in class org.elasticsearch.search.SearchPhaseResult
-
Returns the results request ID that is used to reference the search context on the executing node
- getRequestId() - Method in class org.elasticsearch.transport.NetworkMessage
- getRequests() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- getRequestsPerSecond() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The throttle for this request in sub-requests per second.
- getRequestsPerSecond() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
The number of requests per second to which to throttle the request.
- getRequiredFeature() - Method in interface org.elasticsearch.cluster.ClusterState.FeatureAware
-
An optional feature that is required for the client to have.
- getRequiredMappingUpdate() - Method in class org.elasticsearch.index.engine.Engine.Result
-
If the operation was aborted due to missing mappings, this method will return the mappings that are required to complete the operation.
- getRequiredSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- getRerouteInterval() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getRescoreQuery() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- getRescoreQueryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Gets the original query weight for rescoring.
- getRescorers() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The next
Rescorer
s added by this plugin. - getResizeSourceIndex() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getResizeType() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Returns the type of the resize operation
- getResizeType() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestShrinkIndexAction
- getResizeType() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestSplitIndexAction
- getResourceId() - Method in exception org.elasticsearch.ElasticsearchException
- getResourceType() - Method in exception org.elasticsearch.ElasticsearchException
- getResponse() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The actual response (
IndexResponse
orDeleteResponse
). - getResponse() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The actual get response,
null
if its a failure. - getResponse() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
-
The actual search response, null if its a failure.
- getResponse() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The actual get response,
null
if its a failure. - getResponse() - Method in class org.elasticsearch.tasks.TaskResult
-
Get the response that this task finished with.
- GetResponse - Class in org.elasticsearch.action.get
-
The response of a get action.
- GetResponse(GetResult) - Constructor for class org.elasticsearch.action.get.GetResponse
- getResponseAsMap() - Method in class org.elasticsearch.tasks.TaskResult
-
Convert
TaskResult.getResponse()
from XContent to a Map for easy processing. - getResponseCollectorService() - Method in class org.elasticsearch.search.SearchService
- getResponseHandlers() - Method in class org.elasticsearch.transport.TcpTransport
- getResponseHandlers() - Method in interface org.elasticsearch.transport.Transport
- getResponseHeaders() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Get a copy of all response headers.
- getResponseReader() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
- getResponseReader() - Method in class org.elasticsearch.action.GenericAction
-
Get a reader that can create a new instance of the class from a
StreamInput
- getResponseResult() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- getResponses() - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- getResponses() - Method in class org.elasticsearch.action.get.MultiGetResponse
- getResponses() - Method in class org.elasticsearch.action.search.MultiSearchResponse
-
The list of responses, the order is the same as the one provided in the request.
- getResponses() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- getRestController() - Method in class org.elasticsearch.action.ActionModule
- getRestHandlers(Settings, RestController, ClusterSettings, IndexScopedSettings, SettingsFilter, IndexNameExpressionResolver, Supplier<DiscoveryNodes>) - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Rest handlers added by this plugin.
- getRestHandlerWrapper(ThreadContext) - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Returns a function used to wrap each rest request before handling the request.
- getRestHeaders() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Returns headers which should be copied through rest requests on to internal requests.
- getRestName() - Method in enum org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- getRestoreInfo() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
-
Returns restore information if snapshot was completed before this method returned, null otherwise
- getRestoreInfo() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreCompletionResponse
- getRestoreThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getRestoreThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.FilterRepository
- getRestoreThrottleTimeInNanos() - Method in interface org.elasticsearch.repositories.Repository
-
Returns restore throttle time in nanoseconds
- getRestUsage() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- getResult() - Method in class org.elasticsearch.action.DocWriteResponse
-
The change that occurred to the document.
- GetResult - Class in org.elasticsearch.index.get
- GetResult(String, String, String, long, long, long, boolean, BytesReference, Map<String, DocumentField>) - Constructor for class org.elasticsearch.index.get.GetResult
- GetResult(Engine.Searcher, VersionsAndSeqNoResolver.DocIdAndVersion) - Constructor for class org.elasticsearch.index.engine.Engine.GetResult
-
Build a non-realtime get result from the searcher.
- getResultReaders() - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Get the readers that must be registered for this aggregation's results.
- getResultReaders() - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Get the readers that must be registered for this aggregation's results.
- getResults() - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- getResultType() - Method in class org.elasticsearch.index.engine.Engine.Result
-
whether the operation was successful, has failed or was aborted due to a mapping update
- getResyncedOperations() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
number of operations that have been successfully replicated
- getRetentionLeaseMillis() - Method in class org.elasticsearch.index.IndexSettings
-
The maximum age of a retention lease before it is considered expired.
- getRetentionLeases() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Get all retention leases tracked on this shard.
- getRetentionLeases() - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- getRetentionLeases() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- getRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Get all retention leases tracked on this shard.
- getRetentionLeases(boolean) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
If the expire leases parameter is false, gets all retention leases tracked on this shard and otherwise first calculates expiration of existing retention leases, and then gets all non-expired retention leases tracked on this shard.
- getRetentionLeases(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
If the expire leases parameter is false, gets all retention leases tracked on this shard and otherwise first calculates expiration of existing retention leases, and then gets all non-expired retention leases tracked on this shard.
- getRetentionLeaseStats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
-
Gets the current retention lease stats.
- getRetentionLeaseStats() - Method in class org.elasticsearch.index.shard.IndexShard
- getRetryBackoffInitialTime() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Initial delay after a rejection before retrying request.
- getReturnType(Method) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic return type of
method
. - getRewriteable() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- getRewriteable() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- getRewriteable() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- getRewriteContext(LongSupplier) - Method in class org.elasticsearch.indices.IndicesService
-
Returns a new
QueryRewriteContext
with the givennow
provider - getRewriteContext(LongSupplier) - Method in class org.elasticsearch.search.SearchService
-
Returns a new
QueryRewriteContext
with the givennow
provider - getRewriteTime() - Method in class org.elasticsearch.search.profile.query.QueryProfiler
- getRewriteTime() - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- getRoleName() - Method in enum org.elasticsearch.cluster.node.DiscoveryNode.Role
- getRoles() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
- getRoles() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Returns a set of all the roles that the node fulfills.
- getRolesFromSettings(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
extract node roles from the given settings
- getRolloverInfo(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- getRolloverInfos() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getRootCause() - Method in exception org.elasticsearch.ElasticsearchException
-
Retrieve the innermost cause of this exception, if none, returns the current exception.
- getRootDataPath() - Method in class org.elasticsearch.index.shard.ShardPath
-
Returns the data-path root for this shard.
- getRootFilter() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
- getRootStatePath() - Method in class org.elasticsearch.index.shard.ShardPath
-
Returns the state-path root for this shard.
- getRoughEstimateDurationMillis() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- getRouting() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Gets the routing value used for this request
- getRouting() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getRouting() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The routing on the hit if there is any or null if there isn't.
- getRouting() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Gets the routing value used for this request
- getRoutingEntry() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
-
The shard routing entry for the failed shard.
- getRoutingFactor() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Returns the routing factor for this index.
- getRoutingFactor(int, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Returns the routing factor for and shrunk index with the given number of target shards.
- getRoutingNodes() - Method in class org.elasticsearch.cluster.ClusterState
-
Returns a built (on demand) routing nodes view of the routing table.
- getRoutingNumShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
Returns number of shards that should be used for routing.
- getRoutingNumShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Returns the number of shards that should be used for routing.
- getRoutingPartitionSize() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getRoutingTable() - Method in class org.elasticsearch.cluster.ClusterState
- getRoutingTable() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- getRoutingTable() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- getRows() - Method in class org.elasticsearch.common.Table
- getRulesFromSettings(Environment) - Method in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- getRunningTimeNanos() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns the task running time
- getRxCount() - Method in class org.elasticsearch.transport.TransportStats
- getRxSize() - Method in class org.elasticsearch.transport.TransportStats
- getSafe(Index) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- getScheme() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getScope() - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- getScope() - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
- getScopeAnnotation() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns the scope annotation, or
null
if that isn't known for this instance. - getScopedSettings() - Method in class org.elasticsearch.index.IndexSettings
- getScopeInstance() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns the scope instance, or
null
if that isn't known for this instance. - getScoping() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getScore() - Method in class org.apache.lucene.search.uhighlight.Snippet
- getScore() - Method in class org.elasticsearch.script.SearchScript
-
Return the score of the current document.
- getScore() - Method in class org.elasticsearch.search.SearchHit
-
The score.
- getScore() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
-
Calculates Chi^2 see "Information Retrieval", Manning et al., Eq.
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
-
Calculates Google Normalized Distance, as described in "The Google Similarity Distance", Cilibrasi and Vitanyi, 2007 link: http://arxiv.org/pdf/cs/0412098v3.pdf
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
-
Calculates the significance of a term in a sample against a background of normal distributions by comparing the changes in frequency.
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
-
Calculates mutual information see "Information Retrieval", Manning et al., Eq.
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
-
Indicates the significance of a term in a sample by determining what percentage of all occurrences of a term are found in the sample.
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
-
Calculates score with a script
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristic
- getScoreFunction() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- getScoreFunction() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- getScoreFunctions() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
ScoreFunction
s defined by this plugin. - getScoreMode() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Gets the original query score mode.
- getScoreTerm(Term) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getScript() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- getScript() - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
-
Script to modify the documents before they are processed.
- getScript() - Method in exception org.elasticsearch.script.ScriptException
-
Returns the identifier for which script.
- getScript() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getScript() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getScriptEngine(Settings, Collection<ScriptContext<?>>) - Method in interface org.elasticsearch.plugins.ScriptPlugin
-
Returns a
ScriptEngine
instance ornull
if this plugin doesn't add a new script engine. - getScriptFields() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getScriptService() - Method in class org.elasticsearch.index.IndexService
-
The
ScriptService
to use for this index. - getScriptService() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Return the script service to allow compiling scripts.
- getScriptService() - Method in class org.elasticsearch.ingest.IngestService
- getScriptService() - Method in class org.elasticsearch.script.ScriptModule
-
Service responsible for managing scripts.
- getScriptStack() - Method in exception org.elasticsearch.script.ScriptException
-
Returns the stacktrace for the error in the script.
- getScriptStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getScriptValues() - Method in interface org.elasticsearch.index.fielddata.AtomicFieldData
-
Returns field values for use in scripting.
- getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractAtomicGeoPointFieldData
- getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractAtomicOrdinalsFieldData
- getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVAtomicFieldData
- getScrollCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getScrollCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getScrollId() - Method in class org.elasticsearch.action.search.SearchResponse
-
If scrolling was enabled (
SearchRequest.scroll(org.elasticsearch.search.Scroll)
, the scroll id that can be used to continue scrolling. - getScrollId() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
The scroll id used to fetch the next set of documents.
- getScrollIds() - Method in class org.elasticsearch.action.search.ClearScrollRequest
- getScrollTime() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Get scroll timeout
- getScrollTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getScrollTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSearch() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getSearch() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getSearchAnalyzer(MappedFieldType) - Method in class org.elasticsearch.index.query.QueryShardContext
-
Gets the search analyzer for the given field, or the default if there is none present for the field TODO: remove this by moving defaults into mappers themselves
- getSearchExt(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getSearchExt(String) - Method in class org.elasticsearch.search.internal.SearchContext
- getSearchExts() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
SearchExtBuilder
s defined by this plugin. - getSearchFailures() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
All search failures.
- getSearchOperationListener() - Method in class org.elasticsearch.index.shard.IndexShard
- getSearchQuoteAnalyzer(MappedFieldType) - Method in class org.elasticsearch.index.query.QueryShardContext
-
Gets the search quote analyzer for the given field, or the default if there is none present for the field TODO: remove this by moving defaults into mappers themselves
- getSearchRequest() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The search request that matches the documents to process.
- getSearchRetries() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
The number of times that the request had retry search actions.
- getSearchRetries() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of retries that had to be attempted due to search actions being rejected.
- getSearchRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- getSearchShardTarget() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- getSearchShardTarget() - Method in class org.elasticsearch.search.SearchPhaseResult
- getSearchSimilarity() - Method in class org.elasticsearch.index.query.QueryShardContext
- getSecond() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getSecondOfDay() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getSecondOfMinute() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getSecureMungedAddress() - Static method in class org.elasticsearch.common.MacAddressProvider
- getSecureSettings() - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Return the current secure settings, or
null
if none have been set. - getSeed() - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- getSeedAddresses() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- getSeedNodes() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- getSegmentName(MergePolicy.OneMerge) - Static method in class org.apache.lucene.index.OneMergeHelper
- getSegments() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getSegments() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- getSegments() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getSegments() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getSegmentsFile() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the segments file that this metadata snapshot represents or null if the snapshot is empty.
- getSegmentSort() - Method in class org.elasticsearch.index.engine.Segment
-
Return the sort order of this segment, or null if the segment has no sort.
- getSentence(Locale, int) - Static method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
-
Returns a
BreakIterator.getSentenceInstance(Locale)
bounded to maxLen. - getSeqNo() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The operation sequence number generated by primary NOTE:
SequenceNumbers.UNASSIGNED_SEQ_NO
indicates sequence number was not generated by primary - getSeqNo() - Method in class org.elasticsearch.action.DocWriteResponse
-
Returns the sequence number assigned for this change.
- getSeqNo() - Method in class org.elasticsearch.action.get.GetResponse
-
The sequence number assigned to the last operation that has changed this document, if found.
- getSeqNo() - Method in class org.elasticsearch.index.engine.Engine.Result
-
Get the sequence number on the primary.
- getSeqNo() - Method in class org.elasticsearch.index.get.GetResult
-
The sequence number assigned to the last operation that has changed this document, if found.
- getSeqNo() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getSeqNo() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The sequence number of the match or
SequenceNumbers.UNASSIGNED_SEQ_NO
if sequence numbers weren't requested. - getSeqNo() - Method in class org.elasticsearch.search.SearchHit
-
returns the sequence number of the last modification to the document, or
SequenceNumbers.UNASSIGNED_SEQ_NO
if not requested. - getSeqNoStats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- getSeqNoStats(long) - Method in class org.elasticsearch.index.engine.Engine
- getSeqNoStats(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- getSeqNoStats(long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getServerOpen() - Method in class org.elasticsearch.http.HttpStats
- getServerOpen() - Method in class org.elasticsearch.transport.TransportStats
- getService() - Method in class org.elasticsearch.index.shard.IndexShard
- getSetting() - Method in interface org.elasticsearch.common.settings.SettingUpgrader
-
The setting upgraded by this upgrader.
- getSetting(String) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
-
Returns the string value of the setting for the specified index.
- getSetting(String, String) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
-
Returns the string value for the specified index and setting.
- getSetting(String, String) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
Returns the string value for the specified index and setting.
- getSettingNames() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
It is possible to retrieve the setting names even if the keystore is closed.
- getSettingNames() - Method in interface org.elasticsearch.common.settings.SecureSettings
-
Returns the names of all secure settings available.
- getSettings() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
The settings of the node.
- getSettings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getSettings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getSettings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- getSettings() - Method in class org.elasticsearch.cluster.service.ClusterService
-
The node's settings.
- getSettings() - Method in class org.elasticsearch.common.settings.SettingsModule
- getSettings() - Method in class org.elasticsearch.index.IndexModule
-
Returns the index
Settings
for this index - getSettings() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the settings for this index.
- getSettings() - Method in class org.elasticsearch.plugins.Plugin
-
Returns a list of additional
Setting
definitions for this plugin. - getSettings(GetSettingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Executed a per index settings get request.
- getSettings(GetSettingsRequest, ActionListener<GetSettingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Executed a per index settings get request and returns the settings for the indices specified.
- GetSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.get
- GetSettingsAction() - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
- getSettingsDependencies(String) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
- getSettingsDependencies(String) - Method in class org.elasticsearch.common.settings.Setting
-
Returns a set of settings that are required at validation time.
- getSettingsFilter() - Method in class org.elasticsearch.common.settings.SettingsModule
- getSettingsFilter() - Method in class org.elasticsearch.plugins.Plugin
-
Returns a list of additional settings filter for this plugin
- getSettingsFromIndexSettings(IndexSettings, String) - Static method in class org.elasticsearch.index.analysis.AnalysisRegistry
- getSettingsKey() - Method in enum org.elasticsearch.index.IndexModule.Type
- GetSettingsRequest - Class in org.elasticsearch.action.admin.indices.settings.get
- GetSettingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- GetSettingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.settings.get
- GetSettingsRequestBuilder(ElasticsearchClient, GetSettingsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
- GetSettingsResponse - Class in org.elasticsearch.action.admin.indices.settings.get
- GetSettingsResponse(ImmutableOpenMap<String, Settings>, ImmutableOpenMap<String, Settings>) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- getSettingsVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getSettingUpgraders() - Method in class org.elasticsearch.plugins.Plugin
-
Get the setting upgraders provided by this plugin.
- getShapeAt(int) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- getShapeWriteables() - Static method in enum org.elasticsearch.common.geo.GeoShapeType
- getShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns the shard id of the shard to explain, or
null
to use any unassigned shard (seeClusterAllocationExplainRequest.useAnyUnassignedShard()
). - getShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the shard that the explanation is about.
- getShard() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- getShard() - Method in class org.elasticsearch.search.SearchHit
-
The shard of the search hit.
- getShard(int) - Method in class org.elasticsearch.index.IndexService
-
Return the shard with the provided id, or throw an exception if it doesn't exist.
- getShardAllocationDecision() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
\ Returns the shard allocation decision for attempting to assign or move the shard.
- getShardBalance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
Returns the shard related weight factor.
- getShardContext() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getShardFailures() - Method in class org.elasticsearch.action.search.SearchResponse
-
The failures that occurred during the search.
- getShardFailures() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The list of shard failures exception.
- getShardId() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- getShardId() - Method in class org.elasticsearch.action.admin.indices.segments.IndexShardSegments
- getShardId() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getShardId() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getShardId() - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- getShardId() - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- getShardId() - Method in class org.elasticsearch.action.DocWriteResponse
-
The exact shard the document was changed in.
- getShardId() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- getShardId() - Method in class org.elasticsearch.action.update.UpdateRequest
- getShardId() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- getShardId() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getShardId() - Method in class org.elasticsearch.cluster.routing.allocation.StaleShard
-
The shard id of the stale shard.
- getShardId() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the shards id
- getShardId() - Method in exception org.elasticsearch.ElasticsearchException
- getShardId() - Method in class org.elasticsearch.env.ShardLock
-
Returns the locks shards Id.
- getShardId() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- getShardId() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the engines shard ID
- getShardId() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Returns the shard ID this context was created for.
- getShardId() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getShardId() - Method in class org.elasticsearch.index.shard.ShardPath
- getShardId() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the shard ID this config is created for
- getShardId() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- getShardId() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getShardId() - Method in class org.elasticsearch.search.SearchShardTarget
- getShardId(Object) - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Return the
ShardId
that holds the given segment, ornull
if this segment is not tracked. - getShardIndex() - Method in class org.elasticsearch.search.SearchPhaseResult
-
Returns the shard index in the context of the currently executing search request that is used for accounting on the coordinating node
- getShardInfo() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse
- getShardMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- getShardOrNull(int) - Method in class org.elasticsearch.index.IndexService
-
Return the shard with the provided id, or null if there is no such shard.
- getShardOrNull(int) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Returns shard with given id.
- getShardOrNull(ShardId) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Returns shard for the specified id if it exists otherwise returns
null
. - getShardResults() - Method in class org.elasticsearch.search.profile.SearchProfileShardResults
- getShardRouting() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- getShardRouting() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
-
The shard routing information (cluster wide shard state).
- getShardRouting() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- getShardRoutings() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- getShardRoutings() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
Returns the
ShardRouting
s that this shards iterator holds. - getShards() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- getShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
A shard id to index snapshot shard status map
- getShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns list of snapshot shards
- getShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getShards() - Method in class org.elasticsearch.action.admin.indices.segments.IndexSegments
-
A shard id to index shard segments map (note, index shard segments is the replication shard group that maps to the shard id).
- getShards() - Method in class org.elasticsearch.action.admin.indices.segments.IndexShardSegments
- getShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getShards() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getShards() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
-
A shard id to index shard upgrade status map (note, index shard upgrade status is the replication shard group that maps to the shard id).
- getShards() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- getShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getShards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- getShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of shards - getShards(ClusterState, String, int, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- getShards(ClusterState, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- getShardsAllocators(Settings, ClusterSettings) - Method in interface org.elasticsearch.plugins.ClusterPlugin
-
Return
ShardsAllocator
implementations added by this plugin. - getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getShardSize() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getShardSize(ShardRouting) - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns the shard size for the given shard routing or
null
it that metric is not available. - getShardSize(ShardRouting, long) - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns the shard size for the given shard routing or
defaultValue
it that metric is not available. - getShardSnapshotStatus(SnapshotId, Version, IndexId, ShardId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getShardSnapshotStatus(SnapshotId, Version, IndexId, ShardId) - Method in class org.elasticsearch.repositories.FilterRepository
- getShardSnapshotStatus(SnapshotId, Version, IndexId, ShardId) - Method in interface org.elasticsearch.repositories.Repository
-
Retrieve shard snapshot status for the stored snapshot
- getShardsResultPerIndex() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- getShardsStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
Shards stats
- getShardsStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- getShardState() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the current
ShardRoutingState
of the shard. - getShardStatePath() - Method in class org.elasticsearch.index.shard.ShardPath
- getShardStoreInfo() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
Get the shard store information for the node, if it exists.
- getShardWritingBytes(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
returns how many bytes this shard is currently writing to disk
- getShouldStoreResult() - Method in class org.elasticsearch.action.ActionRequest
-
Should this task store its result after it has finished?
- getShouldStoreResult() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- getSigma() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getSignificanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- getSignificanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- getSignificanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- getSignificanceHeuristicParserRegistry() - Method in class org.elasticsearch.search.SearchModule
-
The registry of
SignificanceHeuristic
s. - getSignificanceHeuristics() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
SignificanceHeuristic
s defined by this plugin. - getSignificanceScore() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- getSignificanceScore() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- getSignificanceScore() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
- getSimilarity() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getSimilarity() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- getSimilarity() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the
Similarity
used for indexing and searching. - getSimilarity(String) - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- getSimilarity(String) - Method in class org.elasticsearch.index.similarity.SimilarityService
- getSinceTime() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- getSingles() - Method in class org.elasticsearch.common.unit.SizeValue
- getSize() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the number of known nodes
- getSize() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the number of this shards instances.
- getSize() - Method in class org.elasticsearch.index.engine.Segment
- getSize() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getSize() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Maximum number of processed documents.
- getSize() - Method in class org.elasticsearch.index.store.StoreStats
- getSize() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- getSize() - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- getSize() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- getSize() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getSizeInBytes() - Method in class org.elasticsearch.index.engine.Segment
- getSizeInBytes() - Method in class org.elasticsearch.index.store.StoreStats
- getSizeInBytes() - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- getSkipped() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
-
Returns how many total clusters were during the execution of the search request
- getSkippedOperations() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
number of translog operations that have been skipped
- getSkippedShards() - Method in class org.elasticsearch.action.search.SearchResponse
-
The number of shards skipped due to pre-filtering
- getSkippedShards() - Method in class org.elasticsearch.index.shard.ReplicationGroup
-
Returns the subset of shards in the routing table that are unassigned or initializing and not ready yet to receive operations (i.e.
- getSlices() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The number of slices this task should be divided into.
- getSlices() - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Returns the number of slices this BulkByScrollRequest will use
- getSliceStatuses() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Statuses of the sub requests into which this sub-request was sliced.
- getSlop() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Sets the phrase slop for this query.
- getSmallestNonClientNodeVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the oldest version in the cluster that is not a client node If there are no non-client nodes, Version.CURRENT will be returned.
- getSnapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns snapshot
- getSnapshot() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
-
The snapshot to delete.
- getSnapshot() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreCompletionResponse
- getSnapshotGlobalMetaData(SnapshotId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getSnapshotGlobalMetaData(SnapshotId) - Method in class org.elasticsearch.repositories.FilterRepository
- getSnapshotGlobalMetaData(SnapshotId) - Method in interface org.elasticsearch.repositories.Repository
-
Returns global metadata associated with the snapshot.
- getSnapshotId() - Method in class org.elasticsearch.snapshots.Snapshot
-
Gets the snapshot id for the snapshot.
- getSnapshotIds() - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns an unmodifiable collection of the snapshot ids.
- getSnapshotIndexMetaData(SnapshotId, IndexId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getSnapshotIndexMetaData(SnapshotId, IndexId) - Method in class org.elasticsearch.repositories.FilterRepository
- getSnapshotIndexMetaData(SnapshotId, IndexId) - Method in interface org.elasticsearch.repositories.Repository
-
Returns the index metadata associated with the snapshot.
- getSnapshotInfo() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
-
Returns snapshot information if snapshot was completed by the time this method returned or null otherwise.
- getSnapshotInfo(SnapshotId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getSnapshotInfo(SnapshotId) - Method in class org.elasticsearch.repositories.FilterRepository
- getSnapshotInfo(SnapshotId) - Method in interface org.elasticsearch.repositories.Repository
-
Reads snapshot description from repository.
- getSnapshotName() - Method in exception org.elasticsearch.snapshots.SnapshotException
- getSnapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
-
Returns the list of snapshots
- getSnapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
-
Returns the list of snapshots
- getSnapshots(GetSnapshotsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot.
- getSnapshots(GetSnapshotsRequest, ActionListener<GetSnapshotsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot.
- getSnapshots(IndexId) - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns an immutable collection of the snapshot ids for the snapshots that contain the given index.
- GetSnapshotsAction - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshots action
- getSnapshotsRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Gets snapshots from repository
- GetSnapshotsRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshot request
- GetSnapshotsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- GetSnapshotsRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Constructs a new get snapshots request with given repository name
- GetSnapshotsRequest(String, String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Constructs a new get snapshots request with given repository name and list of snapshots
- GetSnapshotsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshots request builder
- GetSnapshotsRequestBuilder(ElasticsearchClient, GetSnapshotsAction) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Constructs the new get snapshot request
- GetSnapshotsRequestBuilder(ElasticsearchClient, GetSnapshotsAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Constructs the new get snapshot request with specified repository
- GetSnapshotsResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshots response
- getSnapshotState(SnapshotId) - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns the
SnapshotState
for the given snapshot. - getSnapshotThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getSnapshotThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.FilterRepository
- getSnapshotThrottleTimeInNanos() - Method in interface org.elasticsearch.repositories.Repository
-
Returns snapshot throttle time in nanoseconds
- getSocketTimeout() - Method in class org.elasticsearch.index.reindex.RemoteInfo
-
Time to wait for a response from each request.
- getSoftDeleteRetentionOperations() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the number of extra operations (i.e.
- getSortFields() - Method in class org.elasticsearch.search.SearchHits
-
In case documents were sorted by field(s), returns information about such field(s), null otherwise
- getSortFieldType(SortField) - Static method in class org.elasticsearch.index.IndexSortConfig
- getSorts() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getSortValues() - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- getSortValues() - Method in class org.elasticsearch.search.SearchHit
-
An array of the (formatted) sort values used.
- getSource() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- getSource() - Method in class org.elasticsearch.action.get.GetResponse
- getSource() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- getSource() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- getSource() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getSource() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getSource() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- getSource() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
- getSource() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getSource() - Method in interface org.elasticsearch.common.inject.spi.Element
-
Returns an arbitrary object containing information about the "place" where this element was configured.
- getSource() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- getSource() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- getSource() - Method in class org.elasticsearch.common.inject.spi.Message
- getSource() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- getSource() - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- getSource() - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- getSource() - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- getSource() - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
- getSource() - Method in class org.elasticsearch.index.get.GetResult
- getSource() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getSource() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The source of the hit.
- getSource() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- getSource() - Method in class org.elasticsearch.index.translog.Translog.Delete
- getSource() - Method in class org.elasticsearch.index.translog.Translog.Index
- getSource() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- getSource() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- getSource() - Method in class org.elasticsearch.script.StoredScriptSource
- getSourceAndMetadata() - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the document including its metadata fields, unless
IngestDocument.extractMetadata()
has been called, in which case the metadata fields will not be present anymore. - getSourceAsBytes() - Method in class org.elasticsearch.action.get.GetResponse
-
The source of the document if exists.
- getSourceAsBytesRef() - Method in class org.elasticsearch.action.get.GetResponse
-
Returns bytes reference, also un compress the source if needed.
- getSourceAsMap() - Method in class org.elasticsearch.action.get.GetResponse
-
The source of the document (As a map).
- getSourceAsMap() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
Converts the serialized compressed form of the mappings into a parsed map.
- getSourceAsMap() - Method in class org.elasticsearch.search.SearchHit
-
The source of the document as a map (can be
null
). - getSourceAsString() - Method in class org.elasticsearch.action.get.GetResponse
-
The source of the document (as a string).
- getSourceAsString() - Method in class org.elasticsearch.search.SearchHit
-
The source of the document as string (can be
null
). - getSourceIndex() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Returns the source index name
- getSourceInternal() - Method in class org.elasticsearch.action.get.GetResponse
-
Returns the internal source bytes, as they are returned without munging (for example, might still be compressed).
- getSourceKey() - Method in interface org.elasticsearch.common.inject.spi.ConvertedConstantBinding
-
Returns the key for the source binding.
- getSourceNode() - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
Returns recovery source node (only non-null if peer recovery)
- getSourceRef() - Method in class org.elasticsearch.search.SearchHit
-
Returns bytes reference, also uncompress the source if needed.
- getSources() - Method in class org.elasticsearch.common.inject.internal.Errors
- getSources() - Method in class org.elasticsearch.common.inject.spi.Message
- getStage() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns snapshot stage
- getStage() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getStage() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getStartedShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with the snapshot in the started stage
- getStartingSeqNo(Logger, RecoveryTarget) - Static method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
-
Get the starting sequence number for a sequence-number-based request.
- getStartOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- getStartTime() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns time when snapshot started
- getStartTime() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
-
The start time in milliseconds for deleting the snapshots.
- getStartTime() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getStartTime() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getStartTime() - Method in class org.elasticsearch.tasks.Task
-
Returns the task's start time as a wall clock time since epoch (
System.currentTimeMillis()
style). - getStartTime() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns the task start time
- getState() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
-
Returns the cluster state resulted from the cluster reroute request execution
- getState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns snapshot state
- getState() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
-
The requested cluster state.
- getState() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getState() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- getState() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- getState() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- getState() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- getState(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- getState(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- getStatePath() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- getStates() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- getStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns snapshot stats
- getStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
Returns snapshot stats
- getStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns number of files in the snapshot
- getStats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- getStats() - Method in class org.elasticsearch.index.shard.IndexShard
- getStats() - Method in class org.elasticsearch.ingest.IngestStats.PipelineStat
- getStats() - Method in class org.elasticsearch.ingest.IngestStats.ProcessorStat
- getStats() - Method in class org.elasticsearch.transport.TcpTransport
- getStats() - Method in interface org.elasticsearch.transport.Transport
- getStats(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
constructs a
SeqNoStats
object, using local state and the supplied global checkpoint This is needed to make sure the local checkpoint and max seq no are consistent - getStats(String) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- getStats(ShardId) - Method in class org.elasticsearch.indices.IndicesQueryCache
-
Get usage statistics for the given shard.
- GetStats - Class in org.elasticsearch.index.get
- GetStats() - Constructor for class org.elasticsearch.index.get.GetStats
- GetStats(long, long, long, long, long) - Constructor for class org.elasticsearch.index.get.GetStats
- getStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getStatus() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getStatus() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The rest status.
- getStatus() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The REST status that should be used for the response
- getStatus() - Method in class org.elasticsearch.action.support.replication.ReplicationTask
- getStatus() - Method in class org.elasticsearch.action.TaskOperationFailure
- getStatus() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getStatus() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getStatus() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getStatus() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getStatus() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
- getStatus() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- getStatus() - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Get the combined statuses of sliced subtasks
- getStatus() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- getStatus() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- getStatus() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- getStatus() - Method in enum org.elasticsearch.rest.RestStatus
- getStatus() - Method in class org.elasticsearch.tasks.Task
-
Build a status for this task or null if this task doesn't have status.
- getStatus() - Method in class org.elasticsearch.tasks.TaskInfo
-
The status of the running task.
- getStatus(List<BulkByScrollTask.StatusOrException>) - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Get the combined statuses of slice subtasks, merged with the given list of statuses
- getStatus(Response) - Method in class org.elasticsearch.rest.action.RestToXContentListener
- getStdDeviation() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
-
The standard deviation of the collected values.
- getStdDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getStdDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getStdDeviationAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
-
The standard deviation of the collected values as a String.
- getStdDeviationAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getStdDeviationAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getStdDeviationBound(ExtendedStats.Bounds) - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
-
The upper or lower bounds of the stdDeviation
- getStdDeviationBound(ExtendedStats.Bounds) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getStdDeviationBound(ExtendedStats.Bounds) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getStdDeviationBoundAsString(ExtendedStats.Bounds) - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
-
The upper or lower bounds of stdDev of the collected values as a String.
- getStdDeviationBoundAsString(ExtendedStats.Bounds) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getStdDeviationBoundAsString(ExtendedStats.Bounds) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getStopWords() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getStopWords() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Get the current stop words being used.
- getStore() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getStore() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getStore() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the
Store
instance that provides access to theDirectory
used for the enginesIndexWriter
to write it's index files to. - getStore() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getStoredFieldsContext() - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Gets the stored fields context.
- getStoredFieldsMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getStoredFieldsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the stored fields memory usage by a segment.
- getStoredScript(GetStoredScriptRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a script from the cluster state
- getStoredScript(GetStoredScriptRequest, ActionListener<GetStoredScriptResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a script from the cluster state
- getStoredScript(ClusterState, GetStoredScriptRequest) - Method in class org.elasticsearch.script.ScriptService
- GetStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetStoredScriptRequest - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetStoredScriptRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- GetStoredScriptRequestBuilder - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetStoredScriptRequestBuilder(ElasticsearchClient, GetStoredScriptAction) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequestBuilder
- GetStoredScriptResponse - Class in org.elasticsearch.action.admin.cluster.storedscripts
- getStoreException() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
Exception while trying to open the shard index or from when the shard failed
- getStoreException() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Gets the store exception when trying to read the store, if there was an error.
- getStoreStatuses() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
-
Returns
IndicesShardStoresResponse.StoreStatus
s grouped by their index names and shard ids. - getStrategyName() - Method in enum org.elasticsearch.common.geo.SpatialStrategy
- getStrictStandardDateFormatter() - Static method in class org.elasticsearch.common.joda.Joda
- getString(String) - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
- getString(String) - Method in interface org.elasticsearch.common.settings.SecureSettings
-
Return a string setting.
- getStringKeySerializer() - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Returns a map key serializer for String keys
- getStringRep() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getSubAggregations() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return the configured set of subaggregations
- getSubQuery() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- getSubsetDf() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- getSubsetDf() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- getSubsetDf() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- getSubsetSize() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- getSuccessful() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
-
Returns how many total clusters the search was executed successfully on
- getSuccessful() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- getSuccessfullyProcessed() - Method in interface org.elasticsearch.index.reindex.SuccessfullyProcessed
-
Total number of successfully processed documents.
- getSuccessfulShards() - Method in class org.elasticsearch.action.search.SearchResponse
-
The successful number of shards the search was executed on.
- getSuccessfulShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The successful shards this request was executed on.
- getSuffix() - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
- getSuggest() - Method in class org.elasticsearch.action.search.SearchResponse
- getSuggestCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSuggestCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSuggester() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getSuggesters() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
Suggester
s defined by this plugin. - getSuggestion(String) - Method in class org.elasticsearch.search.suggest.Suggest
- getSuggestions() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Get all the
Suggestions
that were added to the globalSuggestBuilder
, together with their names - getSuggestTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSuggestTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSum() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- getSum() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getSum() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
- getSumAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- getSumAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getSumAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
- getSumDocFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Field
-
Return the sum of
ScriptedSimilarity.Term.getDocFreq()
for all terms that exist in this field, or-1
if this statistic is not available. - getSumOfOtherDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getSumOfOtherDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- getSumOfOtherDocCounts() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms
-
Return the sum of the document counts of all buckets that did not make it to the top buckets.
- getSumOfOtherDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getSumOfSquares() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
-
The sum of the squares of the collected values.
- getSumOfSquares() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getSumOfSquares() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getSumOfSquaresAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
-
The sum of the squares of the collected values as a String.
- getSumOfSquaresAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getSumOfSquaresAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getSumTotalTermFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Field
-
Return the sum of
ScriptedSimilarity.Term.getTotalTermFreq()
for all terms that exist in this field, or-1
if this statistic is not available. - getSupersetDf() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- getSupersetDf() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- getSupersetDf() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
- getSupersetNumDocs() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
-
Get the number of docs in the superset.
- getSupersetNumDocs() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregatorFactory
-
Get the number of docs in the superset.
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- getSupersetSize() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- getSupertype(Class<?>) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the generic form of
supertype
. - getSupportTransportActions() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- getSwap() - Method in class org.elasticsearch.monitor.os.OsStats
- getSyncId() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the sync id of the commit point that this MetadataSnapshot represents.
- getSynonymFilter() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
- getSynonymFilter() - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
Return a version of this TokenFilterFactory appropriate for synonym parsing Filters that should not be applied to synonyms (for example, those that produce multiple tokens) should throw an exception
- getSystemCpuPercent() - Method in class org.elasticsearch.monitor.os.OsProbe
- getSystemProperties() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns a read-only view of all system properties
- getSystemProperties() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestAliasAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestAllocationAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestCountAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestFielddataAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestMasterAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestNodesAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestPluginsAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestRecoveryAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestSegmentsAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestSnapshotAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestTemplatesAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- getTag() - Method in class org.elasticsearch.ingest.AbstractProcessor
- getTag() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getTag() - Method in interface org.elasticsearch.ingest.Processor
-
Gets the tag of a processor.
- getTag() - Method in class org.elasticsearch.ingest.TrackingResultProcessor
- getTargetAllocationID() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getTargetBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getTargetIndexRequest() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Returns the
CreateIndexRequest
for the shrink index - getTargetNode() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Get the node that the allocator will assign the shard to, returning
null
if there is no node to which the shard will be assigned or moved. - getTargetNode() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getTargetRelocatingShard() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns a shard routing representing the target shard.
- getTask() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
-
Get the actual result of the fetch.
- getTask() - Method in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- getTask() - Method in class org.elasticsearch.persistent.PersistentTaskResponse
- getTask() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getTask() - Method in class org.elasticsearch.search.internal.SearchContext
- getTask() - Method in class org.elasticsearch.tasks.TaskResult
-
Get the task that this wraps.
- getTask(long) - Method in class org.elasticsearch.tasks.TaskManager
-
Returns a task with given id, or null if the task is not found.
- getTask(String) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- getTask(GetTaskRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a task.
- getTask(GetTaskRequest, ActionListener<GetTaskResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a task.
- GetTaskAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
Action for retrieving a list of currently running tasks
- getTaskExecutionEWMA() - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
-
Returns the exponentially weighted moving average of the task execution time
- getTaskFailures() - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
-
The list of task failures exception.
- getTaskGroups() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Get the tasks found by this request grouped by parent tasks.
- getTaskHeaders() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Returns headers which should be copied from internal requests into tasks.
- getTaskId() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Get the TaskId to look up.
- getTaskId() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
Returns the id of the task that should be processed.
- getTaskId() - Method in class org.elasticsearch.action.TaskOperationFailure
- getTaskId() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- getTaskId() - Method in class org.elasticsearch.tasks.TaskInfo
- getTaskInfo() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup.Builder
- getTaskInfo() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- getTaskManager() - Method in class org.elasticsearch.transport.TransportService
- getTaskMaxWaitingTime() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getTaskName() - Method in class org.elasticsearch.common.StopWatch.TaskInfo
-
Return the name of this task.
- getTaskName() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- getTaskName() - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
- getTaskName() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- getTaskRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a get task request.
- GetTaskRequest - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
A request to get node tasks
- GetTaskRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
- GetTaskRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
Builder for the request to retrieve the list of tasks running on the specified nodes
- GetTaskRequestBuilder(ElasticsearchClient, GetTaskAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequestBuilder
- GetTaskResponse - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
Returns the list of tasks currently running on the nodes
- GetTaskResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- GetTaskResponse(TaskResult) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- getTasks() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Get the tasks found by this request.
- getTasks() - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
-
Returns a stream of all pending tasks.
- getTasks() - Method in class org.elasticsearch.tasks.TaskManager
-
Returns the list of currently running tasks on the node
- getTaskWithId(ClusterState, String) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- getTb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getTbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getTempDir() - Static method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- getTemplates() - Method in class org.elasticsearch.cluster.metadata.MetaData
- getTemplates(GetIndexTemplatesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Gets index template.
- getTemplates(GetIndexTemplatesRequest, ActionListener<GetIndexTemplatesResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Gets an index template.
- getTempNameForFile(String) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
Get a temporary name for the provided file name.
- getTera() - Method in class org.elasticsearch.common.unit.SizeValue
- getTeraFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getTerm() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- getTerm() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
- getTerm() - Method in class org.elasticsearch.index.engine.Engine.Result
- getTerms() - Method in class org.apache.lucene.queries.BlendedTermQuery
- getTerms() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Returns the terms for each position in this phrase
- getTerms() - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypesQuery
- getTermsMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getTermsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the terms dictionary memory usage by a segment.
- getTermVectors(IndexShard, TermVectorsRequest) - Static method in class org.elasticsearch.index.termvectors.TermVectorsService
- getTermVectorsMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getTermVectorsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the term vectors memory usage by a segment.
- getText() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- getText() - Method in class org.apache.lucene.search.uhighlight.Snippet
- getText() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- getText() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- getText() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getTexts() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- getThreadContext() - Method in class org.elasticsearch.threadpool.ThreadPool
- getThreadPool() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- getThreadPool() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
Thread Pool level statistics.
- getThreadPool() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Use the same threadpool by default.
- getThreadPool() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a thread-pool mainly used to get estimated time stamps from
ThreadPool.relativeTimeInMillis()
and to schedule async force merge calls on theThreadPool.Names.FORCE_MERGE
thread-pool - getThreadPool() - Method in class org.elasticsearch.index.IndexService
-
The
ThreadPool
to use for this index. - getThreadPool() - Method in class org.elasticsearch.index.shard.IndexShard
- getThreadPool() - Method in class org.elasticsearch.transport.TransportService
-
Returns the internal thread pool
- getThreadPoolType() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getThreads() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
The total number of threads in the cluster
- getThreads() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getThreshold() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
Returns the currently configured delta threshold
- getThrottled() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
The total time this request has throttled itself not including the current throttle time if it is currently sleeping.
- getThrottledUntil() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Remaining delay of any current throttle sleep or 0 if not sleeping.
- getThrottleTime() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
Gets the amount of time in a TimeValue that the index has been under merge throttling control
- getTime() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns snapshot running time
- getTime() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- getTime() - Method in class org.elasticsearch.common.StopWatch.TaskInfo
-
Return the time this task took.
- getTime() - Method in class org.elasticsearch.index.get.GetStats
- getTime() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Returns the total time (inclusive of children) for this query node.
- getTime() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- getTime() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getTimeBreakdown() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Returns the timing breakdown for this particular query node
- getTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
- getTimeInQueue() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getTimeInQueueInMillis() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getTimeout() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Timeout to wait for any async actions this request must take.
- getTimeout() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- getTimeout() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Timeout to wait for the shards on to be available for each bulk request?
- getTimer() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getTimer(T) - Method in class org.elasticsearch.search.profile.AbstractProfileBreakdown
- getTimestamp() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getTimestamp() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- getTimestamp() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getTimestamp() - Method in class org.elasticsearch.monitor.fs.FsInfo
- getTimestamp() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getTimestamp() - Method in class org.elasticsearch.monitor.os.OsStats
- getTimestamp() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getTimeThrottledNanos() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
-
The total time duration for which tasks in the control group have been throttled.
- getTimeZone() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getTimeZone() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange.ParsedBucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getTo() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getToAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getTokenFilterProvider(String) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Returns a registered
TokenFilterFactory
provider by name ornull
if the token filter was not registered - getTokenFilterProvider(String, IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Returns a registered
TokenFilterFactory
provider byIndexSettings
or a registeredTokenFilterFactory
provider by predefined name ornull
if the tokenFilter was not registered - getTokenFilters() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional
TokenFilter
s. - getTokenizerName() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
-
The name of the tokenizer as configured by the user.
- getTokenizerProvider(String) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Returns a registered
TokenizerFactory
provider by name ornull
if the tokenizer was not registered - getTokenizerProvider(String, IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Returns a registered
TokenizerFactory
provider byIndexSettings
or a registeredTokenizerFactory
provider by predefined name ornull
if the tokenizer was not registered - getTokenizers() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional
Tokenizer
s. - getTokens() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- getTokens() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- getTokenStreamToAutomaton() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- getTokenStreamToAutomaton() - Method in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
- getTombstoneDocSupplier() - Method in class org.elasticsearch.index.engine.EngineConfig
- getTombstones() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
-
Get the current unmodifiable index tombstone list.
- getTook() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
How long the bulk execution took.
- getTook() - Method in class org.elasticsearch.action.search.SearchResponse
-
How long the search took.
- getTook() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getTook() - Method in class org.elasticsearch.index.engine.Engine.Result
-
get total time in nanoseconds
- getTook() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getTopDocs() - Method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
-
Transform
FirstPassGroupingCollector.getTopGroups(int, boolean)
output inCollapseTopFieldDocs
. - getTotal() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
total number of shards in the cluster
- getTotal() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
- getTotal() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getTotal() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getTotal() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getTotal() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
-
Returns how many total clusters the search was requested to be executed on
- getTotal() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- getTotal() - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- getTotal() - Method in class org.elasticsearch.index.flush.FlushStats
-
The total number of flush executed.
- getTotal() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total number of merges executed.
- getTotal() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The total number of refresh executed.
- getTotal() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getTotal() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
The total number of documents this request will process.
- getTotal() - Method in class org.elasticsearch.index.search.stats.SearchStats
- getTotal() - Method in class org.elasticsearch.index.shard.IndexingStats
- getTotal() - Method in class org.elasticsearch.monitor.fs.FsInfo
- getTotal() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getTotal() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getTotal() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- getTotal() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
-
Get the Process cpu time (sum of User and Sys).
- getTotalBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getTotalBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- getTotalBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- getTotalBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- getTotalBytes() - Method in class org.elasticsearch.cluster.DiskUsage
- getTotalBytes() - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
- getTotalBytesPerSecAutoThrottle() - Method in class org.elasticsearch.index.merge.MergeStats
- getTotalBytesWritten(Thread, MergePolicy.OneMerge) - Static method in class org.apache.lucene.index.OneMergeHelper
-
Returns total bytes written by this merge.
- getTotalCapacity() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- getTotalCompressedSize() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
-
Deprecated.
- getTotalCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The total number of lookups in the cache.
- getTotalFileCount() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns total number of files in the snapshot
- getTotalFileCount() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getTotalHits() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
What were the total number of documents matching the search?
- getTotalHits() - Method in class org.elasticsearch.search.query.QuerySearchResult
- getTotalHits() - Method in class org.elasticsearch.search.SearchHits
-
The total number of hits that matches the search request.
- getTotalIndexingBuffer() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- getTotalIndexingBufferBytes() - Method in class org.elasticsearch.indices.IndicesService
- getTotalLoadedClassCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
- getTotalMemory() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
Utility method which computes total memory by adding FieldData, PercolatorCache, Segments (memory, index writer, version map)
- getTotalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getTotalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Gets the total number of shards from all indices, including replicas and closed indices.
- getTotalNumDocs() - Method in class org.elasticsearch.index.merge.MergeStats
- getTotalNumOrds() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number of document ID to ordinal pairs in this builder.
- getTotalOpen() - Method in class org.elasticsearch.http.HttpStats
- getTotalOpenIndexShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Gets the total number of open shards from all indices.
- getTotalOperations() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
total number of translog operations that were captured by translog snapshot
- getTotalOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalPhysicalMemorySize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the total amount of physical memory in bytes.
- getTotalReadKilobytes() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalReadOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Total number of shards
- getTotalShards() - Method in class org.elasticsearch.action.search.SearchResponse
-
The total number of shards the search was executed on.
- getTotalShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The total shards this request ran against.
- getTotalSize() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns total size of files in the snapshot
- getTotalSize() - Method in class org.elasticsearch.index.merge.MergeStats
- getTotalSize() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getTotalSizeInBytes() - Method in class org.elasticsearch.index.merge.MergeStats
- getTotalSizeInBytes() - Method in class org.elasticsearch.index.shard.DocsStats
-
Returns the total size in bytes of all documents in this stats.
- getTotalStats() - Method in class org.elasticsearch.ingest.IngestStats
- getTotalStoppedTime() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time large merges were stopped so smaller merges could finish.
- getTotalStoppedTimeInMillis() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time large merges were stopped so smaller merges could finish.
- getTotalSwapSpaceSize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the total amount of swap space in bytes.
- getTotalTermFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Term
-
Return the total number of occurrences of this term in the index, or
-1
if this statistic is not available. - getTotalThrottledTime() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time merge IO writes were throttled.
- getTotalThrottledTimeInMillis() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time merge IO writes were throttled.
- getTotalTime() - Method in class org.elasticsearch.index.flush.FlushStats
-
The total time merges have been executed.
- getTotalTime() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time merges have been executed.
- getTotalTime() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The total time merges have been executed.
- getTotalTime() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getTotalTimeInMillis() - Method in class org.elasticsearch.index.flush.FlushStats
-
The total time merges have been executed (in milliseconds).
- getTotalTimeInMillis() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time merges have been executed (in milliseconds).
- getTotalTimeInMillis() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The total time merges have been executed (in milliseconds).
- getTotalVirtual() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
- getTotalVirtualMemorySize() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the size (in bytes) of virtual memory that is guaranteed to be available to the running process
- getTotalWriteKilobytes() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalWriteOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getToUpgradeBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getToUpgradeBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- getToUpgradeBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- getToUpgradeBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- getToUpgradeBytesAncient() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getToUpgradeBytesAncient() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- getToUpgradeBytesAncient() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- getToUpgradeBytesAncient() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- getTrackedLocalCheckpointForShard(String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns the local checkpoint information tracked for a specific shard.
- getTragicException() - Method in class org.elasticsearch.index.translog.Translog
-
If this
Translog
was closed as a side-effect of a tragic exception, e.g. - getTransient(String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns a transient header object or
null
if there is no header for the given key - getTransientSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
-
Returns the transient settings for the cluster
- getTransientSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- getTranslog() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getTranslog() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getTranslog() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getTranslogConfig() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the translog config for this engine
- getTranslogDurability() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the translog durability for this index.
- getTranslogDurability() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the current translog durability mode
- getTranslogGenerationOfLastCommit() - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
-
Returns a translog generation that will be used to calculate the number of uncommitted operations since the last index commit.
- getTranslogLastWriteLocation() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the last location that the translog of this engine has written into.
- getTranslogLastWriteLocation() - Method in class org.elasticsearch.index.engine.InternalEngine
- getTranslogLastWriteLocation() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getTranslogLocation() - Method in class org.elasticsearch.index.engine.Engine.Result
-
get the translog location after executing the operation
- getTranslogPath() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the translog path for this engine
- getTranslogRetentionAge() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the transaction log retention age which controls the maximum age (time from creation) that translog files will be kept around
- getTranslogRetentionSize() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the transaction log retention size which controls how much of the translog is kept around to allow for ops based recoveries
- getTranslogSizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogStats
- getTranslogStats() - Method in class org.elasticsearch.index.engine.Engine
- getTranslogStats() - Method in class org.elasticsearch.index.engine.InternalEngine
- getTranslogStats() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getTranslogSyncInterval() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the translog sync interval.
- getTranslogUUID() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the translog uuid used to associate a lucene index with a translog.
- getTransport() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- getTransport() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getTransportAction() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- getTransportInterceptor() - Method in class org.elasticsearch.common.network.NetworkModule
-
Returns a composite
TransportInterceptor
containing all registered interceptors - getTransportInterceptors(NamedWriteableRegistry, ThreadContext) - Method in interface org.elasticsearch.plugins.NetworkPlugin
-
Returns a list of
TransportInterceptor
instances that are used to intercept incoming and outgoing transport (inter-node) requests. - getTransports(Settings, ThreadPool, PageCacheRecycler, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Method in interface org.elasticsearch.plugins.NetworkPlugin
-
Returns a map of
Transport
suppliers. - getTransportSupplier() - Method in class org.elasticsearch.common.network.NetworkModule
- getTree() - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
After the query has been run and profiled, we need to merge the flat timing map with the dependency graph to build a data structure that mirrors the original query tree
- getTree() - Method in class org.elasticsearch.search.profile.AbstractProfiler
- getTrigramLambda() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- getTrimAboveSeqNo() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- getTrippedCount() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getTrippedCount() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getTrippedCount() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getTrippedCount() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getTxCount() - Method in class org.elasticsearch.transport.TransportStats
- getTxSize() - Method in class org.elasticsearch.transport.TransportStats
- getType() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- getType() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The type of the action.
- getType() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The type of the action.
- getType() - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- getType() - Method in class org.elasticsearch.action.DocWriteResponse
-
The type of the document changed.
- getType() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getType() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The type of the field.
- getType() - Method in class org.elasticsearch.action.get.GetResponse
-
The type of the document.
- getType() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The type of the document.
- getType() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The type of the action.
- getType() - Method in exception org.elasticsearch.action.RoutingMissingException
- getType() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The type of the document.
- getType() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
-
The type of the action.
- getType() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.EmptyStoreRecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.LocalShardsRecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.PeerRecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- getType() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- getType() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
-
Gets the type containing the members to be injected.
- getType() - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- getType() - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Gets underlying
Type
instance. - getType() - Method in class org.elasticsearch.index.get.GetResult
-
The type of the document.
- getType() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Returns the type (for testing)
- getType() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getType() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The type that the hit has.
- getType() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getType() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getType() - Method in class org.elasticsearch.ingest.ConditionalProcessor
- getType() - Method in class org.elasticsearch.ingest.DropProcessor
- getType() - Method in class org.elasticsearch.ingest.PipelineProcessor
- getType() - Method in interface org.elasticsearch.ingest.Processor
-
Gets the type of a processor
- getType() - Method in class org.elasticsearch.ingest.ProcessorInfo
- getType() - Method in class org.elasticsearch.ingest.TrackingResultProcessor
- getType() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getType() - Method in class org.elasticsearch.persistent.decider.AssignmentDecision
- getType() - Method in class org.elasticsearch.script.Script
- getType() - Method in interface org.elasticsearch.script.ScriptEngine
-
The language name used in the script APIs to refer to this scripting backend.
- getType() - Method in interface org.elasticsearch.search.aggregations.Aggregation
- getType() - Method in interface org.elasticsearch.search.aggregations.BaseAggregationBuilder
-
The name of the type of aggregation built by this builder.
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilter
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.global.ParsedGlobal
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedHistogram
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.missing.ParsedMissing
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ParsedNested
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ParsedReverseNested
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedGeoDistance
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.ParsedSampler
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantLongTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantStringTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getType() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.avg.ParsedAvg
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.ParsedCardinality
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.ParsedGeoBounds
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.ParsedGeoCentroid
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.mad.ParsedMedianAbsoluteDeviation
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.max.ParsedMax
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.min.ParsedMin
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentileRanks
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentiles
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentileRanks
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentiles
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ParsedScriptedMetric
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.sum.ParsedSum
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.ParsedTopHits
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ParsedValueCount
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.ParsedWeightedAvg
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.ParsedBucketMetricValue
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.ParsedPercentilesBucket
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ParsedExtendedStatsBucket
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.ParsedStatsBucket
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.ParsedDerivative
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedSimpleValue
- getType() - Method in class org.elasticsearch.search.SearchHit
-
The type of the document.
- getType() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- getType() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
gets the type identifier of this
PhraseSuggestionBuilder.CandidateGenerator
- getType() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- getType() - Method in interface org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.CandidateGenerator
- getType() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
Returns a string representing the type of the suggestion.
- getType() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- getType() - Method in class org.elasticsearch.tasks.Task
-
Returns task channel type (netty, transport, direct)
- getType() - Method in class org.elasticsearch.tasks.TaskInfo
- getType() - Method in enum org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- getTypeConverter() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
- getTypeConverter() - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- getTypeFromElement(E) - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
- getTypeFromElement(Aggregator) - Method in class org.elasticsearch.search.profile.aggregation.InternalAggregationProfileTree
- getTypeLiteral() - Method in class org.elasticsearch.common.inject.Key
-
Gets the key type.
- getTypeMatcher() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
- getTypeMatcher() - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- getTypeMatcher() - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
-
Returns the type matcher which chooses which types the listener should be notified of.
- getTypes() - Method in class org.elasticsearch.index.query.QueryShardContext
- getTypes() - Method in class org.elasticsearch.search.lookup.DocLookup
- getTypeStats() - Method in class org.elasticsearch.index.shard.IndexingStats
- getUid() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- getUnassignedInfo() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the unassigned info for the shard, or
null
if the shard is active. - getUnassignedShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getUnassignedShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getUnassignedShards() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getUnassignedShards() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getUnassignedTimeInMillis() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
The timestamp in milliseconds when the shard became unassigned, based on System.currentTimeMillis().
- getUnassignedTimeInNanos() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
The timestamp in nanoseconds when the shard became unassigned, based on System.nanoTime().
- getUnavailableInSyncShards() - Method in class org.elasticsearch.index.shard.ReplicationGroup
-
Returns the set of shard allocation ids that are in the in-sync set but have no assigned routing entry
- getUncommittedOperations() - Method in class org.elasticsearch.index.translog.TranslogStats
-
the number of operations in generations of the translog that weren't yet to committed to lucene
- getUncommittedSizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogStats
-
the size of the generations in the translog that weren't yet to committed to lucene
- getUnigramLambda() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- getUnloadedClassCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
- getUpdated() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getUpdated() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- getUpdated() - Method in interface org.elasticsearch.index.reindex.SuccessfullyProcessed
-
Count of documents updated.
- getUpdated() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- getUpgradedVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Return the
Version
on which this index has been upgraded. - getUpperBounds() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- getUpserts() - Method in class org.elasticsearch.cluster.DiffableUtils.MapDiff
-
Map entries that, when this diff is applied to a map, should be added to the map or fully replace the previous value.
- getUpserts() - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- getUptime() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getUsageCount() - Method in class org.elasticsearch.rest.BaseRestHandler
- getUsageStats(DiscoveryNode, boolean) - Method in class org.elasticsearch.usage.UsageService
-
Get the current usage statistics for this node.
- getUsed() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getUsed() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getUsed() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- getUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getUsed() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getUsed() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- getUsedBytes() - Method in class org.elasticsearch.cluster.DiskUsage
- getUsedDiskAsPercentage() - Method in class org.elasticsearch.cluster.DiskUsage
- getUsedPercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getUserData() - Method in class org.elasticsearch.index.engine.CommitStats
- getUsername() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getUuid() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getUuid() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreCompletionResponse
- getUUID() - Method in class org.elasticsearch.index.Index
- getUUID() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the indexes UUID
- getUUID() - Method in class org.elasticsearch.snapshots.SnapshotId
-
Returns the snapshot UUID
- getValidationMethod() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns geo coordinate validation method to use.
- getValidationMethod() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Returns validation method for geo coordinates.
- getValidationMethod() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Returns the validation method to use for geo coordinates.
- getValue() - Method in enum org.elasticsearch.action.support.WriteRequest.RefreshPolicy
- getValue() - Method in class org.elasticsearch.common.cache.RemovalNotification
- getValue() - Method in class org.elasticsearch.common.document.DocumentField
-
The first value of the hit.
- getValue() - Method in interface org.elasticsearch.common.inject.spi.ConvertedConstantBinding
-
Returns the converted value.
- getValue() - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
-
Fetch the first field value or 0 millis after epoch if there are no in.
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
- getValue() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- getValue() - Method in enum org.elasticsearch.index.VersionType
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.avg.Avg
-
The average value.
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.avg.ParsedAvg
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.cardinality.Cardinality
-
The number of unique terms.
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.ParsedCardinality
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.max.Max
-
The maximum.
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.max.ParsedMax
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.min.Min
-
The minimum.
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.min.ParsedMin
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.Percentile
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.sum.ParsedSum
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.sum.Sum
-
The sum.
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ParsedValueCount
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.valuecount.ValueCount
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.ParsedWeightedAvg
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvg
-
The average value.
- getValue() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- getValue() - Method in class org.elasticsearch.search.lookup.FieldLookup
- getValue(String) - Method in interface org.elasticsearch.common.settings.SettingUpgrader
-
The logic to upgrade the setting value.
- getValue(Setting<T>) - Method in class org.elasticsearch.index.IndexSettings
- getValue(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Returns the instance value for the current settings.
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.ParsedCardinality
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
- getValueAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregation.SingleValue
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ParsedValueCount
- getValueCount() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number of distinct ordinals in this builder.
- getValues() - Method in class org.elasticsearch.common.document.DocumentField
-
The field values.
- getValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
-
Return a copy of the list of the values for the current document.
- getValues() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- getValues() - Method in class org.elasticsearch.search.lookup.FieldLookup
- getValues(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
Returns an array of values of the field specified as the method parameter.
- getValues(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- getValues(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- getValues(ValuesSource.Numeric, LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTermsAggregator
- getValues(ValuesSource.Numeric, LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- getValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- getValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- getValuesSketch() - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- getValuesSourceType() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- getValueType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Factory
- getValueType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- getValueType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- getVariance() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
-
The variance of the collected values.
- getVariance() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getVariance() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getVarianceAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
-
The variance of the collected values as a String.
- getVarianceAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getVarianceAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- getVerifyIndex() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getVersion() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
The current ES version
- getVersion() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The version of the action.
- getVersion() - Method in class org.elasticsearch.action.DocWriteResponse
-
Returns the current version of the doc.
- getVersion() - Method in class org.elasticsearch.action.get.GetResponse
-
The version of the doc.
- getVersion() - Method in class org.elasticsearch.action.main.MainResponse
- getVersion() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getVersion() - Method in class org.elasticsearch.cluster.ClusterState
- getVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- getVersion() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- getVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- getVersion() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- getVersion() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
The version of the node on the other side of this stream.
- getVersion() - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
The version of the node on the other side of this stream.
- getVersion() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- getVersion() - Method in class org.elasticsearch.index.engine.Engine.Result
-
get the updated document version
- getVersion() - Method in class org.elasticsearch.index.engine.Segment
- getVersion() - Method in class org.elasticsearch.index.get.GetResult
-
The version of the doc.
- getVersion() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getVersion() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The version of the match or
-1
if the version wasn't requested. - getVersion() - Method in class org.elasticsearch.ingest.Pipeline
-
An optional version stored with the pipeline so that it can be used to determine if the pipeline should be updated / replaced.
- getVersion() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getVersion() - Method in class org.elasticsearch.monitor.os.OsInfo
- getVersion() - Method in class org.elasticsearch.plugins.PluginInfo
-
The version of the plugin
- getVersion() - Method in class org.elasticsearch.search.SearchHit
-
The version of the hit.
- getVersion() - Method in class org.elasticsearch.transport.NetworkMessage
- getVersion() - Method in class org.elasticsearch.transport.TaskTransportChannel
- getVersion() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- getVersion() - Method in class org.elasticsearch.transport.TcpTransportChannel
- getVersion() - Method in interface org.elasticsearch.transport.Transport.Connection
-
Returns the version of the node this connection was established with.
- getVersion() - Method in interface org.elasticsearch.transport.TransportChannel
-
Returns the version of the other party that this channel will send a response to.
- getVersionConflicts() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getVersionConflicts() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of version conflicts this request has hit.
- getVersionMapMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getVersionMapMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the memory usage by version map
- getVersions() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getVersions() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
- getVIntKeySerializer() - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Returns a map key serializer for Integer keys.
- getVmName() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getVmVendor() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getVmVersion() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getWaitForActiveShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Returns the configured
IndexMetaData.SETTING_WAIT_FOR_ACTIVE_SHARDS
, which defaults to an active shard count of 1 if not specified. - getWaitForActiveShards() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The number of shard copies that must be active before proceeding with the write.
- getWaitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Should this request wait for all found tasks to complete?
- getWaitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Should this request wait for all found tasks to complete?
- getWarmer() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getWarmer() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns an
Engine.Warmer
used to warm new searchers before they are used for searching. - getWarmer() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getWeekOfWeekyear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getWeekyear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getWeight() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- getWeight() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- getWeight() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- getWeight() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
The weight applied to the function before combining.
- getWeight() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregatorFactory
-
Returns the
Weight
for this filter aggregation, creating it if necessary. - getWeightRanking() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
The weight ranking for allocating a shard to the node.
- getWeights() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregatorFactory
-
Returns the
Weight
s for this filter aggregation, creating it if necessary. - getWhitespaceNormalizer(String) - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns a normalizer that splits on whitespace mapped to the given name or
null
if not present - getWildcardQuery(String, String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getWindow() - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
-
Returns the window size for this aggregation
- getWindowSize() - Method in class org.elasticsearch.search.rescore.RescoreContext
-
Size of the window to rescore.
- getWordList(Environment, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
-
Fetches a list of words from the specified settings file.
- getWordList(Environment, Settings, String, String) - Static method in class org.elasticsearch.index.analysis.Analysis
-
Fetches a list of words from the specified settings file.
- getWordSet(Environment, Version, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
- getWorkerState() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Returns the object that manages sending search requests.
- getWrappedAnalyzer(String) - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
- getWrappedAnalyzer(String) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- getWrappedClass() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- getWriteableName() - Method in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- getWriteableName() - Method in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- getWriteableName() - Method in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- getWriteableName() - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Returns the name of the writeable object
- getWriteableName() - Method in class org.elasticsearch.cluster.RestoreInProgress
-
Returns the name of the writeable object
- getWriteableName() - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
- getWriteableName() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- getWriteableName() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- getWriteableName() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- getWriteableName() - Method in interface org.elasticsearch.common.io.stream.NamedWriteable
-
Returns the name of the writeable object
- getWriteableName() - Method in interface org.elasticsearch.common.io.stream.VersionedNamedWriteable
-
Returns the name of the writeable object
- getWriteableName() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanTermQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.TermQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.TypeQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- getWriteableName() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- getWriteableName() - Method in class org.elasticsearch.ingest.IngestMetadata
- getWriteableName() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- getWriteableName() - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- getWriteableName() - Method in class org.elasticsearch.script.ScriptMetaData
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.InternalExtendedStatsBucket
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- getWriteableName() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- getWriteableName() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- getWriteableName() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- getWriteableName() - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- getWriteableName() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- getWriteableName() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- getWriteableName() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- getWriteableName() - Method in class org.elasticsearch.tasks.RawTaskStatus
- getWriteableRegistry() - Method in class org.elasticsearch.index.query.QueryRewriteContext
- getWriteableType() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- getWriteableType() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- getWriteableType() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
Returns a integer representing the type of the suggestion.
- getWriteableType() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- getWriteIndex() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
- getWritingBytes() - Method in class org.elasticsearch.index.engine.Engine
-
Returns how many bytes we are currently moving from heap to disk
- getWritingBytes() - Method in class org.elasticsearch.index.engine.InternalEngine
-
Returns how many bytes we are currently moving from indexing buffer to segments on disk
- getWritingBytes() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getWritingBytes() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns how many bytes we are currently moving from heap to disk
- getXContentHumanReadableTransformers() - Method in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- getXContentRegistry() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
The registry used to build new
XContentParser
s. - getXContentRegistry() - Method in class org.elasticsearch.rest.RestRequest
-
Get the
NamedXContentRegistry
that should be used to create parsers from this request. - getXContentType() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- getXContentType() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- getXContentType() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- getXContentType() - Method in class org.elasticsearch.index.mapper.SourceToParse
- getXContentType() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getXContentType() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The content type of the hit source.
- getXContentType() - Method in class org.elasticsearch.rest.RestRequest
-
The
XContentType
that was parsed from theContent-Type
header. - getXContentWriters() - Method in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- getYear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getYearOfCentury() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getYearOfEra() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getYesDecisionMessages() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
-
Provides feedback from commands with a YES decision that should be displayed to the user after the command has been applied
- getZenHostsProviders(TransportService, NetworkService) - Method in interface org.elasticsearch.plugins.DiscoveryPlugin
-
Returns providers of unicast host lists for zen discovery.
- getZone() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getZonedDateTime() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- giga() - Method in class org.elasticsearch.common.unit.SizeValue
- GIGA - org.elasticsearch.common.unit.SizeUnit
- gigaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- global() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- global(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Global
aggregation with the given name. - global(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- Global - Interface in org.elasticsearch.search.aggregations.bucket.global
-
A
global
aggregation. - GLOBAL - org.elasticsearch.index.analysis.AnalyzerScope
- GLOBAL_CHECKPOINT_SYNC_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.IndexService
- GLOBAL_NETWORK_BIND_HOST_SETTING - Static variable in class org.elasticsearch.common.network.NetworkService
- GLOBAL_NETWORK_HOST_SETTING - Static variable in class org.elasticsearch.common.network.NetworkService
- GLOBAL_NETWORK_PUBLISH_HOST_SETTING - Static variable in class org.elasticsearch.common.network.NetworkService
- GLOBAL_ORDINALS - org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- GLOBAL_ORDINALS - org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory.ExecutionMode
- GLOBAL_ORDINALS - org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
- GLOBAL_STATE_FILE_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.MetaData
- GLOBAL_TEXT_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestBuilder
- GlobalAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.global
- GlobalAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- GlobalAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
-
Read from a stream.
- GlobalAggregationBuilder(GlobalAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- GlobalAggregator - Class in org.elasticsearch.search.aggregations.bucket.global
- GlobalAggregator(String, AggregatorFactories, SearchContext, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- GlobalAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.global
- GlobalAggregatorFactory(String, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregatorFactory
- globalBlockedException(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- globalBlockedRaiseException(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- globalBlockLevel() - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- globalBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Cluster level block to check before request execution.
- globalBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- globalCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the global checkpoint on the primary shard.
- globalCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.ReplicaResponse
-
The global checkpoint for the shard.
- globalCheckpoint() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- globalCheckpoint() - Method in class org.elasticsearch.indices.recovery.RecoveryFinalizeRecoveryRequest
- GlobalCheckpointListeners - Class in org.elasticsearch.index.shard
-
Represents a collection of global checkpoint listeners.
- GlobalCheckpointListeners.GlobalCheckpointListener - Interface in org.elasticsearch.index.shard
-
A global checkpoint listener consisting of a callback that is notified when the global checkpoint is updated or the shard is closed.
- GlobalCheckpointSyncAction - Class in org.elasticsearch.index.seqno
-
Background global checkpoint sync action initiated when a shard goes inactive.
- GlobalCheckpointSyncAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- GlobalCheckpointSyncAction.Request - Class in org.elasticsearch.index.seqno
- globalForceSource(boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight
- globalMaxOrd(IndexSearcher) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
- GlobalOrdinalsBuilder - Enum in org.elasticsearch.index.fielddata.ordinals
-
Utility class to build global ordinals.
- GlobalOrdinalsIndexFieldData - Class in org.elasticsearch.index.fielddata.ordinals
-
IndexFieldData
base class for concrete global ordinals implementations. - GlobalOrdinalsIndexFieldData(IndexSettings, String, AtomicOrdinalsFieldData[], OrdinalMap, long, Function<SortedSetDocValues, ScriptDocValues<?>>) - Constructor for class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- globalOrdinalsMapping(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- globalOrdinalsMapping(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
-
Returns a mapping from segment ordinals to global ordinals.
- GlobalOrdinalsSignificantTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.significant
-
An global ordinal based implementation of significant terms, based on
SignificantStringTermsAggregator
. - GlobalOrdinalsSignificantTermsAggregator(String, AggregatorFactories, ValuesSource.Bytes.WithOrdinals.FieldData, DocValueFormat, TermsAggregator.BucketCountThresholds, IncludeExclude.OrdinalsFilter, SearchContext, Aggregator, boolean, SignificanceHeuristic, SignificantTermsAggregatorFactory, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
- GlobalOrdinalsStringTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
-
An aggregator of string values that relies on global ordinals in order to build buckets.
- GlobalOrdinalsStringTermsAggregator(String, AggregatorFactories, ValuesSource.Bytes.WithOrdinals, BucketOrder, DocValueFormat, TermsAggregator.BucketCountThresholds, IncludeExclude.OrdinalsFilter, SearchContext, Aggregator, boolean, Aggregator.SubAggCollectionMode, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- GlobalOrdinalsStringTermsAggregator.GlobalOrdLookupFunction - Interface in org.elasticsearch.search.aggregations.bucket.terms
- globalOrdinalsValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- globalOrdinalsValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
- GND - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- GND(boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
- GND(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
-
Read from a stream.
- GND.GNDBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- GNDBuilder(boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDBuilder
- GONE - org.elasticsearch.rest.RestStatus
-
The requested resource is no longer available at the server and no forwarding address is known.
- gramSize() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the
PhraseSuggestionBuilder.gramSize(int)
parameter - gramSize(int) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the gram size for the n-gram model used for this suggester.
- GRAMSIZE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- GREEN - org.elasticsearch.cluster.health.ClusterHealthStatus
- groupBy(ShardOperationFailedException[]) - Static method in class org.elasticsearch.ExceptionsHelper
-
Deduplicate the failures by exception message and index.
- groupClusterIndices(Set<String>, String[], Predicate<String>) - Method in class org.elasticsearch.transport.RemoteClusterAware
-
Groups indices per cluster by splitting remote cluster-alias, index-name pairs on
RemoteClusterAware.REMOTE_CLUSTER_INDEX_SEPARATOR
. - GroupedActionListener<T> - Class in org.elasticsearch.action.support
-
An action listener that delegates it's results to another listener once it has received one or more failures or N results.
- GroupedActionListener(ActionListener<Collection<T>>, int, Collection<T>) - Constructor for class org.elasticsearch.action.support.GroupedActionListener
-
Creates a new listener
- groupIndices(IndicesOptions, String[], Predicate<String>) - Method in class org.elasticsearch.transport.RemoteClusterService
- GroupKey(String) - Constructor for class org.elasticsearch.common.settings.Setting.GroupKey
- groups() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- groups() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- groups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Sets specific search group stats to retrieve the stats for.
- groups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Sets specific search group stats to retrieve the stats for.
- groupSetting(String, Consumer<Settings>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- groupSetting(String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- GroupShardsIterator<ShardIt extends ShardIterator> - Class in org.elasticsearch.cluster.routing
-
This class implements a compilation of
ShardIterator
s. - GroupShardsIterator(List<ShardIt>) - Constructor for class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Constructs a enw GroupShardsIterator from the given list.
- groupStats() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- groupStats() - Method in class org.elasticsearch.search.internal.SearchContext
- groupStats(List<String>) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- groupStats(List<String>) - Method in class org.elasticsearch.search.internal.SearchContext
- groupStats(List<String>) - Method in class org.elasticsearch.search.internal.SubSearchContext
- grow() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
Make sure the
SortingBinaryDocValues.values
array can store at leastSortingBinaryDocValues.count
entries. - grow(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Ensure there are at least
maxBucketOrd
buckets available. - grow(ByteArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(DoubleArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(FloatArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(IntArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(LongArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(ObjectArray<T>, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - gt(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- GT_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- gte(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- GTE_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- guardedRamBytesUsed(Accountable) - Static method in class org.elasticsearch.index.engine.Engine
-
Returns 0 in the case where accountable is null, otherwise returns
ramBytesUsed()
- guessRootCauses() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- guessRootCauses() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the root cause of this exception or multiple if different shards caused different exceptions
- guessRootCauses(Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns the root cause of this exception or multiple if different shards caused different exceptions.
- Guice - Class in org.elasticsearch.common.inject
-
The entry point to the Guice framework.
H
- h1 - Variable in class org.elasticsearch.common.hash.MurmurHash3.Hash128
-
lower 64 bits part
- h2 - Variable in class org.elasticsearch.common.hash.MurmurHash3.Hash128
-
higher 64 bits part
- HALF_FLOAT - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- HALF_FLOAT - org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- handle(int) - Method in interface org.elasticsearch.bootstrap.ConsoleCtrlHandler
-
Handles the Ctrl event.
- handle(Object, Errors) - Method in interface org.elasticsearch.common.inject.internal.ErrorHandler
-
Handles an error.
- handle(Message) - Method in interface org.elasticsearch.common.inject.internal.ErrorHandler
-
Handles a user-reported error.
- handleBareFuzzy(String, Token, String) - Method in class org.apache.lucene.queryparser.classic.XQueryParser
- handleBareFuzzy(String, Token, String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- handleCancel() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- handleCommitRequest(PublishClusterStateAction.CommitClusterStateRequest, TransportChannel) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- HandledTransportAction<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support
-
A TransportAction that self registers a handler into the transport service
- HandledTransportAction(Settings, String, boolean, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- HandledTransportAction(Settings, String, boolean, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, String) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- HandledTransportAction(Settings, String, boolean, ThreadPool, TransportService, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- HandledTransportAction(Settings, String, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- HandledTransportAction(Settings, String, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, String) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- HandledTransportAction(Settings, String, ThreadPool, TransportService, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- handleException(TransportException) - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- handleException(TransportException) - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
- handleException(TransportException) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
- handleException(TransportException) - Method in class org.elasticsearch.transport.PlainTransportFuture
- handleException(TransportException) - Method in class org.elasticsearch.transport.TransportChannelResponseHandler
- handleException(TransportException) - Method in interface org.elasticsearch.transport.TransportResponseHandler
- handleException(TransportException) - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- handleIncomingClusterStateRequest(BytesTransportRequest, TransportChannel) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- handleJoinRequest(DiscoveryNode, MembershipAction.JoinCallback) - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
processes or queues an incoming join request.
- handler() - Method in class org.elasticsearch.transport.Transport.ResponseContext
- handleRequest(RestRequest, RestChannel, NodeClient) - Method in class org.elasticsearch.rest.BaseRestHandler
- handleRequest(RestRequest, RestChannel, NodeClient) - Method in class org.elasticsearch.rest.DeprecationRestHandler
-
Handles a rest request.
- handleRequest(RestRequest, RestChannel, NodeClient) - Method in interface org.elasticsearch.rest.RestHandler
-
Handles a rest request.
- handleRequest(TcpChannel, InboundMessage.RequestMessage, int) - Method in class org.elasticsearch.transport.TcpTransport
- handleResponse(TransportResponse.Empty) - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
- handleResponse(Response) - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- handleResponse(T) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
- handleResponse(T) - Method in class org.elasticsearch.transport.TransportChannelResponseHandler
- handleResponse(T) - Method in interface org.elasticsearch.transport.TransportResponseHandler
- handleResponse(T) - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- handleResponse(V) - Method in class org.elasticsearch.transport.PlainTransportFuture
- handleTransportDisconnect(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- handleTransportDisconnect(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- HANDOFF_PRIMARY_CONTEXT - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- handoffPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- handoffPrimaryContext(ReplicationTracker.PrimaryContext) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Handoff the primary context between the relocation source and the relocation target.
- handoffPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- handshake(Transport.Connection, long) - Method in class org.elasticsearch.transport.TransportService
-
Executes a high-level handshake using the given connection and returns the discovery node of the node the connection was established with.
- handshake(Transport.Connection, long, Predicate<ClusterName>) - Method in class org.elasticsearch.transport.TransportService
-
Executes a high-level handshake using the given connection and returns the discovery node of the node the connection was established with.
- HANDSHAKE_ACTION_NAME - Static variable in class org.elasticsearch.transport.TransportService
- HandshakeResponse(DiscoveryNode, ClusterName, Version) - Constructor for class org.elasticsearch.transport.TransportService.HandshakeResponse
- HandshakeResponse(StreamInput) - Constructor for class org.elasticsearch.transport.TransportService.HandshakeResponse
- HasAggregations - Interface in org.elasticsearch.search.aggregations
- hasAggs() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns
true
if this query result has unconsumed aggregations - hasAlias(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
- hasAliases(String[], String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Checks if at least one of the specified aliases exists in the specified concrete indices.
- hasAsyncActions() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Returns
true
if there are any registered async actions. - hasBeenProcessedBefore(Engine.Operation) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Checks if the given operation has been processed in this engine or not.
- hasBytes() - Method in class org.elasticsearch.common.text.Text
-
Whether a
BytesReference
view of the data is already materialized. - hasChanged(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Returns true if this updaters setting has changed with the current update
- hasChanges() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- hasClauses() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Returns
true
iff this query builder has at least one should, must, must not or filter clause. - hasCompleteHistoryOperations(String, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Checks if we have a completed history of operations since the given starting seqno (inclusive).
- hasCompleteOperationHistory(String, MapperService, long) - Method in class org.elasticsearch.index.engine.Engine
-
Checks if this engine has every operations since
startingSeqNo
(inclusive) in its history (either Lucene or translog) - hasCompleteOperationHistory(String, MapperService, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- hasCompleteOperationHistory(String, MapperService, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- hasConcreteIndex(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
- hasConsumedTopDocs() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns
true
iff the top docs have already been consumed. - hasContent() - Method in class org.elasticsearch.rest.RestRequest
- hasContentOrSourceParam() - Method in class org.elasticsearch.rest.RestRequest
-
Does this request have content or a
source
parameter? Use this instead ofRestRequest.hasContent()
if this RestHandler treats thesource
parameter like the body content. - hasContextMappings() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- hasCustomDataPath() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if the index has a custom data path - hasData() - Method in class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
-
Does the result actually contain data? If not, then there are on going fetch operations happening, and it should wait for it.
- hasDeletionsInProgress() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns
true
if there are snapshot deletions in progress in the cluster, returnsfalse
otherwise. - HasDependencies - Interface in org.elasticsearch.common.inject.spi
- hasDocValues() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- hasEnoughCandidates(Collection<ElectMasterService.MasterCandidate>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- hasEnoughMasterNodes(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- hasErrors() - Method in class org.elasticsearch.common.inject.internal.Errors
- hasExplanation() - Method in class org.elasticsearch.action.explain.ExplainResponse
- hasFailures() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
Has anything failed with the execution.
- hasFailures() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Determine if there are any node failures in
BaseNodesResponse.failures
. - hasFeature(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Test if the stream has the specified feature.
- hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.SearchContext
- hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- hasField(String) - Method in class org.elasticsearch.ingest.IngestDocument
-
Checks whether the document contains a value for the provided path
- hasField(String, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Checks whether the document contains a value for the provided path
- hasField(TemplateScript.Factory) - Method in class org.elasticsearch.ingest.IngestDocument
-
Checks whether the document contains a value for the provided templated path
- hasGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasGlobalBlockWithId(int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasGlobalBlockWithLevel(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasGlobalBlockWithStatus(RestStatus) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
Is there a global block with the provided status?
- hash() - Method in class org.elasticsearch.index.store.StoreFileMetaData
-
Returns a variable length hash of the file represented by this metadata object.
- hash(byte[], int, int) - Static method in class org.elasticsearch.cluster.routing.Murmur3HashFunction
- hash(String) - Static method in class org.elasticsearch.cluster.routing.Murmur3HashFunction
- hash128(byte[], int, int, long, MurmurHash3.Hash128) - Static method in enum org.elasticsearch.common.hash.MurmurHash3
-
Compute the hash of the MurmurHash3_x64_128 hashing function.
- Hash128() - Constructor for class org.elasticsearch.common.hash.MurmurHash3.Hash128
- hashCode() - Method in class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- hashCode() - Method in class org.apache.lucene.queries.BlendedTermQuery
- hashCode() - Method in class org.apache.lucene.queries.MinDocQuery
- hashCode() - Method in class org.apache.lucene.queries.SearchAfterSortedDocQuery
- hashCode() - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmVersion
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- hashCode() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
- hashCode() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- hashCode() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- hashCode() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- hashCode() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- hashCode() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- hashCode() - Method in class org.elasticsearch.action.explain.ExplainResponse
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- hashCode() - Method in class org.elasticsearch.action.GenericAction
- hashCode() - Method in class org.elasticsearch.action.get.GetResponse
- hashCode() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- hashCode() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- hashCode() - Method in class org.elasticsearch.action.main.MainResponse
- hashCode() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- hashCode() - Method in class org.elasticsearch.action.search.MultiSearchRequest
- hashCode() - Method in class org.elasticsearch.action.search.SearchRequest
- hashCode() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- hashCode() - Method in class org.elasticsearch.action.search.SearchScrollRequest
- hashCode() - Method in class org.elasticsearch.action.support.ActiveShardCount
- hashCode() - Method in class org.elasticsearch.action.support.IndicesOptions
- hashCode() - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- hashCode() - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- hashCode() - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- hashCode() - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- hashCode() - Method in class org.elasticsearch.Build
- hashCode() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- hashCode() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- hashCode() - Method in class org.elasticsearch.cluster.ClusterName
- hashCode() - Method in class org.elasticsearch.cluster.DiskUsage
- hashCode() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- hashCode() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- hashCode() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- hashCode() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- hashCode() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
- hashCode() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
- hashCode() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- hashCode() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
- hashCode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- hashCode() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
- hashCode() - Method in class org.elasticsearch.cluster.RestoreInProgress
- hashCode() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- hashCode() - Method in class org.elasticsearch.cluster.routing.AllocationId
- hashCode() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- hashCode() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- hashCode() - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
- hashCode() - Method in class org.elasticsearch.cluster.routing.RecoverySource
- hashCode() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- hashCode() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- hashCode() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
- hashCode() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- hashCode() - Method in class org.elasticsearch.common.bytes.BytesReference
- hashCode() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- hashCode() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- hashCode() - Method in class org.elasticsearch.common.compress.CompressedXContent
- hashCode() - Method in class org.elasticsearch.common.document.DocumentField
- hashCode() - Method in class org.elasticsearch.common.FieldMemoryStats
- hashCode() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- hashCode() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- hashCode() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- hashCode() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- hashCode() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- hashCode() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- hashCode() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- hashCode() - Method in class org.elasticsearch.common.geo.GeoPoint
- hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- hashCode() - Method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
- hashCode() - Method in class org.elasticsearch.common.inject.Key
- hashCode() - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder
- hashCode() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- hashCode() - Method in class org.elasticsearch.common.inject.spi.Dependency
- hashCode() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
- hashCode() - Method in class org.elasticsearch.common.inject.spi.Message
- hashCode() - Method in class org.elasticsearch.common.inject.TypeLiteral
- hashCode() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
- hashCode() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- hashCode() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- hashCode() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- hashCode() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.common.rounding.Rounding
- hashCode() - Method in class org.elasticsearch.common.settings.SecureString
- hashCode() - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- hashCode() - Method in class org.elasticsearch.common.settings.Setting
- hashCode() - Method in class org.elasticsearch.common.settings.Setting.SimpleKey
- hashCode() - Method in class org.elasticsearch.common.settings.Settings
- hashCode() - Method in class org.elasticsearch.common.text.Text
- hashCode() - Method in class org.elasticsearch.common.transport.TransportAddress
- hashCode() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- hashCode() - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
- hashCode() - Method in class org.elasticsearch.common.unit.Fuzziness
- hashCode() - Method in class org.elasticsearch.common.unit.SizeValue
- hashCode() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- hashCode() - Method in class org.elasticsearch.env.NodeMetaData
- hashCode() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- hashCode() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- hashCode() - Method in class org.elasticsearch.index.engine.Engine.CommitId
- hashCode() - Method in class org.elasticsearch.index.engine.Segment
- hashCode() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- hashCode() - Method in class org.elasticsearch.index.get.GetResult
- hashCode() - Method in class org.elasticsearch.index.Index
- hashCode() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- hashCode() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- hashCode() - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypesQuery
- hashCode() - Method in class org.elasticsearch.index.mapper.Uid
- hashCode() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- hashCode() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- hashCode() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- hashCode() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- hashCode() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- hashCode() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- hashCode() - Method in class org.elasticsearch.index.refresh.RefreshStats
- hashCode() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- hashCode() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- hashCode() - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- hashCode() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- hashCode() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- hashCode() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- hashCode() - Method in class org.elasticsearch.index.seqno.RetentionLease
- hashCode() - Method in class org.elasticsearch.index.seqno.RetentionLeases
- hashCode() - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
- hashCode() - Method in class org.elasticsearch.index.seqno.SeqNoStats
- hashCode() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- hashCode() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- hashCode() - Method in class org.elasticsearch.index.shard.ShardId
- hashCode() - Method in class org.elasticsearch.index.shard.ShardPath
- hashCode() - Method in class org.elasticsearch.index.shard.ShardStateMetaData
- hashCode() - Method in class org.elasticsearch.index.similarity.SimilarityProvider
- hashCode() - Method in class org.elasticsearch.index.translog.Translog.Delete
- hashCode() - Method in class org.elasticsearch.index.translog.Translog.Index
- hashCode() - Method in class org.elasticsearch.index.translog.Translog.Location
- hashCode() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- hashCode() - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- hashCode() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
- hashCode() - Method in class org.elasticsearch.indices.TermsLookup
- hashCode() - Method in class org.elasticsearch.ingest.IngestDocument
- hashCode() - Method in class org.elasticsearch.ingest.IngestInfo
- hashCode() - Method in class org.elasticsearch.ingest.IngestMetadata
- hashCode() - Method in class org.elasticsearch.ingest.PipelineConfiguration
- hashCode() - Method in class org.elasticsearch.ingest.ProcessorInfo
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.ByteValue
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.ListValue
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.MapValue
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.ObjectValue
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.TemplatedValue
- hashCode() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
- hashCode() - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTaskResponse
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Assignment
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- hashCode() - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- hashCode() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- hashCode() - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- hashCode() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- hashCode() - Method in class org.elasticsearch.plugins.PluginInfo
- hashCode() - Method in class org.elasticsearch.repositories.IndexId
- hashCode() - Method in class org.elasticsearch.repositories.RepositoryData
- hashCode() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- hashCode() - Method in class org.elasticsearch.script.Script
- hashCode() - Method in class org.elasticsearch.script.ScriptMetaData
- hashCode() - Method in class org.elasticsearch.script.StoredScriptSource
- hashCode() - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.Aggregations
- hashCode() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- hashCode() - Method in class org.elasticsearch.search.aggregations.BucketOrder
- hashCode() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- hashCode() - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- hashCode() - Method in class org.elasticsearch.search.aggregations.InternalOrder
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.Percentile
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- hashCode() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- hashCode() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- hashCode() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- hashCode() - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- hashCode() - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- hashCode() - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
- hashCode() - Method in class org.elasticsearch.search.fetch.subphase.DocValueFieldsContext.FieldAndFormat
- hashCode() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- hashCode() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- hashCode() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- hashCode() - Method in class org.elasticsearch.search.internal.AliasFilter
- hashCode() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- hashCode() - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- hashCode() - Method in class org.elasticsearch.search.Scroll
- hashCode() - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- hashCode() - Method in class org.elasticsearch.search.SearchExtBuilder
- hashCode() - Method in class org.elasticsearch.search.SearchHit
- hashCode() - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
- hashCode() - Method in class org.elasticsearch.search.SearchHits
- hashCode() - Method in class org.elasticsearch.search.SearchShardTarget
- hashCode() - Method in class org.elasticsearch.search.SearchSortValues
- hashCode() - Method in class org.elasticsearch.search.slice.SliceBuilder
- hashCode() - Method in class org.elasticsearch.search.slice.SliceQuery
- hashCode() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
- hashCode() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- hashCode() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- hashCode() - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- hashCode() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- hashCode() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- hashCode() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- hashCode() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- hashCode() - Method in class org.elasticsearch.snapshots.RestoreInfo
- hashCode() - Method in class org.elasticsearch.snapshots.Snapshot
- hashCode() - Method in class org.elasticsearch.snapshots.SnapshotId
- hashCode() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- hashCode() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
- hashCode() - Method in class org.elasticsearch.tasks.RawTaskStatus
- hashCode() - Method in class org.elasticsearch.tasks.TaskId
- hashCode() - Method in class org.elasticsearch.tasks.TaskInfo
- hashCode() - Method in class org.elasticsearch.tasks.TaskResult
- hashCode() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- hashCode() - Method in class org.elasticsearch.Version
- hashCode(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- hashCode(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns the hashCode of
type
. - hashCode(ByteArray) - Method in class org.elasticsearch.common.util.BigArrays
- hashFile(BytesRefBuilder, InputStream, long) - Static method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Computes a strong hash value for small files.
- hasInactivePrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- hasInactiveShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- hasIndex(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
- hasIndex(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- hasIndex(Index) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- hasIndex(Index) - Method in class org.elasticsearch.indices.IndicesService
- hasIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasIndexBlockWithId(String, int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasIndexMetaData(IndexMetaData) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Returns true iff existing index has the same
IndexMetaData
instance - hasIndexOrAlias(String, ClusterState) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- hasIndexScope() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting has an index scope, otherwisefalse
- hasIndexSort() - Method in class org.elasticsearch.index.IndexSortConfig
-
Returns true if the index should be sorted
- hasInitiatedFetching(ShardRouting) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
Returns a boolean indicating whether fetching shard data has been triggered at any point for the given shard.
- hasLength(CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Check that the given CharSequence is neither
null
nor of length 0. - hasLength(String) - Static method in class org.elasticsearch.common.Strings
-
Check that the given String is neither
null
nor of length 0. - hasLength(BytesReference) - Static method in class org.elasticsearch.common.Strings
-
Check that the given BytesReference is neither
null
nor of length 0 Note: Will returntrue
for a BytesReference that purely consists of whitespace. - hasLockedKeys() - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Returns
true
if this lock has at least one locked key. - hasMapping(String) - Method in class org.elasticsearch.index.mapper.MapperService
- hasMatchingSyncId() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Returns
true
if the shard copy has a matching sync id with the primary shard. - hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
- hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
- hasMultiTermComponent() - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
-
Does this tokenizer has an equivalent component for analyzing multi-term queries?
- hasNativeController() - Method in class org.elasticsearch.plugins.PluginInfo
-
Whether or not the plugin has a native controller.
- hasNested() - Method in class org.elasticsearch.index.mapper.MapperService
- hasNestedObjects() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- hasNext() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
- hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks.Iter
- hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles.Iter
- hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks.Iter
- hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles.Iter
- hasNext() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket.Iter
- hasNodeFile() - Method in class org.elasticsearch.env.NodeEnvironment
- hasNodeScope() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting has a node scope, otherwisefalse
- hasOnlySuggest() - Method in class org.elasticsearch.search.internal.SearchContext
- hasParam(String) - Method in class org.elasticsearch.rest.RestRequest
- hasParentField() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
- hasPassword() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Return true iff calling
KeyStoreWrapper.decrypt(char[])
requires a non-empty password. - hasPayloads() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
- hasPendingAsyncFetch() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns
true
iff the current allocation run has not processed all of the in-flight or available shard or store fetches. - hasProfileResults() - Method in class org.elasticsearch.search.query.QuerySearchResult
- hasRecoveries() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- hasRun() - Method in class org.elasticsearch.common.util.concurrent.RunOnce
-
true
if theRunOnce
has been executed once. - hasScoreDocs() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- hasScoreDocs() - Method in class org.elasticsearch.search.suggest.Suggest
-
Whether any suggestions had query hits
- hasScores - Variable in class org.elasticsearch.action.termvectors.TermVectorsFields
- hasScoreTerm(Term) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- hasScriptFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- hasScriptFields() - Method in class org.elasticsearch.search.internal.SearchContext
- hasScriptFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
- hasSearchContext() - Method in class org.elasticsearch.search.query.QuerySearchResult
- hasShard(int) - Method in class org.elasticsearch.index.IndexService
- hasSource() - Method in class org.elasticsearch.search.SearchHit
-
Is the source available or not.
- hasStoredFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- hasStoredFields() - Method in class org.elasticsearch.search.internal.SearchContext
- hasStoredFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
- hasStoredFieldsContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- hasStoredFieldsContext() - Method in class org.elasticsearch.search.internal.SearchContext
- hasStoredFieldsContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- hasString() - Method in class org.elasticsearch.common.text.Text
-
Whether a
String
view of the data is already materialized. - hasSuggestHits() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns
true
if this result has any suggest score docs - hasTask(String) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
-
Checks if the task is currently present in the list
- hasTask(String, long) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
-
Checks if the task is currently present in the list and has the right allocation id
- hasText(CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Check whether the given CharSequence has actual text.
- hasText(String) - Static method in class org.elasticsearch.common.Strings
-
Check whether the given String has actual text.
- hasTooManyMasterNodes(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- hasUnassignedPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns
true
iff thisRoutingNodes
instance has any unassigned primaries even if the primaries are marked as temporarily ignored. - hasUnassignedShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns
true
iff thisRoutingNodes
instance has any unassigned shards even if the shards are marked as temporarily ignored. - hasUncompletedPendingDeletes() - Method in class org.elasticsearch.indices.IndicesService
-
Checks if all pending deletes have completed.
- hasUnknownChecksum() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Checks if the checksum for the file is unknown.
- hasValue(int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- hasValue(int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Checks to see this model can produce a new value, without actually running the algo.
- hasValue(String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns
true
iff the given key has a value in this settings object - haveEmptyIntersection(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- HDR - org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
-
The HDRHistogram method of calculating percentiles
- HDRPercentileRanksAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- HDRPercentileRanksAggregator(String, ValuesSource.Numeric, SearchContext, Aggregator, double[], int, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregator
- HDRPercentileRanksAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- HDRPercentileRanksAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], int, boolean, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregatorFactory
- HDRPercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- HDRPercentilesAggregator(String, ValuesSource.Numeric, SearchContext, Aggregator, double[], int, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregator
- HDRPercentilesAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- HDRPercentilesAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], int, boolean, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregatorFactory
- HEAD - org.elasticsearch.rest.RestRequest.Method
- header - Variable in class org.elasticsearch.index.translog.BaseTranslogReader
- header(String) - Method in class org.elasticsearch.rest.RestRequest
-
Get the value of the header or
null
if not found. - HEADER_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- health(ClusterHealthRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The health of the cluster.
- health(ClusterHealthRequest, ActionListener<ClusterHealthResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The health of the cluster.
- hear(TypeLiteral<I>, TypeEncounter<I>) - Method in interface org.elasticsearch.common.inject.spi.TypeListener
-
Invoked when Guice encounters a new type eligible for constructor or members injection.
- HierarchyCircuitBreakerService - Class in org.elasticsearch.indices.breaker
-
CircuitBreakerService that attempts to redistribute space between breakers if tripped
- HierarchyCircuitBreakerService(Settings, ClusterSettings) - Constructor for class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- HIGH - org.elasticsearch.common.Priority
- HIGH - org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Defaults to 5 seconds
- higherThan(Decision.Type) - Method in enum org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- highFreqMinimumShouldMatch() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- highFreqMinimumShouldMatch(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Sets the minimum number of high frequent query terms that need to match in order to produce a hit when there are no low frequent terms.
- highFreqOperator() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- highFreqOperator(Operator) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Sets the operator to use for terms with a high document frequency (greater than or equal to
CommonTermsQueryBuilder.cutoffFrequency(float)
. - highlight() - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
A static factory method to construct new search highlights.
- highlight() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- highlight() - Method in class org.elasticsearch.search.internal.SearchContext
- highlight() - Method in class org.elasticsearch.search.internal.SubSearchContext
- highlight(String, String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Setup highlighting for suggestions.
- highlight(HighlighterContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.FastVectorHighlighter
- highlight(HighlighterContext) - Method in interface org.elasticsearch.search.fetch.subphase.highlight.Highlighter
- highlight(HighlighterContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.PlainHighlighter
- highlight(HighlighterContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- highlight(SearchContextHighlight) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- highlight(SearchContextHighlight) - Method in class org.elasticsearch.search.internal.SearchContext
- highlight(SearchContextHighlight) - Method in class org.elasticsearch.search.internal.SubSearchContext
- HIGHLIGHT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- HIGHLIGHT_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- HIGHLIGHT_FILTER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- HIGHLIGHT_QUERY_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- HighlightBuilder - Class in org.elasticsearch.search.fetch.subphase.highlight
-
A builder for search highlighting.
- HighlightBuilder() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- HighlightBuilder(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Read from a stream.
- HighlightBuilder(HighlightBuilder, QueryBuilder, List<HighlightBuilder.Field>) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- HighlightBuilder.BoundaryScannerType - Enum in org.elasticsearch.search.fetch.subphase.highlight
- HighlightBuilder.Field - Class in org.elasticsearch.search.fetch.subphase.highlight
- HighlightBuilder.Order - Enum in org.elasticsearch.search.fetch.subphase.highlight
- HIGHLIGHTED - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- highlighter() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Gets the highlighter builder for this request.
- highlighter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the highlighter builder for this request.
- highlighter(HighlightBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
- highlighter(HighlightBuilder) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Adds highlight to perform as part of the search.
- highlighter(HighlightBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds highlight to perform as part of the search.
- Highlighter - Interface in org.elasticsearch.search.fetch.subphase.highlight
-
Highlights a search result.
- HighlighterContext - Class in org.elasticsearch.search.fetch.subphase.highlight
- HighlighterContext(String, SearchContextHighlight.Field, MappedFieldType, SearchContext, FetchSubPhase.HitContext, Query) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlighterContext
- highlighterType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlighterType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlighterType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- highlighterType(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set type of highlighter to use.
- highlightField(String, Query, int, int) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
-
Highlights terms extracted from the provided query within the content of the provided field name
- HighlightField - Class in org.elasticsearch.search.fetch.subphase.highlight
-
A field highlighted with its highlighted fragments.
- HighlightField(String, Text[]) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- highlightFields(Map<String, HighlightField>) - Method in class org.elasticsearch.search.SearchHit
- highlightFilter - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlightFilter() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlightFilter() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- highlightFilter(Boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set this to true when using the highlighterType
fvh
and you want to provide highlighting on filter clauses in your query. - highlightFilters - Static variable in class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
- HighlightPhase - Class in org.elasticsearch.search.fetch.subphase.highlight
- HighlightPhase(Map<String, Highlighter>) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightPhase
- highlightQuery - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlightQuery() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlightQuery() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- highlightQuery(QueryBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Sets a query to be used for highlighting instead of the search query.
- HighlightUtils - Class in org.elasticsearch.search.fetch.subphase.highlight
- HighlightUtils.Encoders - Class in org.elasticsearch.search.fetch.subphase.highlight
- histogram(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Histogram
aggregation with the given name. - Histogram - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
A
histogram
aggregation. - Histogram.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
A bucket in the histogram where documents fall in
- HistogramAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
A builder for histograms on numeric fields.
- HistogramAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Create a new builder with the given name.
- HistogramAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Read from a stream, for internal use only.
- HistogramAggregationBuilder(HistogramAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- HistogramAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.histogram
- HistogramAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, double, double, BucketOrder, boolean, long, double, double, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- HistogramFactory - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
Implemented by histogram aggregations and used by pipeline aggregations to insert buckets.
- HistogramValuesSourceBuilder - Class in org.elasticsearch.search.aggregations.bucket.composite
-
A
CompositeValuesSourceBuilder
that builds aHistogramValuesSource
from another numeric values source using the provided interval. - HistogramValuesSourceBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- HistogramValuesSourceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- HISTORY_UUID_KEY - Static variable in class org.elasticsearch.index.engine.Engine
- hit() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- hitContext - Variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlighterContext
- HitContext() - Constructor for class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in interface org.elasticsearch.search.fetch.FetchSubPhase
-
Executes the hit level phase, with a reader and doc id (note, its a low level reader, and the matching doc).
- hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.subphase.ExplainFetchSubPhase
- hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceSubPhase
- hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightPhase
- hits - Variable in class org.elasticsearch.action.search.SearchResponseSections
- hits() - Method in class org.elasticsearch.action.search.SearchResponseSections
- hits() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- hits(SearchHits) - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- HITS - Static variable in class org.elasticsearch.search.SearchHits.Fields
- hitsExecute(SearchContext, SearchHit[]) - Method in interface org.elasticsearch.search.fetch.FetchSubPhase
- hitsExecute(SearchContext, SearchHit[]) - Method in class org.elasticsearch.search.fetch.subphase.DocValueFieldsFetchSubPhase
- hitsExecute(SearchContext, SearchHit[]) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsFetchSubPhase
- hitsExecute(SearchContext, SearchHit[]) - Method in class org.elasticsearch.search.fetch.subphase.MatchedQueriesFetchSubPhase
- hitsExecute(SearchContext, SearchHit[]) - Method in class org.elasticsearch.search.fetch.subphase.ParentFieldSubFetchPhase
- hitsExecute(SearchContext, SearchHit[]) - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsFetchSubPhase
- hitsExecute(SearchContext, SearchHit[]) - Method in class org.elasticsearch.search.fetch.subphase.SeqNoPrimaryTermFetchSubPhase
- hitsExecute(SearchContext, SearchHit[]) - Method in class org.elasticsearch.search.fetch.subphase.VersionFetchSubPhase
- hole(LineStringBuilder) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
-
Add a new hole to the polygon
- hole(LineStringBuilder, boolean) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
-
Add a new hole to the polygon
- HOLE_CHARACTER - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- holes() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- holt(double[], double, double) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Calculate a doubly exponential weighted moving average Alpha controls the smoothing of the data.
- holtForecast(double[], double, double, int) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Version of holt that can "forecast", not exposed as a whitelisted function for moving_fn scripts, but here as compatibility/code sharing for existing moving_avg agg.
- HoltLinearModel - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
-
Calculate a doubly exponential weighted moving average
- HoltLinearModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- HoltLinearModel(double, double) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- HoltLinearModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
-
Read from a stream.
- HoltLinearModel.HoltLinearModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
- HoltLinearModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel.HoltLinearModelBuilder
- holtWinters(double[], double, double, double, int, boolean) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Calculate a triple exponential weighted moving average Alpha controls the smoothing of the data.
- holtWintersForecast(double[], double, double, double, int, double, boolean, int) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Version of holt-winters that can "forecast", not exposed as a whitelisted function for moving_fn scripts, but here as compatibility/code sharing for existing moving_avg agg.
- HoltWintersModel - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
-
Calculate a triple exponential weighted moving average
- HoltWintersModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- HoltWintersModel(double, double, double, int, HoltWintersModel.SeasonalityType, boolean) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- HoltWintersModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
-
Read from a stream.
- HoltWintersModel.HoltWintersModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
- HoltWintersModel.SeasonalityType - Enum in org.elasticsearch.search.aggregations.pipeline.movavg.models
- HoltWintersModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
- HOST - Static variable in class org.elasticsearch.transport.TransportSettings
- HotThreads - Class in org.elasticsearch.monitor.jvm
- HotThreads() - Constructor for class org.elasticsearch.monitor.jvm.HotThreads
- hour() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day.
- HOUR - org.elasticsearch.common.time.FormatNames
- HOUR - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- HOUR_MINUTE - org.elasticsearch.common.time.FormatNames
- HOUR_MINUTE_SECOND - org.elasticsearch.common.time.FormatNames
- HOUR_MINUTE_SECOND_FRACTION - org.elasticsearch.common.time.FormatNames
- HOUR_MINUTE_SECOND_MILLIS - org.elasticsearch.common.time.FormatNames
- HOUR_OF_DAY - org.elasticsearch.common.rounding.DateTimeUnit
- hourMinute() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day and two digit minute of hour.
- hourMinuteSecond() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, and two digit second of minute.
- hourMinuteSecondFraction() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and three digit fraction of second (HH:mm:ss.SSS).
- hourMinuteSecondMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and three digit fraction of second (HH:mm:ss.SSS).
- hours(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- HppcMaps - Class in org.elasticsearch.common.collect
- HppcMaps.Object - Class in org.elasticsearch.common.collect
- HppcMaps.Object.Integer - Class in org.elasticsearch.common.collect
- HTML - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils.Encoders
- http() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node HTTP be returned.
- http() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node HTTP be returned.
- http(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node HTTP be returned.
- http(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node HTTP be returned.
- HTTP_DEFAULT_TYPE_SETTING - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_ENABLED - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_SERVER_WORKER_THREAD_NAME_PREFIX - Static variable in interface org.elasticsearch.http.HttpServerTransport
- HTTP_TYPE_DEFAULT_KEY - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_TYPE_KEY - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_TYPE_SETTING - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_VERSION_NOT_SUPPORTED - org.elasticsearch.rest.RestStatus
-
The server does not support, or refuses to support, the HTTP protocol version that was used in the request message.
- HttpException - Exception in org.elasticsearch.http
- HttpException(String) - Constructor for exception org.elasticsearch.http.HttpException
- HttpException(String, Throwable) - Constructor for exception org.elasticsearch.http.HttpException
- HttpException(StreamInput) - Constructor for exception org.elasticsearch.http.HttpException
- HttpInfo - Class in org.elasticsearch.http
- HttpInfo(StreamInput) - Constructor for class org.elasticsearch.http.HttpInfo
- HttpInfo(BoundTransportAddress, long) - Constructor for class org.elasticsearch.http.HttpInfo
- HttpOnTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.TcpTransport.HttpOnTransportException
- HttpServerTransport - Interface in org.elasticsearch.http
- HttpServerTransport.Dispatcher - Interface in org.elasticsearch.http
-
Dispatches HTTP requests.
- HttpStats - Class in org.elasticsearch.http
- HttpStats(long, long) - Constructor for class org.elasticsearch.http.HttpStats
- HttpStats(StreamInput) - Constructor for class org.elasticsearch.http.HttpStats
- HttpTransportSettings - Class in org.elasticsearch.http
- humanReadable() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- humanReadable() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- humanReadable(boolean) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- humanReadable(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- HUNSPELL_DICTIONARY_OPTIONS - Static variable in class org.elasticsearch.indices.analysis.HunspellService
- HUNSPELL_IGNORE_CASE - Static variable in class org.elasticsearch.indices.analysis.HunspellService
- HUNSPELL_LAZY_LOAD - Static variable in class org.elasticsearch.indices.analysis.HunspellService
- HunspellService - Class in org.elasticsearch.indices.analysis
-
Serves as a node level registry for hunspell dictionaries.
- HunspellService(Settings, Environment, Map<String, Dictionary>) - Constructor for class org.elasticsearch.indices.analysis.HunspellService
- HunspellTokenFilterFactory - Class in org.elasticsearch.index.analysis
- HunspellTokenFilterFactory(IndexSettings, String, Settings, HunspellService) - Constructor for class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
- HYBRIDFS - org.elasticsearch.index.IndexModule.Type
- HyperLogLogPlusPlus - Class in org.elasticsearch.search.aggregations.metrics.cardinality
-
Hyperloglog++ counter, implemented based on pseudo code from http://static.googleusercontent.com/media/research.google.com/fr//pubs/archive/40671.pdf and its appendix https://docs.google.com/document/d/1gyjfMHy43U9OWBXxfaeG-3MjGzejW1dlpyMwEYAAWEI/view?fullscreen This implementation is different from the original implementation in that it uses a hash table instead of a sorted list for linear counting.
- HyperLogLogPlusPlus(int, BigArrays, long) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
I
- id - Variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- id - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- id - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- id - Variable in class org.elasticsearch.Version
- id() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- id() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- id() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- id() - Method in enum org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- id() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- id() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
The id of the document to delete.
- id() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the id of the document for this request
- id() - Method in class org.elasticsearch.action.explain.ExplainRequest
- id() - Method in class org.elasticsearch.action.get.GetRequest
- id() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- id() - Method in class org.elasticsearch.action.index.IndexRequest
-
The id of the indexed document.
- id() - Method in enum org.elasticsearch.action.search.SearchType
-
The internal id of the type.
- id() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Returns the id of document the term vector is requested for.
- id() - Method in enum org.elasticsearch.action.ThreadingModel
- id() - Method in class org.elasticsearch.action.update.UpdateRequest
-
The id of the indexed document.
- id() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- id() - Method in enum org.elasticsearch.cluster.metadata.IndexMetaData.State
- id() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard id.
- id() - Method in enum org.elasticsearch.common.rounding.DateTimeUnit
- id() - Method in class org.elasticsearch.common.rounding.Rounding
- id() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- id() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
an always increasing unique identifier for this ping response.
- id() - Method in class org.elasticsearch.index.engine.Engine.Delete
- id() - Method in class org.elasticsearch.index.engine.Engine.Get
- id() - Method in class org.elasticsearch.index.engine.Engine.Index
- id() - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
-
Deprecated.
- id() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- id() - Method in class org.elasticsearch.index.mapper.SourceToParse
- id() - Method in class org.elasticsearch.index.mapper.Uid
- id() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- id() - Method in class org.elasticsearch.index.seqno.RetentionLease
-
The identifier for this retention lease.
- id() - Method in enum org.elasticsearch.index.shard.IndexShardState
- id() - Method in class org.elasticsearch.index.shard.ShardId
- id() - Method in class org.elasticsearch.index.translog.Translog.Delete
- id() - Method in class org.elasticsearch.index.translog.Translog.Index
- id() - Method in enum org.elasticsearch.index.translog.Translog.Operation.Type
- id() - Method in enum org.elasticsearch.indices.recovery.RecoveryState.Stage
- id() - Method in class org.elasticsearch.indices.TermsLookup
- id() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- id() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- id() - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- id() - Method in class org.elasticsearch.search.internal.SearchContext
- id() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- id() - Method in exception org.elasticsearch.search.SearchContextMissingException
- id(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- id(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- id(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- id(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Sets the id of the document to delete.
- id(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
- id(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the id of the document to fetch.
- id(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the id of the indexed document.
- id(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets the id of document the term vector is requested for.
- id(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the id of the indexed document.
- ID - org.elasticsearch.ingest.IngestDocument.MetaData
- ID - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- ID - Static variable in class org.elasticsearch.repositories.IndexId
- ID_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- ID_FIELD - Static variable in class org.elasticsearch.search.slice.SliceBuilder
- identical - Variable in class org.elasticsearch.index.store.Store.RecoveryDiff
-
Files that exist in both snapshots and they can be considered the same ie.
- identicalTo(Object) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches only the given object.
- IDENTITY_FILTER - Static variable in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
A TokenFilterFactory that does no filtering to its TokenStream
- idFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- IdFieldMapper - Class in org.elasticsearch.index.mapper
-
A mapper for the _id field.
- IdFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- IdFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- ids() - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Returns the ids for the query.
- ids(String[]) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- ids(String...) - Static method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Deprecated.construct the items array externally and use it in the constructor / setter
- idsEqual(byte[]) - Method in class org.elasticsearch.index.engine.Engine.CommitId
- idsQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Constructs a query that will match only specific ids within all types.
- idsQuery(String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Constructs a query that will match only specific ids within types.
- IdsQueryBuilder - Class in org.elasticsearch.index.query
-
A query that will return only documents matching specific ids (and a type).
- IdsQueryBuilder() - Constructor for class org.elasticsearch.index.query.IdsQueryBuilder
-
Creates a new IdsQueryBuilder with no types specified upfront
- IdsQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.IdsQueryBuilder
-
Read from a stream.
- IfConfig - Class in org.elasticsearch.common.network
-
Simple class to log
ifconfig
-style output at DEBUG logging. - IfConfig() - Constructor for class org.elasticsearch.common.network.IfConfig
- ifPrimaryTerm() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
If set, only perform this delete request if the document was last modification was assigned this primary term.
- ifPrimaryTerm() - Method in interface org.elasticsearch.action.DocWriteRequest
-
If set, only perform this request if the document was last modification was assigned this primary term.
- ifPrimaryTerm() - Method in class org.elasticsearch.action.index.IndexRequest
-
If set, only perform this indexing request if the document was last modification was assigned this primary term.
- ifPrimaryTerm() - Method in class org.elasticsearch.action.update.UpdateRequest
-
If set, only perform this update request if the document was last modification was assigned this primary term.
- ifSeqNo() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
If set, only perform this delete request if the document was last modification was assigned this sequence number.
- ifSeqNo() - Method in interface org.elasticsearch.action.DocWriteRequest
-
If set, only perform this request if the document was last modification was assigned this sequence number.
- ifSeqNo() - Method in class org.elasticsearch.action.index.IndexRequest
-
If set, only perform this indexing request if the document was last modification was assigned this sequence number.
- ifSeqNo() - Method in class org.elasticsearch.action.update.UpdateRequest
-
If set, only perform this update request if the document was last modification was assigned this sequence number.
- IGNORE_ABOVE - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper.Defaults
- IGNORE_ALIASES - org.elasticsearch.action.support.IndicesOptions.Option
- IGNORE_FAILURE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- IGNORE_MALFORMED - org.elasticsearch.index.query.GeoValidationMethod
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Defaults
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper.Defaults
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Defaults
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Names
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.IpFieldMapper.Defaults
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.NumberFieldMapper.Defaults
- IGNORE_MALFORMED_SETTING - Static variable in class org.elasticsearch.index.mapper.FieldMapper
- IGNORE_THROTTLED - org.elasticsearch.action.support.IndicesOptions.Option
- IGNORE_UNAVAILABLE - org.elasticsearch.action.support.IndicesOptions.Option
- IGNORE_UNMAPPED - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- IGNORE_Z_VALUE - Static variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Defaults
- IGNORE_Z_VALUE - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Defaults
- IGNORE_Z_VALUE - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Names
- ignoreAbove - Variable in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- ignoreAbove(int) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- ignoreAliases() - Method in class org.elasticsearch.action.support.IndicesOptions
- ignoreCase - Variable in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
-
Deprecated.this property only works with tokenizer property
- ignoreCase() - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
- ignored() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
The list of ignored unassigned shards (read only).
- IgnoredFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper that records fields that have been ignored because they were malformed.
- IgnoredFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- IgnoredFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- IgnoredFieldMapper.IgnoredFieldType - Class in org.elasticsearch.index.mapper
- IgnoredFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- IgnoredFieldType() - Constructor for class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- IgnoredFieldType(IgnoredFieldMapper.IgnoredFieldType) - Constructor for class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- ignoreDisable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- ignoreDisable(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- ignoredSize() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns the size of the temporarily marked as ignored unassigned shards
- ignoreException() - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext.ScriptField
- ignoreFailure() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- ignoreIdleThreads() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- ignoreIdleThreads(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- ignoreIdleThreads(boolean) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- ignoreIndexSettings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns the list of index settings and index settings groups that shouldn't be restored from snapshot
- ignoreIndexSettings(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the list of index settings and index settings groups that shouldn't be restored from snapshot
- ignoreIndexSettings(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the list of index settings and index settings groups that shouldn't be restored from snapshot
- ignoreMalformed - Variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- ignoreMalformed - Variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- ignoreMalformed - Variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- ignoreMalformed - Variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- ignoreMalformed() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- ignoreMalformed(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- ignoreMalformed(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- ignoreMalformed(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- ignoreMalformed(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- ignoreMalformed(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- ignoreRecoveryAttempt() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns
true
if this shard can ignore a recovery attempt made to it (since the already doing/done it) - ignoreShard(ShardRouting, UnassignedInfo.AllocationStatus, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Marks a shard as temporarily ignored and adds it to the ignore unassigned list.
- ignoreThrottled() - Method in class org.elasticsearch.action.support.IndicesOptions
- ignoreUnavailable() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- ignoreUnavailable() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Returns whether the request permits unavailable snapshots to be ignored.
- ignoreUnavailable() - Method in class org.elasticsearch.action.support.IndicesOptions
- ignoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Set to true to ignore unavailable snapshots
- ignoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Set to
true
to ignore unavailable snapshots, instead of throwing an exception. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the path is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns true if unmapped geo fields should be treated as located at an infinite distance
- ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Sets whether the query builder should ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets whether the query builder should ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Sets whether the query builder should ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Sets whether the query builder should ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Sets whether the query builder should ignore unmapped paths (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the path is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- ignoreZValue - Variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- ignoreZValue - Variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- ignoreZValue - Variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- ignoreZValue() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- ignoreZValue() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- ignoreZValue() - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- ignoreZValue(boolean) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- ignoreZValue(boolean) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- ignoreZValue(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- IllegalIndexShardStateException - Exception in org.elasticsearch.index.shard
- IllegalIndexShardStateException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- IllegalIndexShardStateException(ShardId, IndexShardState, String, Object...) - Constructor for exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- IllegalIndexShardStateException(ShardId, IndexShardState, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- illegalScorer(String) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Return a Scorer that throws an ElasticsearchIllegalStateException on all operations with the given message.
- IllegalShardRoutingStateException - Exception in org.elasticsearch.cluster.routing
-
This exception defines illegal states of shard routing
- IllegalShardRoutingStateException(ShardRouting, String) - Constructor for exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
- IllegalShardRoutingStateException(ShardRouting, String, Throwable) - Constructor for exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
- IllegalShardRoutingStateException(StreamInput) - Constructor for exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
- IMMEDIATE - org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Force a refresh as part of this request.
- IMMEDIATE - org.elasticsearch.common.Priority
- immutableMap() - Method in class org.elasticsearch.common.collect.MapBuilder
-
Build an immutable copy of the map under construction.
- ImmutableOpenIntMap<VType> - Class in org.elasticsearch.common.collect
-
An immutable map implementation based on open hash map.
- ImmutableOpenIntMap.Builder<VType> - Class in org.elasticsearch.common.collect
- ImmutableOpenMap<KType,VType> - Class in org.elasticsearch.common.collect
-
An immutable map implementation based on open hash map.
- ImmutableOpenMap.Builder<KType,VType> - Class in org.elasticsearch.common.collect
- ImmutableOpenMapDiff(ImmutableOpenMap<K, T>, ImmutableOpenMap<K, T>, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.ImmutableOpenMapDiff
- ImmutableOpenMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.ImmutableOpenMapDiff
- IMPLEMENTATION_ALREADY_SET - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- ImplementedBy - Annotation Type in org.elasticsearch.common.inject
-
A pointer to the default implementation of a type.
- implies(Permission) - Method in class org.elasticsearch.script.ClassPermission
- in - Variable in class org.elasticsearch.client.FilterClient
- in() - Method in class org.elasticsearch.client.FilterClient
-
Returns the delegate
Client
- in(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
See the EDSL examples at
Binder
. - in(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- in(Scope) - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
See the EDSL examples at
Binder
. - in(Scope) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- IN_FLIGHT_REQUESTS - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The in-flight request breaker tracks bytes allocated for reading and writing requests on the network layer.
- IN_FLIGHT_REQUESTS_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- IN_FLIGHT_REQUESTS_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- IN_FLIGHT_REQUESTS_CIRCUIT_BREAKER_TYPE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- IN_PROGRESS - org.elasticsearch.snapshots.SnapshotState
-
Snapshot process has started
- inboundMessage(TcpChannel, BytesReference) - Method in class org.elasticsearch.transport.TcpTransport
-
Handles inbound message that has been decoded.
- InboundMessage - Class in org.elasticsearch.transport
- InboundMessage.RequestMessage - Class in org.elasticsearch.transport
- InboundMessage.ResponseMessage - Class in org.elasticsearch.transport
- inc() - Method in class org.elasticsearch.common.metrics.CounterMetric
- inc(long) - Method in class org.elasticsearch.common.metrics.CounterMetric
- inc(long) - Method in class org.elasticsearch.common.metrics.MeanMetric
- incCurrentAsSource() - Method in class org.elasticsearch.index.recovery.RecoveryStats
- incCurrentAsTarget() - Method in class org.elasticsearch.index.recovery.RecoveryStats
- INCH - org.elasticsearch.common.unit.DistanceUnit
- include() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- include(boolean) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Whether to include the input documents.
- INCLUDE_CREATED - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
XContent param name to indicate if "created" count must be included in the response.
- INCLUDE_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- INCLUDE_NEGATIVES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- INCLUDE_TYPE_NAME_PARAMETER - Static variable in class org.elasticsearch.rest.BaseRestHandler
-
Parameter that controls whether certain REST apis should include type names in their requests or responses.
- INCLUDE_UPDATED - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
XContent param name to indicate if "updated" count must be included in the response.
- includeAliases() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns true if aliases should be restored from this snapshot
- includeAliases(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
If set to true the restore procedure will restore aliases
- includeDefaults() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsRequest
- includeDefaults() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
-
Whether to return all default settings for each of the indices.
- includeDefaults() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- includeDefaults() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- includeDefaults() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsRequest
-
When include_defaults is set, return default settings which are normally suppressed.
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
-
Sets the value of "include_defaults".
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
Indicates whether default mapping settings should be returned
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
-
Indicates whether default mapping settings should be returned
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
-
When include_defaults is set, return default values which are normally suppressed.
- includeDiskInfo() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns
true
if information about disk usage and shard sizes should also be returned. - includeDiskInfo(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Set to
true
to include information about the gathered disk information of nodes in the cluster. - includeExclude - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- includeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
-
Get terms to include and exclude from the aggregation results
- includeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
-
Get terms to include and exclude from the aggregation results
- includeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Get terms to include and exclude from the aggregation results
- includeExclude(IncludeExclude) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
-
Set terms to include and exclude from the aggregation results
- includeExclude(IncludeExclude) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
-
Set terms to include and exclude from the aggregation results
- includeExclude(IncludeExclude) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set terms to include and exclude from the aggregation results
- IncludeExclude - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Defines the include/exclude regular expression filtering for string terms aggregation.
- IncludeExclude(double[], double[]) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(int, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(long[], long[]) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(String[], String[]) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(SortedSet<BytesRef>, SortedSet<BytesRef>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(RegExp, RegExp) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
-
Read from a stream.
- IncludeExclude.LongFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.OrdinalsFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.PartitionedLongFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.SetBackedLongFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.StringFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- includeFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- includeGlobalState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns true if global state should be stored as part of the snapshot
- includeGlobalState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns true if global state should be restored from this snapshot
- includeGlobalState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns true if global state is included in the snapshot, false otherwise.
- includeGlobalState() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- includeGlobalState() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- includeGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Set to true if global state should be stored as part of the snapshot
- includeGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
If set to true the restore procedure will restore global cluster state.
- includeInAll - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- includeInAll - Variable in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- includeInAll() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- includeInAll(boolean) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- includeInAll(Boolean, FieldMapper) - Method in class org.elasticsearch.index.mapper.ParseContext
- includeLower() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the includeLower flag for this query.
- includeLower(boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Should the lower bound be included or not.
- includeNegatives - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
-
Some heuristics do not differentiate between terms that are descriptive for subset or for the background without the subset.
- includeNegatives - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
- includeQuery() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- includeRelocations() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- includes() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- includes() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- includes(String[]) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- INCLUDES_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- includeSegmentFileSizes() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- includeSegmentFileSizes() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- includeSegmentFileSizes(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- includeSegmentFileSizes(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- includeUpper() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the includeUpper flag for this query.
- includeUpper(boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Should the upper bound be included or not.
- includeYesDecisions() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns
true
if yes decisions should be included. - includeYesDecisions(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Set to
true
to include yes decisions for a particular node. - incompatible(SnapshotId) - Static method in class org.elasticsearch.snapshots.SnapshotInfo
-
Gets a new
SnapshotInfo
instance for a snapshot that is incompatible with the current version of the cluster. - INCOMPATIBLE - org.elasticsearch.snapshots.SnapshotState
-
Snapshot is incompatible with the current version of the cluster
- IncompatibleClusterStateVersionException - Exception in org.elasticsearch.cluster
-
Thrown by
Diff.apply(T)
method - IncompatibleClusterStateVersionException(long, String, long, String) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
- IncompatibleClusterStateVersionException(String) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
- IncompatibleClusterStateVersionException(StreamInput) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
- incompatibleSnapshotsFromXContent(XContentParser) - Method in class org.elasticsearch.repositories.RepositoryData
-
Reads the incompatible snapshot ids from x-content, loading them into a new instance of
RepositoryData
that is created from the invoking instance, plus the incompatible snapshots that are read from x-content. - incompatibleSnapshotsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.repositories.RepositoryData
-
Writes the incompatible snapshot ids to x-content.
- incRef() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
- incRef() - Method in interface org.elasticsearch.common.util.concurrent.RefCounted
-
Increments the refCount of this instance.
- incRef() - Method in class org.elasticsearch.index.store.Store
-
Increments the refCount of this Store instance.
- increment(long, double) - Method in interface org.elasticsearch.common.util.DoubleArray
-
Increment value at the given index by
inc
and return the value. - increment(long, float) - Method in interface org.elasticsearch.common.util.FloatArray
-
Increment value at the given index by
inc
and return the value. - increment(long, int) - Method in interface org.elasticsearch.common.util.IntArray
-
Increment value at the given index by
inc
and return the value. - increment(long, long) - Method in interface org.elasticsearch.common.util.LongArray
-
Increment value at the given index by
inc
and return the value. - incrementalFileCount() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns incremental of files that were snapshotted
- incrementalSize() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns incremental of files size that were snapshotted
- incrementBucketDocCount(long, int) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Utility method to increment the doc counts of the given bucket (identified by the bucket ordinal)
- incrementRecoveredOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- incrementRecoveredOperations(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- incrementToken() - Method in class org.elasticsearch.common.lucene.all.AllTokenStream
- incrementVersion() - Method in class org.elasticsearch.cluster.ClusterState.Builder
- index - Variable in class org.elasticsearch.action.ShardOperationFailedException
- index - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
- index - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- index - Variable in class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
The concrete index name Whether index property is optional depends on the concrete implementation.
- index - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- index - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- index - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
- index - Variable in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
- index() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- index() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The index name to create.
- index() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- index() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- index() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the index that this request operates on
- index() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- index() - Method in class org.elasticsearch.action.ShardOperationFailedException
-
The index the operation failed on.
- index() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- index() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- index() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- index() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- index() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- index() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Get the index name
- index() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
Get the index of the shard which allocation should be canceled
- index() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- index() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- index() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- index() - Method in class org.elasticsearch.index.AbstractIndexComponent
- index() - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
- index() - Method in class org.elasticsearch.index.fielddata.UidIndexFieldData
- index() - Method in interface org.elasticsearch.index.IndexComponent
- index() - Method in class org.elasticsearch.index.mapper.SourceToParse
- index() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- index() - Method in class org.elasticsearch.index.query.QueryShardContext
- index() - Method in class org.elasticsearch.indices.TermsLookup
- index(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- index(boolean) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Builder
-
Deprecated.
- index(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Set the index this action is operating on.
- index(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- index(String) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Set the index for this request
- index(String) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- index(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- index(String) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- index(String) - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
Sets the index.
- index(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- index(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
- index(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- index(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- index(IndexRequest) - Method in interface org.elasticsearch.client.Client
-
Index a JSON source associated with a given index and type.
- index(IndexRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- index(IndexRequest, ActionListener<IndexResponse>) - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- index(IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.Engine
-
Perform document index operation on the engine
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- index(Index) - Method in class org.elasticsearch.cluster.metadata.MetaData
- index(Index) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- Index - Class in org.elasticsearch.index
-
A value class representing the basic required properties of an Elasticsearch index.
- Index() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Index
- Index(String, String) - Constructor for class org.elasticsearch.index.Index
- Index(String, String, long, long, byte[]) - Constructor for class org.elasticsearch.index.translog.Translog.Index
- Index(String, String, long, long, long, VersionType, byte[], String, String, long) - Constructor for class org.elasticsearch.index.translog.Translog.Index
- Index(Term, long, ParsedDocument) - Constructor for class org.elasticsearch.index.engine.Engine.Index
- Index(Term, ParsedDocument, long, long, long, VersionType, Engine.Operation.Origin, long, long, boolean, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.Index
- Index(IndexMetaData) - Constructor for class org.elasticsearch.cluster.metadata.AliasOrIndex.Index
- Index(StreamInput) - Constructor for class org.elasticsearch.index.Index
-
Read from a stream.
- Index(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Index
- Index(Engine.Index, Engine.IndexResult) - Constructor for class org.elasticsearch.index.translog.Translog.Index
- INDEX - org.elasticsearch.action.DocWriteRequest.OpType
-
Index the source.
- INDEX - org.elasticsearch.index.analysis.AnalyzerScope
- INDEX - org.elasticsearch.index.engine.Engine.Operation.TYPE
- INDEX - org.elasticsearch.index.translog.Translog.Operation.Type
- INDEX - org.elasticsearch.indices.recovery.RecoveryState.Stage
-
recovery of lucene files, either reusing local ones are copying new ones
- INDEX - org.elasticsearch.ingest.IngestDocument.MetaData
- INDEX - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- INDEX - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- INDEX_ANALYSIS_CHAR_FILTER - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- INDEX_ANALYSIS_FILTER - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- INDEX_ANALYSIS_TOKENIZER - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- INDEX_AUTO_EXPAND_REPLICAS_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_BALANCE_FACTOR_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- INDEX_BLOCKS_METADATA_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_BLOCKS_READ_ONLY_ALLOW_DELETE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_BLOCKS_READ_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_BLOCKS_WRITE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
How much heap (% or bytes) we will share across all actively indexing shards on this node (default: 10%).
- INDEX_CACHE_REQUEST_ENABLED_SETTING - Static variable in class org.elasticsearch.indices.IndicesRequestCache
-
A setting to enable or disable request caching on an index level.
- INDEX_CHECK_ON_STARTUP - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_CLOSED_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.MetaDataIndexStateService
- INDEX_CLOSED_BLOCK_ID - Static variable in class org.elasticsearch.cluster.metadata.MetaDataIndexStateService
- INDEX_CODEC_SETTING - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
Index setting to change the low level lucene codec used for writing new segments.
- INDEX_COMPOUND_FORMAT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_CONTENT_TYPE - Static variable in class org.elasticsearch.client.Requests
-
The default content type to use to generate source documents when indexing.
- INDEX_CREATED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of an API creation of an index.
- INDEX_DATA_PATH_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_DELAYED_NODE_LEFT_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.routing.UnassignedInfo
- INDEX_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- INDEX_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- INDEX_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- INDEX_FIELDDATA_CACHE_KEY - Static variable in class org.elasticsearch.index.fielddata.IndexFieldDataService
- INDEX_FOLDER_NAME - Static variable in class org.elasticsearch.index.shard.ShardPath
- INDEX_FORMAT_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_GC_DELETES_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_INDEXING_SLOWLOG_LEVEL_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_MAX_SOURCE_CHARS_TO_LOG_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
-
Reads how much of the source to log.
- INDEX_INDEXING_SLOWLOG_REFORMAT_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_DEBUG_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_INFO_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_TRACE_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_WARN_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_LOAD_RANDOM_ACCESS_FILTERS_EAGERLY_SETTING - Static variable in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- INDEX_LOCK_FACTOR_SETTING - Static variable in class org.elasticsearch.index.store.FsDirectoryService
- INDEX_MAPPER_DYNAMIC_DEFAULT - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPER_DYNAMIC_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPING_DEPTH_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPING_NESTED_FIELDS_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPING_SINGLE_TYPE_SETTING_KEY - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_MAPPING_TOTAL_FIELDS_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MERGE_ENABLED - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_DELETES_PCT_ALLOWED_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_EXPUNGE_DELETES_ALLOWED_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_FLOOR_SEGMENT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_MAX_MERGE_AT_ONCE_EXPLICIT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_MAX_MERGE_AT_ONCE_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_MAX_MERGED_SEGMENT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_RECLAIM_DELETES_WEIGHT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_SEGMENTS_PER_TIER_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_METADATA_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_NAME - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper.Defaults
- INDEX_NUMBER_OF_REPLICAS_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_NUMBER_OF_ROUTING_SHARDS_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_NUMBER_OF_SHARDS_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_OPTIMIZE_AUTO_GENERATED_IDS - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
Configures an index to optimize documents with auto generated ids for append only.
- INDEX_OPTIONS_DOCS - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- INDEX_OPTIONS_FREQS - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- INDEX_OPTIONS_OFFSETS - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- INDEX_OPTIONS_POSITIONS - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- INDEX_PREFIX_MAX_CHARS - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- INDEX_PREFIX_MIN_CHARS - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- INDEX_PRIORITY_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_QUERY_CACHE_ENABLED_SETTING - Static variable in class org.elasticsearch.index.IndexModule
- INDEX_QUERY_CACHE_EVERYTHING_SETTING - Static variable in class org.elasticsearch.index.IndexModule
- INDEX_READ_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_READ_ONLY_ALLOW_DELETE_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_READ_ONLY_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_READ_ONLY_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_REOPENED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of opening a closed index.
- INDEX_RESIZE_SOURCE_NAME - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_RESIZE_SOURCE_NAME_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_RESIZE_SOURCE_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_RESIZE_SOURCE_UUID_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_ROUTING_ALLOCATION_ENABLE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- INDEX_ROUTING_EXCLUDE_GROUP_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_ROUTING_EXCLUDE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_ROUTING_INCLUDE_GROUP_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_ROUTING_INCLUDE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_ROUTING_INITIAL_RECOVERY_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_ROUTING_PARTITION_SIZE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_ROUTING_REBALANCE_ENABLE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- INDEX_ROUTING_REQUIRE_GROUP_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_ROUTING_REQUIRE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_SEARCH_SLOWLOG_LEVEL - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_DEBUG_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_INFO_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_TRACE_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_WARN_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_DEBUG_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_INFO_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_TRACE_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_WARN_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_THROTTLED - Static variable in class org.elasticsearch.index.IndexSettings
-
Marks an index to be searched throttled.
- INDEX_SETTING_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_SETTINGS_KEY_PREDICATE - Static variable in class org.elasticsearch.common.settings.IndexScopedSettings
- INDEX_SHRINK_SOURCE_NAME - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_SHRINK_SOURCE_NAME_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_SHRINK_SOURCE_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_SHRINK_SOURCE_UUID_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_SOFT_DELETES_RETENTION_LEASE_PERIOD_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls the maximum length of time since a retention lease is created or renewed before it is considered expired.
- INDEX_SOFT_DELETES_RETENTION_OPERATIONS_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls how many soft-deleted documents will be kept around before being merged away.
- INDEX_SOFT_DELETES_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Specifies if the index should use soft-delete instead of hard-delete for update/delete operations.
- INDEX_SORT_FIELD_SETTING - Static variable in class org.elasticsearch.index.IndexSortConfig
-
The list of field names
- INDEX_SORT_MISSING_SETTING - Static variable in class org.elasticsearch.index.IndexSortConfig
-
The missing value for each specified sort field (ie.
- INDEX_SORT_MODE_SETTING - Static variable in class org.elasticsearch.index.IndexSortConfig
-
The
MultiValueMode
for each specified sort field (ie. - INDEX_SORT_ORDER_SETTING - Static variable in class org.elasticsearch.index.IndexSortConfig
-
The
SortOrder
for each specified sort field (ie. - INDEX_STATE_FILE_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_STORE_PRE_LOAD_SETTING - Static variable in class org.elasticsearch.index.IndexModule
-
On which extensions to load data into the file-system cache upon opening of files.
- INDEX_STORE_STATS_REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.store.Store
- INDEX_STORE_TYPE_SETTING - Static variable in class org.elasticsearch.index.IndexModule
- INDEX_TOTAL_SHARDS_PER_NODE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
-
Controls the maximum number of shards per index on a single Elasticsearch node.
- INDEX_TRANSLOG_DURABILITY_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_TRANSLOG_FLUSH_THRESHOLD_SIZE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_TRANSLOG_GENERATION_THRESHOLD_SIZE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
The maximum size of a translog generation.
- INDEX_TRANSLOG_RETENTION_AGE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls how long translog files that are no longer needed for persistence reasons will be kept around before being deleted.
- INDEX_TRANSLOG_RETENTION_SIZE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls how many translog files that are no longer needed for persistence reasons will be kept around before being deleted.
- INDEX_TRANSLOG_SYNC_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_TTL_DISABLE_PURGE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Deprecated.
- INDEX_UUID_NA_VALUE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- INDEX_WARMER_ENABLED_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_WRITE_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- IndexAction - Class in org.elasticsearch.action.index
- indexAliases(ClusterState, String, Predicate<AliasMetaData>, boolean, Set<String>) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Iterates through the list of indices and selects the effective list of required aliases for the given index.
- indexAliasesRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates an index aliases request allowing to add and remove aliases.
- indexAnalyzer() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- indexAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
-
A smart analyzer used for indexing that takes into account specific analyzers configured per
FieldMapper
. - indexAnalyzer() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- indexAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService
- indexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- IndexAnalyzers - Class in org.elasticsearch.index.analysis
-
IndexAnalyzers contains a name to analyzer mapping for a specific index.
- IndexAnalyzers(IndexSettings, NamedAnalyzer, NamedAnalyzer, NamedAnalyzer, Map<String, NamedAnalyzer>, Map<String, NamedAnalyzer>, Map<String, NamedAnalyzer>) - Constructor for class org.elasticsearch.index.analysis.IndexAnalyzers
- indexBlocked(ClusterBlockLevel, String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indexBlockedException(ClusterBlockLevel, String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indexBlockedRaiseException(ClusterBlockLevel, String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indexBlockLevel() - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- indexBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Index level block to check before request execution.
- indexBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- indexBlockLevel() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- indexBoost() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- indexBoost() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- indexBoost() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- indexBoost(String, float) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the boost a specific index or alias will receive when the query is executed against it.
- indexBoosts() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the boost a specific indices or aliases will receive when the query is executed against them.
- indexCache - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- IndexCache - Class in org.elasticsearch.index.cache
- IndexCache(IndexSettings, QueryCache, BitsetFilterCache) - Constructor for class org.elasticsearch.index.cache.IndexCache
- IndexClosedException - Exception in org.elasticsearch.indices
-
Exception indicating that one or more requested indices are closed.
- IndexClosedException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexClosedException
- IndexClosedException(Index) - Constructor for exception org.elasticsearch.indices.IndexClosedException
- IndexCommitRef(IndexCommit, CheckedRunnable<IOException>) - Constructor for class org.elasticsearch.index.engine.Engine.IndexCommitRef
- IndexComponent - Interface in org.elasticsearch.index
- indexCreated - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- indexCreated(Settings) - Static method in class org.elasticsearch.Version
-
Return the
Version
of Elasticsearch that has been used to create an index given its settings. - indexCreatedVersion - Variable in class org.elasticsearch.index.mapper.FieldMapper
- indexCreatedVersion() - Method in class org.elasticsearch.index.mapper.Mapper.BuilderContext
- IndexCreationException - Exception in org.elasticsearch.indices
- IndexCreationException(String, Throwable) - Constructor for exception org.elasticsearch.indices.IndexCreationException
- IndexCreationException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexCreationException
- INDEXED - org.elasticsearch.index.query.GeoExecType
- indexedShapeId() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- indexedShapeIndex() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- indexedShapeIndex(String) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Sets the name of the index where the indexed Shape can be found
- indexedShapePath() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- indexedShapePath(String) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Sets the path of the field in the indexed Shape document that has the Shape itself
- indexedShapeRouting() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- indexedShapeRouting(String) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Sets the optional routing to the indexed Shape that will be used in the query
- indexedShapeType() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- IndexEventListener - Interface in org.elasticsearch.index.shard
-
An index event listener is the primary extension point for plugins and build-in services to react / listen to per-index and per-shard events.
- indexExists(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexExists(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexExists(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
- IndexFailedEngineException - Exception in org.elasticsearch.index.engine
-
Deprecated.
- IndexFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.IndexFailedEngineException
-
Deprecated.
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint.Fielddata
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- indexFieldData() - Method in class org.elasticsearch.search.aggregations.support.FieldContext
- IndexFieldData<FD extends AtomicFieldData> - Interface in org.elasticsearch.index.fielddata
-
Thread-safe utility class that allows to get per-segment values via the
IndexFieldData.load(LeafReaderContext)
method. - IndexFieldData.Builder - Interface in org.elasticsearch.index.fielddata
- IndexFieldData.Global<FD extends AtomicFieldData> - Interface in org.elasticsearch.index.fielddata
- IndexFieldData.XFieldComparatorSource - Class in org.elasticsearch.index.fielddata
- IndexFieldData.XFieldComparatorSource.Nested - Class in org.elasticsearch.index.fielddata
-
Simple wrapper class around a filter that matches parent documents and a filter that matches child documents.
- IndexFieldDataCache - Interface in org.elasticsearch.index.fielddata
-
A simple field data cache abstraction on the *index* level.
- IndexFieldDataCache.Listener - Interface in org.elasticsearch.index.fielddata
- IndexFieldDataCache.None - Class in org.elasticsearch.index.fielddata
- IndexFieldDataService - Class in org.elasticsearch.index.fielddata
- IndexFieldDataService(IndexSettings, IndicesFieldDataCache, CircuitBreakerService, MapperService) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataService
- IndexFieldMapper - Class in org.elasticsearch.index.mapper
- IndexFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- IndexFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- IndexFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- IndexFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- indexFiles() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns list of files in the shard
- indexFiles() - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
Returns a list of file in the snapshot
- IndexGeoPointFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
IndexFieldData
for geo points. - indexGet(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexGet(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexGraveyard() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- indexGraveyard() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
The collection of index deletions in the cluster.
- indexGraveyard(IndexGraveyard) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- IndexGraveyard - Class in org.elasticsearch.cluster.metadata
-
A collection of tombstones for explicitly marking indices as deleted in the cluster state.
- IndexGraveyard(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.IndexGraveyard
- IndexGraveyard.Builder - Class in org.elasticsearch.cluster.metadata
-
A class to build an IndexGraveyard.
- IndexGraveyard.IndexGraveyardDiff - Class in org.elasticsearch.cluster.metadata
-
A class representing a diff of two IndexGraveyard objects.
- IndexGraveyard.Tombstone - Class in org.elasticsearch.cluster.metadata
-
An individual tombstone entry for representing a deleted index.
- IndexId - Class in org.elasticsearch.repositories
-
Represents a single snapshotted index in the repository.
- IndexId(String, String) - Constructor for class org.elasticsearch.repositories.IndexId
- IndexId(StreamInput) - Constructor for class org.elasticsearch.repositories.IndexId
- indexing - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- indexing() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- indexing(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Indexing - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- IndexingMemoryController - Class in org.elasticsearch.indices
- IndexingOperationListener - Interface in org.elasticsearch.index.shard
-
An indexing listener for indexing, delete, events.
- IndexingOperationListener.CompositeListener - Class in org.elasticsearch.index.shard
-
A Composite listener that multiplexes calls to each of the listeners methods.
- IndexingSlowLog - Class in org.elasticsearch.index
- indexingStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
- IndexingStats - Class in org.elasticsearch.index.shard
- IndexingStats() - Constructor for class org.elasticsearch.index.shard.IndexingStats
- IndexingStats(IndexingStats.Stats, Map<String, IndexingStats.Stats>) - Constructor for class org.elasticsearch.index.shard.IndexingStats
- IndexingStats.Stats - Class in org.elasticsearch.index.shard
- indexingStrategyForOperation(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- indexInsert(int, int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexInsert(int, KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- indexMetaData(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- IndexMetaData - Class in org.elasticsearch.cluster.metadata
- IndexMetaData.Builder - Class in org.elasticsearch.cluster.metadata
- IndexMetaData.State - Enum in org.elasticsearch.cluster.metadata
- indexMetaDataChanged(IndexMetaData, IndexMetaData) - Static method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff theIndexMetaData
for a given index has changed between the previous cluster state and the new cluster state. - IndexMetaDataUpdater - Class in org.elasticsearch.cluster.routing.allocation
-
Observer that tracks changes made to RoutingNodes in order to update the primary terms and in-sync allocation ids in
IndexMetaData
once the allocation round has completed. - IndexMetaDataUpdater() - Constructor for class org.elasticsearch.cluster.routing.allocation.IndexMetaDataUpdater
- IndexMetaWriteInfo(IndexMetaData, IndexMetaData, String) - Constructor for class org.elasticsearch.gateway.GatewayMetaState.IndexMetaWriteInfo
- IndexModule - Class in org.elasticsearch.index
-
IndexModule represents the central extension point for index level custom implementations like:
Similarity
- NewSimilarity
implementations can be registered throughIndexModule.addSimilarity(String, TriFunction)
while existing Providers can be referenced through Settings under theIndexModule.SIMILARITY_SETTINGS_PREFIX
prefix along with the "type" value. - IndexModule(IndexSettings, AnalysisRegistry, EngineFactory, Map<String, Function<IndexSettings, IndexStore>>) - Constructor for class org.elasticsearch.index.IndexModule
-
Construct the index module for the index with the specified index settings.
- IndexModule.IndexSearcherWrapperFactory - Interface in org.elasticsearch.index
-
Factory for creating new
IndexSearcherWrapper
instances - IndexModule.Type - Enum in org.elasticsearch.index
- indexNameExpressionResolver - Variable in class org.elasticsearch.action.support.TransportAction
- IndexNameExpressionResolver - Class in org.elasticsearch.cluster.metadata
- IndexNameExpressionResolver(Settings) - Constructor for class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- IndexNotFoundException - Exception in org.elasticsearch.index
- IndexNotFoundException(String) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNotFoundException(String, String) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
-
Construct with a custom message.
- IndexNotFoundException(String, Throwable) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNotFoundException(Index) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNotFoundException(Index, Throwable) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNumericFieldData - Interface in org.elasticsearch.index.fielddata
- IndexNumericFieldData.NumericType - Enum in org.elasticsearch.index.fielddata
- indexOf(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexOf(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexOptions(IndexOptions) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- indexOptions(IndexOptions) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- indexOptionsSet - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- indexOptionToString(IndexOptions) - Static method in class org.elasticsearch.index.mapper.FieldMapper
- IndexOrdinalsFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
IndexFieldData
for data that is indexed with ordinals. - IndexOutputOutputStream - Class in org.elasticsearch.common.lucene.store
-
OutputStream
that writes into underlying IndexOutput - IndexOutputOutputStream(IndexOutput) - Constructor for class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- indexPaths(Index) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all index paths.
- indexPhrases(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- indexPrefixes(int, int) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- IndexPrimaryShardNotAllocatedException - Exception in org.elasticsearch.indices
-
Thrown when some action cannot be performed because the primary shard of some shard group in an index has not been allocated post api action.
- IndexPrimaryShardNotAllocatedException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
- IndexPrimaryShardNotAllocatedException(Index) - Constructor for exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
- IndexQueryCache - Class in org.elasticsearch.index.cache.query
-
The index-level query cache.
- IndexQueryCache(IndexSettings, IndicesQueryCache) - Constructor for class org.elasticsearch.index.cache.query.IndexQueryCache
- indexReplace(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexReplace(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexRequest() - Static method in class org.elasticsearch.client.Requests
- indexRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Create an index request against a specific index.
- IndexRequest - Class in org.elasticsearch.action.index
-
Index request to index a typed JSON document into a specific index and make it searchable.
- IndexRequest() - Constructor for class org.elasticsearch.action.index.IndexRequest
- IndexRequest(String) - Constructor for class org.elasticsearch.action.index.IndexRequest
-
Constructs a new index request against the specific index.
- IndexRequest(String, String) - Constructor for class org.elasticsearch.action.index.IndexRequest
-
Constructs a new index request against the specific index and type.
- IndexRequest(String, String, String) - Constructor for class org.elasticsearch.action.index.IndexRequest
-
Constructs a new index request against the index, type, id and using the source.
- IndexRequestBuilder - Class in org.elasticsearch.action.index
-
An index document action request builder.
- IndexRequestBuilder(ElasticsearchClient, IndexAction) - Constructor for class org.elasticsearch.action.index.IndexRequestBuilder
- IndexRequestBuilder(ElasticsearchClient, IndexAction, String) - Constructor for class org.elasticsearch.action.index.IndexRequestBuilder
- IndexResponse - Class in org.elasticsearch.action.index
-
A response of an index operation,
- IndexResponse() - Constructor for class org.elasticsearch.action.index.IndexResponse
- IndexResponse(ShardId, String, String, long, long, long, boolean) - Constructor for class org.elasticsearch.action.index.IndexResponse
- IndexResponse.Builder - Class in org.elasticsearch.action.index
-
Builder class for
IndexResponse
. - IndexResult(long, long, long, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.IndexResult
- IndexResult(Exception, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.IndexResult
-
use in case of the index operation failed before getting to internal engine
- IndexResult(Exception, long, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.IndexResult
- IndexResult(Mapping) - Constructor for class org.elasticsearch.index.engine.Engine.IndexResult
- indexRouting() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the index routing value associated with the alias
- indexRouting() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- indexRouting(String) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates an index routing value to the alias
- indexRouting(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indexRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- indexRoutings() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- indexRoutings() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the routing values resolved by the coordinating node for the index pointed by
ShardSearchRequest.shardId()
. - indexRoutings() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- indexRoutingTable(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- IndexRoutingTable - Class in org.elasticsearch.cluster.routing
-
The
IndexRoutingTable
represents routing information for a single index. - IndexRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
- indexRoutingTableChanged(String) - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the routing table has changed for the given index. - IndexScope - org.elasticsearch.common.settings.Setting.Property
-
Index scope
- IndexScopedSettings - Class in org.elasticsearch.common.settings
-
Encapsulates all valid index level settings.
- IndexScopedSettings(Settings, Set<Setting<?>>) - Constructor for class org.elasticsearch.common.settings.IndexScopedSettings
- IndexSearcherWrapper - Class in org.elasticsearch.index.shard
-
Extension point to add custom functionality at request time to the
DirectoryReader
andIndexSearcher
managed by theIndexShard
. - IndexSearcherWrapper() - Constructor for class org.elasticsearch.index.shard.IndexSearcherWrapper
- IndexSegments - Class in org.elasticsearch.action.admin.indices.segments
- indexService(Index) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Returns an IndexService for the specified index if exists otherwise returns
null
. - indexService(Index) - Method in class org.elasticsearch.indices.IndicesService
-
Returns an IndexService for the specified index if exists otherwise returns
null
. - IndexService - Class in org.elasticsearch.index
- IndexService(IndexSettings, NodeEnvironment, NamedXContentRegistry, SimilarityService, IndexService.ShardStoreDeleter, AnalysisRegistry, EngineFactory, CircuitBreakerService, BigArrays, ThreadPool, ScriptService, Client, QueryCache, IndexStore, IndexEventListener, IndexModule.IndexSearcherWrapperFactory, MapperRegistry, IndicesFieldDataCache, List<SearchOperationListener>, List<IndexingOperationListener>, NamedWriteableRegistry) - Constructor for class org.elasticsearch.index.IndexService
- IndexService.ShardStoreDeleter - Interface in org.elasticsearch.index
- indexServiceSafe(Index) - Method in class org.elasticsearch.indices.IndicesService
-
Returns an IndexService for the specified index if exists otherwise a
IndexNotFoundException
is thrown. - indexSettings - Variable in class org.elasticsearch.index.AbstractIndexComponent
- indexSettings - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- indexSettings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns settings that should be added/changed in all restored indices
- indexSettings() - Method in class org.elasticsearch.index.mapper.Mapper.BuilderContext
- indexSettings() - Method in class org.elasticsearch.index.mapper.ParseContext
- indexSettings() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- indexSettings() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- indexSettings() - Method in interface org.elasticsearch.index.shard.IndexShardComponent
- indexSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets settings that should be added/changed in all restored indices
- indexSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets settings that should be added/changed in all restored indices
- indexSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets settings that should be added/changed in all restored indices
- indexSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets settings that should be added/changed in all restored indices
- IndexSettings - Class in org.elasticsearch.index
-
This class encapsulates all index level settings and handles settings updates.
- IndexSettings(IndexMetaData, Settings) - Constructor for class org.elasticsearch.index.IndexSettings
-
Creates a new
IndexSettings
instance. - IndexSettings(IndexMetaData, Settings, IndexScopedSettings) - Constructor for class org.elasticsearch.index.IndexSettings
-
Creates a new
IndexSettings
instance. - indexShard - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- indexShard() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- indexShard() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- indexShard() - Method in class org.elasticsearch.search.internal.SearchContext
- IndexShard - Class in org.elasticsearch.index.shard
- IndexShard(ShardRouting, IndexSettings, ShardPath, Store, Supplier<Sort>, IndexCache, MapperService, SimilarityService, EngineFactory, IndexEventListener, IndexSearcherWrapper, ThreadPool, BigArrays, Engine.Warmer, List<SearchOperationListener>, List<IndexingOperationListener>, Runnable, RetentionLeaseSyncer, CircuitBreakerService) - Constructor for class org.elasticsearch.index.shard.IndexShard
- IndexShard.ShardFailure - Class in org.elasticsearch.index.shard
-
Simple struct encapsulating a shard failure
- IndexShardClosedException - Exception in org.elasticsearch.index.shard
- IndexShardClosedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
- IndexShardClosedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
- IndexShardClosedException(ShardId, String) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
- IndexShardClosedException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
- IndexShardComponent - Interface in org.elasticsearch.index.shard
- IndexShardNotRecoveringException - Exception in org.elasticsearch.index.shard
- IndexShardNotRecoveringException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotRecoveringException
- IndexShardNotRecoveringException(ShardId, IndexShardState) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotRecoveringException
- IndexShardNotStartedException - Exception in org.elasticsearch.index.shard
- IndexShardNotStartedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotStartedException
- IndexShardNotStartedException(ShardId, IndexShardState) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotStartedException
- IndexShardRecoveringException - Exception in org.elasticsearch.index.shard
- IndexShardRecoveringException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveringException
- IndexShardRecoveringException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveringException
- IndexShardRecoveryException - Exception in org.elasticsearch.index.shard
- IndexShardRecoveryException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveryException
- IndexShardRecoveryException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveryException
- IndexShardRelocatedException - Exception in org.elasticsearch.index.shard
- IndexShardRelocatedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
- IndexShardRelocatedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
- IndexShardRelocatedException(ShardId, String) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
- IndexShardRestoreException - Exception in org.elasticsearch.index.snapshots
-
Generic shard restore exception
- IndexShardRestoreException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
- IndexShardRestoreException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
- IndexShardRestoreException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
- IndexShardRestoreFailedException - Exception in org.elasticsearch.index.snapshots
-
Thrown when restore of a shard fails
- IndexShardRestoreFailedException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
- IndexShardRestoreFailedException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
- IndexShardRestoreFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
- IndexShardRoutingTable - Class in org.elasticsearch.cluster.routing
-
IndexShardRoutingTable
encapsulates all instances of a single shard. - IndexShardRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
- indexShards(ClusterState, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- IndexShardSegments - Class in org.elasticsearch.action.admin.indices.segments
- IndexShardSnapshotException - Exception in org.elasticsearch.index.snapshots
-
Generic shard snapshot exception
- IndexShardSnapshotException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
- IndexShardSnapshotException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
- IndexShardSnapshotException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
- IndexShardSnapshotException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
- IndexShardSnapshotFailedException - Exception in org.elasticsearch.index.snapshots
-
Thrown when snapshot process is failed on a shard level
- IndexShardSnapshotFailedException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
- IndexShardSnapshotFailedException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
- IndexShardSnapshotFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
- IndexShardSnapshotFailedException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
- IndexShardSnapshotStatus - Class in org.elasticsearch.index.snapshots
-
Represent shard snapshot status
- IndexShardSnapshotStatus.Copy - Class in org.elasticsearch.index.snapshots
-
Returns an immutable state of
IndexShardSnapshotStatus
at a given point in time. - IndexShardSnapshotStatus.Stage - Enum in org.elasticsearch.index.snapshots
-
Snapshot stage
- IndexShardStartedException - Exception in org.elasticsearch.index.shard
- IndexShardStartedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardStartedException
- IndexShardStartedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardStartedException
- IndexShardState - Enum in org.elasticsearch.index.shard
- indexShardStateChanged(IndexShard, IndexShardState, IndexShardState, String) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after a shard's
IndexShardState
changes. - IndexShardStats - Class in org.elasticsearch.action.admin.indices.stats
- IndexShardStats(ShardId, ShardStats[]) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- IndexShardUpgradeStatus - Class in org.elasticsearch.action.admin.indices.upgrade.get
- indexSize - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- IndexSortConfig - Class in org.elasticsearch.index
-
Holds all the information that is used to build the sort order of an index.
- IndexSortConfig(IndexSettings) - Constructor for class org.elasticsearch.index.IndexSortConfig
- IndexStats - Class in org.elasticsearch.action.admin.indices.stats
- IndexStats(String, String, ShardStats[]) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexStats
- IndexStats.IndexStatsBuilder - Class in org.elasticsearch.action.admin.indices.stats
- IndexStatsBuilder(String, String) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexStats.IndexStatsBuilder
- IndexStore - Class in org.elasticsearch.index.store
- IndexStore(IndexSettings) - Constructor for class org.elasticsearch.index.store.IndexStore
- IndexStorePlugin - Interface in org.elasticsearch.plugins
-
A plugin that provides alternative index store implementations.
- IndexTemplateMetaData - Class in org.elasticsearch.cluster.metadata
- IndexTemplateMetaData(String, int, Integer, List<String>, Settings, ImmutableOpenMap<String, CompressedXContent>, ImmutableOpenMap<String, AliasMetaData>) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- IndexTemplateMetaData.Builder - Class in org.elasticsearch.cluster.metadata
- indexTemplateMetaDataUpgraders - Variable in class org.elasticsearch.plugins.MetaDataUpgrader
- IndexTemplateMissingException - Exception in org.elasticsearch.indices
- IndexTemplateMissingException(String) - Constructor for exception org.elasticsearch.indices.IndexTemplateMissingException
- IndexTemplateMissingException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexTemplateMissingException
- IndexThrottle() - Constructor for class org.elasticsearch.index.engine.Engine.IndexThrottle
- indexTranslogOperations(List<Translog.Operation>, int, long, long, RetentionLeases, ActionListener<Long>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- indexTranslogOperations(List<Translog.Operation>, int, long, long, RetentionLeases, ActionListener<Long>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Index a set of translog operations on the target
- indexTranslogOperations(List<Translog.Operation>, int, long, long, RetentionLeases, ActionListener<Long>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- IndexUpgradeStatus - Class in org.elasticsearch.action.admin.indices.upgrade.get
- indexUUID - Variable in class org.elasticsearch.index.shard.ShardStateMetaData
- indexUUID() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- indexUUID() - Method in class org.elasticsearch.index.IndexService
- indexVersion() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns index version
- indexVersionCreated() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- indexVersionCreated() - Method in class org.elasticsearch.index.query.QueryShardContext
- IndexWarmer - Class in org.elasticsearch.index
- IndexWarmer.Listener - Interface in org.elasticsearch.index
- IndexWarmer.TerminationHandle - Interface in org.elasticsearch.index
-
A handle on the execution of warm-up action.
- indices - Variable in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indices() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- indices() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
- indices() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- indices() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
The indices
- indices() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns a list of indices that should be included into the snapshot
- indices() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns list of indices that should be restored from snapshot
- indices() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indices() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
The indices to be closed
- indices() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
The index to delete.
- indices() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- indices() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The indices the mappings will be put.
- indices() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
The indices to be opened
- indices() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- indices() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- indices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The list of indices where this field name is defined as
type
, or null if all indices have the sametype
for the field. - indices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- indices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- indices() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- indices() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- indices() - Method in interface org.elasticsearch.action.IndicesRequest
-
Returns the array of indices that the action relates to
- indices() - Method in class org.elasticsearch.action.OriginalIndices
- indices() - Method in class org.elasticsearch.action.search.SearchRequest
-
The indices
- indices() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indices() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- indices() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- indices() - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- indices() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- indices() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- indices() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- indices() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- indices() - Method in interface org.elasticsearch.client.AdminClient
-
A client allowing to perform actions/operations against the indices.
- indices() - Method in class org.elasticsearch.cluster.ack.IndicesClusterStateUpdateRequest
-
Returns the indices the operation needs to be executed on
- indices() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- indices() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indices() - Method in class org.elasticsearch.cluster.metadata.MetaData
- indices() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns list of indices
- indices() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- indices() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- indices() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- indices() - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- indices() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- indices() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- indices() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
List of restored indices
- indices() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns indices that were included in this snapshot.
- indices(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should information about indices (currently just indexing buffers) be returned
- indices(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should indices stats be returned.
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
Sets the indices the search will be executed on.
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets a list of indices that should be included into the snapshot
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the list of indices that should be restored from snapshot
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Sets the indices to be closed
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Sets the indices this put mapping operation will execute on.
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Sets the indices to be opened
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the indices to apply to settings update to
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Sets the indices for the shard stores request
- indices(String...) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
-
The list of indices to lookup
- indices(String...) - Method in interface org.elasticsearch.action.IndicesRequest.Replaceable
-
Sets the indices that the action relates to.
- indices(String...) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the indices the search will be executed on.
- indices(String...) - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indices(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- indices(String...) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- indices(String...) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- indices(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets a list of indices that should be included into the snapshot
- indices(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the list of indices that should be restored from snapshot
- indices(CommonStatsFlags) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- indices(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indices(ImmutableOpenMap<String, IndexMetaData>) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- indices(Index[]) - Method in class org.elasticsearch.cluster.ack.IndicesClusterStateUpdateRequest
-
Sets the indices the operation needs to be executed on
- INDICES - org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
- INDICES - org.elasticsearch.index.analysis.AnalyzerScope
- INDICES_ALL_ACTIVE - org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Re-balancing is allowed only once all shards on all indices are active.
- INDICES_BOOST_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- INDICES_CACHE_CLEAN_INTERVAL_SETTING - Static variable in class org.elasticsearch.indices.IndicesService
- INDICES_CACHE_QUERY_COUNT_SETTING - Static variable in class org.elasticsearch.indices.IndicesQueryCache
- INDICES_CACHE_QUERY_EXPIRE - Static variable in class org.elasticsearch.indices.IndicesRequestCache
- INDICES_CACHE_QUERY_SIZE - Static variable in class org.elasticsearch.indices.IndicesRequestCache
- INDICES_CACHE_QUERY_SIZE_SETTING - Static variable in class org.elasticsearch.indices.IndicesQueryCache
- INDICES_FIELDDATA_CACHE_SIZE_KEY - Static variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- INDICES_FOLDER - Static variable in class org.elasticsearch.env.NodeEnvironment
- INDICES_MAPPING_DYNAMIC_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
- INDICES_MAX_CLAUSE_COUNT_SETTING - Static variable in class org.elasticsearch.search.SearchModule
- INDICES_OPTIONS - Static variable in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- INDICES_PRIMARIES_ACTIVE - org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Re-balancing is allowed only once all primary shards on all indices are active.
- INDICES_QUERIES_CACHE_ALL_SEGMENTS_SETTING - Static variable in class org.elasticsearch.indices.IndicesQueryCache
- INDICES_RECOVERY_ACTIVITY_TIMEOUT_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
recoveries that don't show any activity for more then this interval will be failed.
- INDICES_RECOVERY_INTERNAL_ACTION_TIMEOUT_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
timeout value to use for requests made as part of the recovery process
- INDICES_RECOVERY_INTERNAL_LONG_ACTION_TIMEOUT_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
timeout value to use for requests made as part of the recovery process that are expected to take long time.
- INDICES_RECOVERY_MAX_BYTES_PER_SEC_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- INDICES_RECOVERY_MAX_CONCURRENT_FILE_CHUNKS_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
Controls the maximum number of file chunk requests that can be sent concurrently from the source node to the target node.
- INDICES_RECOVERY_RETRY_DELAY_NETWORK_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
how long to wait before retrying after network related issues
- INDICES_RECOVERY_RETRY_DELAY_STATE_SYNC_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
how long to wait before retrying after issues cause by cluster state syncing between nodes i.e., local node is not yet known on remote node, remote shard not yet started etc.
- INDICES_SHARDS_CLOSED_TIMEOUT - Static variable in class org.elasticsearch.indices.IndicesService
- INDICES_STORE_DELETE_SHARD_TIMEOUT - Static variable in class org.elasticsearch.indices.store.IndicesStore
- IndicesAdminClient - Interface in org.elasticsearch.client
-
Administrative actions/operations against indices.
- indicesAliases(IndicesAliasesClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService
- IndicesAliasesAction - Class in org.elasticsearch.action.admin.indices.alias
- IndicesAliasesClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.alias
-
Cluster state update request that allows to add or remove aliases
- IndicesAliasesClusterStateUpdateRequest(List<AliasAction>) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
- IndicesAliasesRequest - Class in org.elasticsearch.action.admin.indices.alias
-
A request to add/remove aliases for one or more indices.
- IndicesAliasesRequest() - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- IndicesAliasesRequest.AliasActions - Class in org.elasticsearch.action.admin.indices.alias
-
Request to take one or more actions on one or more indexes and alias combinations.
- IndicesAliasesRequest.AliasActions.Type - Enum in org.elasticsearch.action.admin.indices.alias
- IndicesAliasesRequestBuilder - Class in org.elasticsearch.action.admin.indices.alias
-
Builder for request to modify many aliases at once.
- IndicesAliasesRequestBuilder(ElasticsearchClient, IndicesAliasesAction) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
- indicesAllowReleaseResources(String[]) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
Returns
true
iff non of the given have aClusterBlockLevel.METADATA_WRITE
in place where theClusterBlock.isAllowReleaseResources()
returnsfalse
. - indicesBlockedException(ClusterBlockLevel, String[]) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- IndicesClusterStateService - Class in org.elasticsearch.indices.cluster
- IndicesClusterStateService(Settings, IndicesService, ClusterService, ThreadPool, PeerRecoveryTargetService, ShardStateAction, NodeMappingRefreshAction, RepositoriesService, SearchService, SyncedFlushService, PeerRecoverySourceService, SnapshotShardsService, PrimaryReplicaSyncer, GlobalCheckpointSyncAction, RetentionLeaseSyncAction, RetentionLeaseBackgroundSyncAction) - Constructor for class org.elasticsearch.indices.cluster.IndicesClusterStateService
- IndicesClusterStateService.AllocatedIndex<T extends IndicesClusterStateService.Shard> - Interface in org.elasticsearch.indices.cluster
- IndicesClusterStateService.AllocatedIndices<T extends IndicesClusterStateService.Shard,U extends IndicesClusterStateService.AllocatedIndex<T>> - Interface in org.elasticsearch.indices.cluster
- IndicesClusterStateService.AllocatedIndices.IndexRemovalReason - Enum in org.elasticsearch.indices.cluster
- IndicesClusterStateService.Shard - Interface in org.elasticsearch.indices.cluster
- IndicesClusterStateUpdateRequest<T extends IndicesClusterStateUpdateRequest<T>> - Class in org.elasticsearch.cluster.ack
-
Base cluster state update request that allows to execute update against multiple indices
- IndicesClusterStateUpdateRequest() - Constructor for class org.elasticsearch.cluster.ack.IndicesClusterStateUpdateRequest
- indicesCreated() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns the indices created in this event
- indicesDeleted() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns the indices deleted in this event
- IndicesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.indices
- indicesExistsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates an indices exists request.
- IndicesExistsRequest - Class in org.elasticsearch.action.admin.indices.exists.indices
- IndicesExistsRequest() - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- IndicesExistsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- IndicesExistsRequestBuilder - Class in org.elasticsearch.action.admin.indices.exists.indices
- IndicesExistsRequestBuilder(ElasticsearchClient, IndicesExistsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
- IndicesExistsResponse - Class in org.elasticsearch.action.admin.indices.exists.indices
- IndicesExistsResponse(boolean) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsResponse
- IndicesFieldDataCache - Class in org.elasticsearch.indices.fielddata.cache
- IndicesFieldDataCache(Settings, IndexFieldDataCache.Listener) - Constructor for class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- IndicesFieldDataCache.FieldDataWeigher - Class in org.elasticsearch.indices.fielddata.cache
- IndicesFieldDataCache.Key - Class in org.elasticsearch.indices.fielddata.cache
- indicesLevelRequest - Variable in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- IndicesModule - Class in org.elasticsearch.indices
-
Configures classes and services that are shared by indices on each node.
- IndicesModule(List<MapperPlugin>) - Constructor for class org.elasticsearch.indices.IndicesModule
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Specifies the indices options.
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- indicesOptions() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the options for this request
- indicesOptions() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- indicesOptions() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- indicesOptions() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- indicesOptions() - Method in interface org.elasticsearch.action.IndicesRequest
-
Returns the indices options used to resolve indices.
- indicesOptions() - Method in class org.elasticsearch.action.OriginalIndices
- indicesOptions() - Method in class org.elasticsearch.action.search.MultiSearchRequest
- indicesOptions() - Method in class org.elasticsearch.action.search.SearchRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- indicesOptions() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- indicesOptions() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- indicesOptions() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- indicesOptions() - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- indicesOptions() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- indicesOptions() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Specifies the indices options.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Specifies what type of requested indices to ignore and how to deal wild wildcard expressions.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Specifies what type of requested indices to ignore and wildcard indices expressions By default, expands wildcards to both open and closed indices
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.MultiSearchRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.SearchRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- IndicesOptions - Class in org.elasticsearch.action.support
-
Controls how to deal with unavailable concrete indices (closed or missing), how wildcard expressions are expanded to actual indices (all, closed or open indices) and how to deal with wildcard expressions that resolve to no indices.
- IndicesOptions(EnumSet<IndicesOptions.Option>, EnumSet<IndicesOptions.WildcardStates>) - Constructor for class org.elasticsearch.action.support.IndicesOptions
- IndicesOptions.Option - Enum in org.elasticsearch.action.support
- IndicesOptions.WildcardStates - Enum in org.elasticsearch.action.support
- indicesPath - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
- IndicesQueryCache - Class in org.elasticsearch.indices
- IndicesQueryCache(Settings) - Constructor for class org.elasticsearch.indices.IndicesQueryCache
- IndicesRequest - Interface in org.elasticsearch.action
-
Needs to be implemented by all
ActionRequest
subclasses that relate to one or more indices. - IndicesRequest.Replaceable - Interface in org.elasticsearch.action
- IndicesRequestCache - Class in org.elasticsearch.indices
-
The indices request cache allows to cache a shard level request stage responses, helping with improving similar requests that are potentially expensive (because of aggs for example).
- indicesRouting() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- indicesRouting(Map<String, IndexRoutingTable>) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- IndicesSegmentResponse - Class in org.elasticsearch.action.admin.indices.segments
- IndicesSegmentsAction - Class in org.elasticsearch.action.admin.indices.segments
- indicesSegmentsRequest(String...) - Static method in class org.elasticsearch.client.Requests
- IndicesSegmentsRequest - Class in org.elasticsearch.action.admin.indices.segments
- IndicesSegmentsRequest() - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- IndicesSegmentsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- IndicesSegmentsRequestBuilder - Class in org.elasticsearch.action.admin.indices.segments
- IndicesSegmentsRequestBuilder(ElasticsearchClient, IndicesSegmentsAction) - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
- indicesService - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- IndicesService - Class in org.elasticsearch.indices
- IndicesService(Settings, PluginsService, NodeEnvironment, NamedXContentRegistry, AnalysisRegistry, IndexNameExpressionResolver, MapperRegistry, NamedWriteableRegistry, ThreadPool, IndexScopedSettings, CircuitBreakerService, BigArrays, ScriptService, Client, MetaStateService, Collection<Function<IndexSettings, Optional<EngineFactory>>>, Map<String, Function<IndexSettings, IndexStore>>) - Constructor for class org.elasticsearch.indices.IndicesService
- IndicesService.ShardDeletionCheckResult - Enum in org.elasticsearch.indices
-
result type returned by
signaling different reasons why a shard can / cannot be deleted
- IndicesShardStoreRequestBuilder - Class in org.elasticsearch.action.admin.indices.shards
-
Request builder for
IndicesShardStoresRequest
- IndicesShardStoreRequestBuilder(ElasticsearchClient, Action<IndicesShardStoresRequest, IndicesShardStoresResponse, IndicesShardStoreRequestBuilder>, String...) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoreRequestBuilder
- IndicesShardStoresAction - Class in org.elasticsearch.action.admin.indices.shards
-
Action for
TransportIndicesShardStoresAction
Exposes shard store information for requested indices. - indicesShardStoresRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates an indices shard stores info request.
- IndicesShardStoresRequest - Class in org.elasticsearch.action.admin.indices.shards
-
Request for
IndicesShardStoresAction
- IndicesShardStoresRequest() - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- IndicesShardStoresRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Create a request for shard stores info for
indices
- IndicesShardStoresResponse - Class in org.elasticsearch.action.admin.indices.shards
-
Response for
IndicesShardStoresAction
Consists ofIndicesShardStoresResponse.StoreStatus
s for requested indices grouped by indices and shard ids and a list of encountered nodeIndicesShardStoresResponse.Failure
s - IndicesShardStoresResponse(ImmutableOpenMap<String, ImmutableOpenIntMap<List<IndicesShardStoresResponse.StoreStatus>>>, List<IndicesShardStoresResponse.Failure>) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- IndicesShardStoresResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- IndicesShardStoresResponse.Failure - Class in org.elasticsearch.action.admin.indices.shards
-
Single node failure while retrieving shard store information
- IndicesShardStoresResponse.StoreStatus - Class in org.elasticsearch.action.admin.indices.shards
-
Shard store information from a node
- IndicesShardStoresResponse.StoreStatus.AllocationStatus - Enum in org.elasticsearch.action.admin.indices.shards
-
The status of the shard store with respect to the cluster
- IndicesStatsAction - Class in org.elasticsearch.action.admin.indices.stats
- IndicesStatsRequest - Class in org.elasticsearch.action.admin.indices.stats
-
A request to get indices level stats.
- IndicesStatsRequest() - Constructor for class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- IndicesStatsRequestBuilder - Class in org.elasticsearch.action.admin.indices.stats
-
A request to get indices level stats.
- IndicesStatsRequestBuilder(ElasticsearchClient, IndicesStatsAction) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- IndicesStatsResponse - Class in org.elasticsearch.action.admin.indices.stats
- IndicesStore - Class in org.elasticsearch.indices.store
- IndicesStore(Settings, IndicesService, ClusterService, TransportService, ThreadPool) - Constructor for class org.elasticsearch.indices.store.IndicesStore
- InetAddresses - Class in org.elasticsearch.common.network
- InetAddresses() - Constructor for class org.elasticsearch.common.network.InetAddresses
- infer(boolean, boolean) - Static method in enum org.elasticsearch.index.query.GeoValidationMethod
-
Returns validation method corresponding to given coerce and ignoreMalformed values.
- InFlightOpsRequest() - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- InFlightOpsRequest(ShardId) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- info() - Method in interface org.elasticsearch.http.HttpServerTransport
- info() - Method in class org.elasticsearch.ingest.IngestService
- info() - Method in class org.elasticsearch.monitor.jvm.JvmService
- info() - Method in class org.elasticsearch.monitor.os.OsService
- info() - Method in class org.elasticsearch.monitor.process.ProcessService
- info() - Method in class org.elasticsearch.plugins.PluginsService
-
Get information about plugins and modules
- info() - Method in class org.elasticsearch.threadpool.ThreadPool
- info() - Method in class org.elasticsearch.transport.TransportService
- info(boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.node.NodeService
- info(String) - Method in class org.elasticsearch.threadpool.ThreadPool
- Info(String, ThreadPool.ThreadPoolType) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
- Info(String, ThreadPool.ThreadPoolType, int) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
- Info(String, ThreadPool.ThreadPoolType, int, int, TimeValue, SizeValue) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
- Info(StreamInput) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
- INFO - org.elasticsearch.index.SlowLogLevel
- ingest() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
- ingest() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- ingest(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should information about ingest be returned
- ingest(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should ingest statistics be returned.
- INGEST - org.elasticsearch.cluster.node.DiscoveryNode.Role
- INGEST_KEY - Static variable in class org.elasticsearch.ingest.IngestDocument
- IngestActionForwarder - Class in org.elasticsearch.action.ingest
-
A utility for forwarding ingest requests to ingest nodes in a round-robin fashion.
- IngestActionForwarder(TransportService) - Constructor for class org.elasticsearch.action.ingest.IngestActionForwarder
- IngestConditionalScript - Class in org.elasticsearch.script
-
A script used by
ConditionalProcessor
. - IngestConditionalScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.IngestConditionalScript
- IngestConditionalScript.Factory - Interface in org.elasticsearch.script
- IngestDocument - Class in org.elasticsearch.ingest
-
Represents a single document being captured before indexing and holds the source and metadata (like id, type and index).
- IngestDocument(String, String, String, String, String, Long, VersionType, Map<String, Object>) - Constructor for class org.elasticsearch.ingest.IngestDocument
- IngestDocument(Map<String, Object>, Map<String, Object>) - Constructor for class org.elasticsearch.ingest.IngestDocument
-
Constructor needed for testing that allows to create a new
IngestDocument
given the provided elasticsearch metadata, source and ingest metadata. - IngestDocument(IngestDocument) - Constructor for class org.elasticsearch.ingest.IngestDocument
-
Copy constructor that creates a new
IngestDocument
which has exactly the same properties as the one provided as argument - IngestDocument.MetaData - Enum in org.elasticsearch.ingest
- IngestInfo - Class in org.elasticsearch.ingest
- IngestInfo(List<ProcessorInfo>) - Constructor for class org.elasticsearch.ingest.IngestInfo
- IngestInfo(StreamInput) - Constructor for class org.elasticsearch.ingest.IngestInfo
-
Read from a stream.
- IngestMetadata - Class in org.elasticsearch.ingest
-
Holds the ingest pipelines that are available in the cluster
- IngestMetadata(Map<String, PipelineConfiguration>) - Constructor for class org.elasticsearch.ingest.IngestMetadata
- IngestMetadata(StreamInput) - Constructor for class org.elasticsearch.ingest.IngestMetadata
- IngestPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to add custom ingest processors - IngestScript - Class in org.elasticsearch.script
-
A script used by the Ingest Script Processor.
- IngestScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.IngestScript
- IngestScript.Factory - Interface in org.elasticsearch.script
- ingestService - Variable in class org.elasticsearch.ingest.Processor.Parameters
- IngestService - Class in org.elasticsearch.ingest
-
Holder class for several ingest related services.
- IngestService(ClusterService, ThreadPool, Environment, ScriptService, AnalysisRegistry, List<IngestPlugin>) - Constructor for class org.elasticsearch.ingest.IngestService
- IngestStats - Class in org.elasticsearch.ingest
- IngestStats(StreamInput) - Constructor for class org.elasticsearch.ingest.IngestStats
-
Read from a stream.
- IngestStats(IngestStats.Stats, List<IngestStats.PipelineStat>, Map<String, List<IngestStats.ProcessorStat>>) - Constructor for class org.elasticsearch.ingest.IngestStats
- IngestStats.PipelineStat - Class in org.elasticsearch.ingest
-
Container for pipeline stats.
- IngestStats.ProcessorStat - Class in org.elasticsearch.ingest
-
Container for processor stats.
- IngestStats.Stats - Class in org.elasticsearch.ingest
- init() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
- init() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
- init() - Method in interface org.elasticsearch.watcher.ResourceWatcher
-
Called once when the resource watcher is added to
ResourceWatcherService
- INIT - org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Snapshot hasn't started yet
- INIT - org.elasticsearch.cluster.RestoreInProgress.State
-
Initializing state
- INIT - org.elasticsearch.cluster.SnapshotsInProgress.State
- INIT - org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot hasn't started yet
- INIT - org.elasticsearch.indices.recovery.RecoveryState.Stage
- initCounter() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- INITIAL_ASSIGNMENT - Static variable in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- INITIAL_STATE_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.DiscoverySettings
- initialize() - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder.MapBinderProviderWithDependencies
- initialize(String, String, long) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Initializes an unassigned shard on a node.
- initialize(String, String, long, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
Initializes the current unassigned shard and moves it from the unassigned list.
- initialize(Map<GenericAction, TransportAction>, Supplier<String>, RemoteClusterService) - Method in class org.elasticsearch.client.node.NodeClient
- initialize(Injector) - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
-
Invoked by Guice at Injector-creation time to prepare providers for each element in this set.
- INITIALIZE - org.elasticsearch.search.profile.aggregation.AggregationTimingType
- initializeAsFromCloseToOpen(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new empty index, as as a result of opening a closed index.
- initializeAsFromDangling(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new index caused by dangling index imported.
- initializeAsNew(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new empty index, as if it was created from an API.
- initializeAsNewRestore(IndexMetaData, RecoverySource.SnapshotRecoverySource, IntSet) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new empty index, to be restored from a snapshot
- initializeAsRecovery(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes an existing index.
- initializeAsRestore(IndexMetaData, RecoverySource.SnapshotRecoverySource) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes an existing index, to be restored from a snapshot
- initialized() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns
true
if the state is initialized. - INITIALIZED - org.elasticsearch.common.component.Lifecycle.State
- initializeDelegate(MembersInjector<T>) - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
-
Sets the actual members injector.
- initializeDelegate(Provider<T>) - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
-
Sets the actual provider.
- initializedReplicaReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- initializedReplicaReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- initializedReplicaReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- initializedReplicaReinitialized(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when an initializing replica is reinitialized.
- initializeShard(ShardRouting, String, String, long, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Moves a shard from unassigned to initialize state
- initializeSnapshot(SnapshotId, List<IndexId>, MetaData) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- initializeSnapshot(SnapshotId, List<IndexId>, MetaData) - Method in class org.elasticsearch.repositories.FilterRepository
- initializeSnapshot(SnapshotId, List<IndexId>, MetaData) - Method in interface org.elasticsearch.repositories.Repository
-
Starts snapshotting process
- initializeUnassignedShard(RoutingAllocation, RoutingNodes, RoutingNode, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Initializes an unassigned shard on a node and removes it from the unassigned
- initializeUnassignedShard(RoutingAllocation, RoutingNodes, RoutingNode, ShardRouting, UnassignedInfo, RecoverySource) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Initializes an unassigned shard on a node and removes it from the unassigned
- initializing() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard is initializing (usually recovering either from peer shard or from gateway).
- INITIALIZING - org.elasticsearch.cluster.routing.ShardRoutingState
-
The shard is initializing (probably recovering from either a peer shard or gateway).
- initiateChannel(DiscoveryNode) - Method in class org.elasticsearch.transport.TcpTransport
-
Initiate a single tcp socket channel.
- initiateTracking(String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Called when the recovery process for a shard has opened the engine on the target shard.
- initiateTracking(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Called when the recovery process for a shard has opened the engine on the target shard.
- initInjector(Injector) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- initReader(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- initReaderForNormalization(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- initRestHandlers(Supplier<DiscoveryNodes>) - Method in class org.elasticsearch.action.ActionModule
- initScheduler(Settings) - Static method in interface org.elasticsearch.threadpool.Scheduler
-
Create a scheduler that can be used client side.
- initScript() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Get the
init
script. - initScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Set the
init
script. - InitScript(Map<String, Object>, Object) - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- Inject - Annotation Type in org.elasticsearch.common.inject
-
Annotates members of your implementation class (constructors, methods and fields) into which the
Injector
should inject values. - InjectionListener<I> - Interface in org.elasticsearch.common.inject.spi
-
Listens for injections into instances of type
I
. - InjectionPoint - Class in org.elasticsearch.common.inject.spi
-
A constructor, field or method that can receive injections.
- InjectionRequest<T> - Class in org.elasticsearch.common.inject.spi
-
A request to inject the instance fields and methods of an instance.
- InjectionRequest(Object, TypeLiteral<T>, T) - Constructor for class org.elasticsearch.common.inject.spi.InjectionRequest
- injectMembers(Object) - Method in interface org.elasticsearch.common.inject.Injector
-
Injects dependencies into the fields and methods of
instance
. - injectMembers(T) - Method in interface org.elasticsearch.common.inject.MembersInjector
-
Injects dependencies into the fields and methods of
instance
. - injector() - Method in class org.elasticsearch.node.Node
- Injector - Interface in org.elasticsearch.common.inject
-
Builds the graphs of objects that make up your application.
- INLINE - org.elasticsearch.script.ScriptType
-
INLINE scripts are specified in numerous queries and compiled on-the-fly.
- INNER_HITS_FIELD - Static variable in class org.elasticsearch.search.collapse.CollapseBuilder
- innerAllocatedUnassigned(RoutingAllocation, PrimaryShardAllocator, ReplicaShardAllocator) - Static method in class org.elasticsearch.gateway.GatewayAllocator
- innerBuild(SearchContext, Map<String, ValuesSourceConfig<ValuesSource.Numeric>>, DocValueFormat, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- innerBuild(SearchContext, Map<String, ValuesSourceConfig<VS>>, DocValueFormat, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<?>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Creates a
CompositeValuesSourceConfig
for this source. - innerBuild(SearchContext, ValuesSourceConfig<?>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- innerBuild(SearchContext, ValuesSourceConfig<?>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- innerBuild(SearchContext, ValuesSourceConfig<?>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Bytes>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.GeoPoint>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.GeoPoint>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.GeoPoint>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.GeoPoint>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource.Numeric>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<ValuesSource>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- innerBuild(SearchContext, ValuesSourceConfig<VS>, AggregatorFactory<?>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- innerBuildContext(int, QueryShardContext) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- innerBuildContext(int, QueryShardContext) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
-
Extensions override this to build the context that they need for rescoring.
- innerContent() - Method in class org.elasticsearch.rest.RestRequest
- innerDocs(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
-
Get a
DocIdSet
that matches the inner documents. - innerEquals(AB) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- innerEquals(Object) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- innerEquals(DateHistogramValuesSourceBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- innerEquals(HistogramValuesSourceBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- innerEquals(TermsValuesSourceBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- innerEquals(BucketMetricsPipelineAggregationBuilder<AF>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- innerEquals(BucketMetricsPipelineAggregationBuilder<AvgBucketPipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- innerEquals(BucketMetricsPipelineAggregationBuilder<MaxBucketPipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- innerEquals(BucketMetricsPipelineAggregationBuilder<MinBucketPipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- innerEquals(BucketMetricsPipelineAggregationBuilder<PercentilesBucketPipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- innerEquals(BucketMetricsPipelineAggregationBuilder<ExtendedStatsBucketPipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- innerEquals(BucketMetricsPipelineAggregationBuilder<StatsBucketPipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- innerEquals(BucketMetricsPipelineAggregationBuilder<SumBucketPipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- innerExecute(String, CompletionSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggester
- innerExecute(String, PhraseSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
- innerExecute(String, TermSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.term.TermSuggester
- innerExecute(String, T, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.Suggester
- innerFromXContent(XContentParser) - Static method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- innerFromXContent(XContentParser, boolean) - Static method in exception org.elasticsearch.ElasticsearchException
- innerFromXContent(XContentParser, String) - Static method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- innerGetRaw(Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- innerHashCode() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- innerHit() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Returns inner hit definition in the scope of this query and reusing the defined type and query.
- innerHit(InnerHitBuilder) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- innerHitBuilder - Variable in class org.elasticsearch.index.query.InnerHitContextBuilder
- InnerHitBuilder - Class in org.elasticsearch.index.query
- InnerHitBuilder() - Constructor for class org.elasticsearch.index.query.InnerHitBuilder
- InnerHitBuilder(String) - Constructor for class org.elasticsearch.index.query.InnerHitBuilder
- InnerHitBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.InnerHitBuilder
-
Read from a stream.
- InnerHitContextBuilder - Class in org.elasticsearch.index.query
-
A builder for
InnerHitsContext.InnerHitSubContext
- InnerHitContextBuilder(QueryBuilder, InnerHitBuilder, Map<String, InnerHitContextBuilder>) - Constructor for class org.elasticsearch.index.query.InnerHitContextBuilder
- innerHits() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- innerHits() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- innerHits() - Method in class org.elasticsearch.search.internal.SearchContext
- InnerHitsContext - Class in org.elasticsearch.search.fetch.subphase
-
Context used for inner hits retrieval
- InnerHitsContext() - Constructor for class org.elasticsearch.search.fetch.subphase.InnerHitsContext
- InnerHitsContext.InnerHitSubContext - Class in org.elasticsearch.search.fetch.subphase
- InnerHitsFetchSubPhase - Class in org.elasticsearch.search.fetch.subphase
- InnerHitsFetchSubPhase(FetchPhase) - Constructor for class org.elasticsearch.search.fetch.subphase.InnerHitsFetchSubPhase
- InnerHitSubContext(String, SearchContext) - Constructor for class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- innerOnFailure(Exception) - Method in class org.elasticsearch.action.NotifyOnceListener
- innerOnResponse(Response) - Method in class org.elasticsearch.action.NotifyOnceListener
- innerPut(PutPipelineRequest, ClusterState) - Static method in class org.elasticsearch.ingest.IngestService
- innerQueries() - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- innerQuery() - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- innerQuery() - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- innerQuery() - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- innerQuery() - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- innerReadFrom(StreamInput) - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- innerReadFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- innerReadFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- innerToString(StringBuilder) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.DocWriteResponse
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponse
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.update.UpdateResponse
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.tasks.TaskResult
- innerToXContent(XContentBuilder, ToXContent.Params, Throwable, String, String, Map<String, List<String>>, Map<String, List<String>>, Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Write subclass' state to the stream
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Write subclass's state to the stream.
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- innerWriteTo(StreamOutput, boolean) - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- innerXContent(XContentBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- innerXContent(XContentBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- innerXContent(XContentBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- innerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
We need to write a manual parser for this because of
BulkByScrollTask.StatusOrException
. - inOrder() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- inOrder(boolean) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
When
inOrder
is true, the spans from each clause must be in the same order as inclauses
and must be non-overlapping. - inPackage(Package) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches classes in the given package.
- InputStreamIndexInput - Class in org.elasticsearch.common.lucene.store
- InputStreamIndexInput(IndexInput, long) - Constructor for class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- InputStreamStreamInput - Class in org.elasticsearch.common.io.stream
- InputStreamStreamInput(InputStream) - Constructor for class org.elasticsearch.common.io.stream.InputStreamStreamInput
-
Creates a new InputStreamStreamInput with unlimited size
- InputStreamStreamInput(InputStream, long) - Constructor for class org.elasticsearch.common.io.stream.InputStreamStreamInput
-
Creates a new InputStreamStreamInput with a size limit
- insecureString(String) - Static method in class org.elasticsearch.common.settings.SecureSetting
-
A setting which contains a sensitive string, but which for legacy reasons must be found outside secure settings.
- insert(String[], int, T) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
- insert(String, T) - Method in class org.elasticsearch.common.path.PathTrie
- INSERT_ZEROS - org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
- insertElement(T[], T, int) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- insertionOrder - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- insertOrUpdate(String[], int, T, BiFunction<T, T, T>) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
- insertOrUpdate(String, T, BiFunction<T, T, T>) - Method in class org.elasticsearch.common.path.PathTrie
-
Insert a value for the given path.
- install(Module) - Method in class org.elasticsearch.common.inject.AbstractModule
- install(Module) - Method in interface org.elasticsearch.common.inject.Binder
-
Uses the given module to configure more bindings.
- install(Module) - Method in class org.elasticsearch.common.inject.PrivateModule
- instance() - Static method in class org.elasticsearch.tasks.LoggingTaskListener
-
Get the instance of NoopActionListener cast appropriately.
- Instance(T) - Constructor for class org.elasticsearch.common.inject.internal.InternalFactory.Instance
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.flush.FlushAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.flush.SyncedFlushAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.get.GetIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.shrink.ResizeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.shrink.ShrinkAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
- INSTANCE - Static variable in class org.elasticsearch.action.bulk.BulkAction
- INSTANCE - Static variable in class org.elasticsearch.action.delete.DeleteAction
- INSTANCE - Static variable in class org.elasticsearch.action.explain.ExplainAction
- INSTANCE - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesAction
- INSTANCE - Static variable in class org.elasticsearch.action.get.GetAction
- INSTANCE - Static variable in class org.elasticsearch.action.get.MultiGetAction
- INSTANCE - Static variable in class org.elasticsearch.action.index.IndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.ingest.DeletePipelineAction
- INSTANCE - Static variable in class org.elasticsearch.action.ingest.GetPipelineAction
- INSTANCE - Static variable in class org.elasticsearch.action.ingest.PutPipelineAction
- INSTANCE - Static variable in class org.elasticsearch.action.ingest.SimulatePipelineAction
- INSTANCE - Static variable in class org.elasticsearch.action.main.MainAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.ClearScrollAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.MultiSearchAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.SearchAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.SearchScrollAction
- INSTANCE - Static variable in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.EmptyResult
- INSTANCE - Static variable in class org.elasticsearch.action.termvectors.MultiTermVectorsAction
- INSTANCE - Static variable in class org.elasticsearch.action.termvectors.TermVectorsAction
- INSTANCE - Static variable in class org.elasticsearch.action.update.UpdateAction
- INSTANCE - Static variable in class org.elasticsearch.cluster.EmptyClusterInfoService
- INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.EmptyStoreRecoverySource
- INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.LocalShardsRecoverySource
- INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.PeerRecoverySource
- INSTANCE - Static variable in class org.elasticsearch.common.xcontent.LoggingDeprecationHandler
- INSTANCE - Static variable in class org.elasticsearch.index.reindex.DeleteByQueryAction
- INSTANCE - Static variable in class org.elasticsearch.index.reindex.ReindexAction
- INSTANCE - Static variable in class org.elasticsearch.index.reindex.UpdateByQueryAction
- INSTANCE - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Add
- INSTANCE - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove
- INSTANCE - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew
- INSTANCE - Static variable in class org.elasticsearch.persistent.CompletionPersistentTaskAction
- INSTANCE - Static variable in class org.elasticsearch.persistent.RemovePersistentTaskAction
- INSTANCE - Static variable in class org.elasticsearch.persistent.StartPersistentTaskAction
- INSTANCE - Static variable in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction
- INSTANCE - Static variable in class org.elasticsearch.search.rescore.QueryRescorer
- INSTANCE - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggester
- INSTANCE - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
- INSTANCE - Static variable in class org.elasticsearch.search.suggest.term.TermSuggester
- INSTANCE - Static variable in class org.elasticsearch.SpecialPermission
- INSTANCE - Static variable in class org.elasticsearch.transport.TransportRequest.Empty
- INSTANCE - Static variable in class org.elasticsearch.transport.TransportResponse.Empty
- INSTANCE_SAME - Static variable in class org.elasticsearch.transport.EmptyTransportResponseHandler
- InstanceBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a single instance.
- InstanceBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- InstanceBindingImpl(Object, Key<T>, Scoping, Set<InjectionPoint>, T) - Constructor for class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- InstanceBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Set<InjectionPoint>, T) - Constructor for class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- instanceClazz - Variable in class org.elasticsearch.script.ScriptContext
-
A class that is an instance of a script.
- InstanceShardOperationRequest<Request extends InstanceShardOperationRequest<Request>> - Class in org.elasticsearch.action.support.single.instance
- InstanceShardOperationRequest() - Constructor for class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- InstanceShardOperationRequest(String) - Constructor for class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- InstanceShardOperationRequestBuilder<Request extends InstanceShardOperationRequest<Request>,Response extends ActionResponse,RequestBuilder extends InstanceShardOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.single.instance
- InstanceShardOperationRequestBuilder(ElasticsearchClient, Action<Request, Response, RequestBuilder>, Request) - Constructor for class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
- inSubpackage(String) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches classes in the given package and its subpackages.
- INSUFFICIENT_STORAGE - org.elasticsearch.rest.RestStatus
-
The 507 (Insufficient Storage) status code means the method could not be performed on the resource because the server is unable to store the representation needed to successfully complete the request.
- inSyncAllocationIds(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- INT - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- INT_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- IntArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of integer values.
- Integer() - Constructor for class org.elasticsearch.common.collect.HppcMaps.Object.Integer
- INTEGER - org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- INTEGER - org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- interceptHandler(String, String, boolean, TransportRequestHandler<T>) - Method in interface org.elasticsearch.transport.TransportInterceptor
-
This is called for each handler that is registered via
TransportService.registerRequestHandler(String, Supplier, String, boolean, boolean, TransportRequestHandler)
orTransportService.registerRequestHandler(String, Supplier, String, TransportRequestHandler)
. - interceptSender(TransportInterceptor.AsyncSender) - Method in interface org.elasticsearch.transport.TransportInterceptor
-
This is called up-front providing the actual low level
TransportInterceptor.AsyncSender
that performs the low level send request. - INTERNAL - org.elasticsearch.index.engine.Engine.SearcherScope
- INTERNAL - org.elasticsearch.index.VersionType
- INTERNAL - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
This is the default and is based on
damerau_levenshtein
, but highly optimized for comparing string distance for terms inside the index. - INTERNAL_CLUSTER_INFO_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.InternalClusterInfoService
- INTERNAL_CLUSTER_INFO_UPDATE_INTERVAL_SETTING - Static variable in class org.elasticsearch.cluster.InternalClusterInfoService
- INTERNAL_SERVER_ERROR - org.elasticsearch.rest.RestStatus
-
The server encountered an unexpected condition which prevented it from fulfilling the request.
- internalActionLongTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- internalActionTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- InternalAdjacencyMatrix - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- InternalAdjacencyMatrix(String, List<InternalAdjacencyMatrix.InternalBucket>, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- InternalAdjacencyMatrix(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
-
Read from a stream.
- InternalAdjacencyMatrix.InternalBucket - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- InternalAggregation - Class in org.elasticsearch.search.aggregations
-
An internal implementation of
Aggregation
. - InternalAggregation(String, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation
-
Constructs an get with a given name.
- InternalAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation
-
Read from a stream.
- InternalAggregation.ReduceContext - Class in org.elasticsearch.search.aggregations
- InternalAggregationProfileTree - Class in org.elasticsearch.search.profile.aggregation
- InternalAggregationProfileTree() - Constructor for class org.elasticsearch.search.profile.aggregation.InternalAggregationProfileTree
- InternalAggregations - Class in org.elasticsearch.search.aggregations
-
An internal implementation of
Aggregations
. - InternalAggregations(List<InternalAggregation>) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregations
-
Constructs a new aggregation.
- InternalAggregations(List<InternalAggregation>, List<SiblingPipelineAggregator>) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregations
-
Constructs a new aggregation providing its
InternalAggregation
s andSiblingPipelineAggregator
s - InternalAutoDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Implementation of
Histogram
. - InternalAutoDateHistogram(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
-
Stream from a stream.
- InternalAutoDateHistogram.Bucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalAvg - Class in org.elasticsearch.search.aggregations.metrics.avg
- InternalAvg(String, double, long, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- InternalAvg(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
-
Read from a stream.
- InternalBinaryRange - Class in org.elasticsearch.search.aggregations.bucket.range
-
A range aggregation for data that is encoded in doc values using a binary representation.
- InternalBinaryRange(String, DocValueFormat, boolean, List<InternalBinaryRange.Bucket>, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- InternalBinaryRange(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
-
Read from a stream.
- InternalBinaryRange.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalBucket() - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation.InternalBucket
- InternalBucket(String, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- InternalBucket(String, long, InternalAggregations, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- InternalBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
-
Read from a stream.
- InternalBucket(StreamInput, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
-
Read from a stream.
- InternalBucketMetricValue - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics
- InternalBucketMetricValue(String, String[], double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- InternalBucketMetricValue(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
-
Read from a stream.
- InternalCardinality - Class in org.elasticsearch.search.aggregations.metrics.cardinality
- InternalCardinality(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
-
Read from a stream.
- InternalClusterInfoService - Class in org.elasticsearch.cluster
-
InternalClusterInfoService provides the ClusterInfoService interface, routinely updated on a timer.
- InternalClusterInfoService(Settings, ClusterService, ThreadPool, NodeClient, Consumer<ClusterInfo>) - Constructor for class org.elasticsearch.cluster.InternalClusterInfoService
- InternalClusterInfoService.SubmitReschedulingClusterInfoUpdatedJob - Class in org.elasticsearch.cluster
-
Class used to submit
InternalClusterInfoService.maybeRefresh()
on theInternalClusterInfoService
threadpool, these jobs will reschedule themselves by placing a new instance of this class onto the scheduled threadpool. - InternalComposite - Class in org.elasticsearch.search.aggregations.bucket.composite
- InternalComposite(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- InternalContext - Class in org.elasticsearch.common.inject.internal
-
Internal context.
- InternalContext() - Constructor for class org.elasticsearch.common.inject.internal.InternalContext
- InternalDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Implementation of
Histogram
. - InternalDateHistogram(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
-
Stream from a stream.
- InternalDateHistogram.Bucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalDateRange - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalDateRange(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange
-
Read from a stream.
- InternalDateRange.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalDateRange.Factory - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalDerivative - Class in org.elasticsearch.search.aggregations.pipeline.derivative
- InternalDerivative(String, double, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
- InternalDerivative(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
-
Read from a stream.
- InternalEngine - Class in org.elasticsearch.index.engine
- InternalEngine(EngineConfig) - Constructor for class org.elasticsearch.index.engine.InternalEngine
- InternalEngine.DeletionStrategy - Class in org.elasticsearch.index.engine
- InternalEngine.IndexingStrategy - Class in org.elasticsearch.index.engine
- InternalEngineFactory - Class in org.elasticsearch.index.engine
- InternalEngineFactory() - Constructor for class org.elasticsearch.index.engine.InternalEngineFactory
- InternalExtendedStats - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
- InternalExtendedStats(String, long, double, double, double, double, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- InternalExtendedStats(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
-
Read from a stream.
- InternalExtendedStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended
- InternalExtendedStatsBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.InternalExtendedStatsBucket
-
Read from a stream.
- InternalFactory<T> - Interface in org.elasticsearch.common.inject.internal
-
Creates objects which will be injected.
- InternalFactory.Instance<T> - Class in org.elasticsearch.common.inject.internal
-
ES: An factory that returns a pre created instance.
- InternalFilter - Class in org.elasticsearch.search.aggregations.bucket.filter
- InternalFilter(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
-
Stream from a stream.
- InternalFilters - Class in org.elasticsearch.search.aggregations.bucket.filter
- InternalFilters(String, List<InternalFilters.InternalBucket>, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- InternalFilters(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
-
Read from a stream.
- InternalFilters.InternalBucket - Class in org.elasticsearch.search.aggregations.bucket.filter
- internalFrequency(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- InternalGeoBounds - Class in org.elasticsearch.search.aggregations.metrics.geobounds
- InternalGeoBounds(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
-
Read from a stream.
- InternalGeoCentroid - Class in org.elasticsearch.search.aggregations.metrics.geocentroid
-
Serialization and merge logic for
GeoCentroidAggregator
. - InternalGeoCentroid(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
Read from a stream.
- InternalGeoDistance - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalGeoDistance(String, List<InternalGeoDistance.Bucket>, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
- InternalGeoDistance(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
-
Read from a stream.
- InternalGeoDistance.Factory - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalGeoHashGrid - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Represents a grid of cells where each cell's location is determined by a geohash.
- InternalGeoHashGrid(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
-
Read from a stream.
- InternalGlobal - Class in org.elasticsearch.search.aggregations.bucket.global
-
A global scope get (the document set on which we aggregate is all documents in the search context (ie.
- InternalGlobal(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
-
Read from a stream.
- InternalHDRPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- InternalHDRPercentileRanks(String, double[], DoubleHistogram, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
- InternalHDRPercentileRanks(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
-
Read from a stream.
- InternalHDRPercentileRanks.Iter - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- InternalHDRPercentiles - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- InternalHDRPercentiles(String, double[], DoubleHistogram, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
- InternalHDRPercentiles(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
-
Read from a stream.
- InternalHDRPercentiles.Iter - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- InternalHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Implementation of
Histogram
. - InternalHistogram(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
Stream from a stream.
- InternalHistogram.Bucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalIndex - org.elasticsearch.common.settings.Setting.Property
-
Indicates an index-level setting that is managed internally.
- InternalMappedSignificantTerms<A extends InternalMappedSignificantTerms<A,B>,B extends InternalSignificantTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.significant
- InternalMappedSignificantTerms(String, int, long, List<PipelineAggregator>, Map<String, Object>, DocValueFormat, long, long, SignificanceHeuristic, List<B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- InternalMappedSignificantTerms(StreamInput, InternalSignificantTerms.Bucket.Reader<B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- InternalMappedTerms<A extends InternalTerms<A,B>,B extends InternalTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Common superclass for results of the terms aggregation on mapped fields.
- InternalMappedTerms(String, BucketOrder, int, long, List<PipelineAggregator>, Map<String, Object>, DocValueFormat, int, boolean, long, List<B>, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- InternalMappedTerms(StreamInput, InternalTerms.Bucket.Reader<B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
-
Read from a stream.
- InternalMax - Class in org.elasticsearch.search.aggregations.metrics.max
- InternalMax(String, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- InternalMax(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.InternalMax
-
Read from a stream.
- InternalMedianAbsoluteDeviation - Class in org.elasticsearch.search.aggregations.metrics.mad
- InternalMedianAbsoluteDeviation(String, List<PipelineAggregator>, Map<String, Object>, DocValueFormat, TDigestState) - Constructor for class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- InternalMedianAbsoluteDeviation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- InternalMin - Class in org.elasticsearch.search.aggregations.metrics.min
- InternalMin(String, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- InternalMin(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.InternalMin
-
Read from a stream.
- InternalMissing - Class in org.elasticsearch.search.aggregations.bucket.missing
- InternalMissing(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
-
Read from a stream.
- InternalMultiBucketAggregation<A extends InternalMultiBucketAggregation,B extends InternalMultiBucketAggregation.InternalBucket> - Class in org.elasticsearch.search.aggregations
- InternalMultiBucketAggregation(String, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- InternalMultiBucketAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
Read from a stream.
- InternalMultiBucketAggregation.InternalBucket - Class in org.elasticsearch.search.aggregations
- InternalNested - Class in org.elasticsearch.search.aggregations.bucket.nested
-
Result of the
NestedAggregator
. - InternalNested(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
-
Read from a stream.
- InternalNumericMetricsAggregation - Class in org.elasticsearch.search.aggregations.metrics
- InternalNumericMetricsAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
-
Read from a stream.
- InternalNumericMetricsAggregation.MultiValue - Class in org.elasticsearch.search.aggregations.metrics
- InternalNumericMetricsAggregation.SingleValue - Class in org.elasticsearch.search.aggregations.metrics
- InternalOrder - Class in org.elasticsearch.search.aggregations
-
Implementations for
MultiBucketsAggregation.Bucket
ordering strategies. - InternalOrder(byte, String, boolean, Comparator<MultiBucketsAggregation.Bucket>) - Constructor for class org.elasticsearch.search.aggregations.InternalOrder
-
Creates an ordering strategy that sorts
MultiBucketsAggregation.Bucket
s by some property. - InternalOrder.Aggregation - Class in org.elasticsearch.search.aggregations
-
MultiBucketsAggregation.Bucket
ordering strategy to sort by a sub-aggregation. - InternalOrder.CompoundOrder - Class in org.elasticsearch.search.aggregations
-
MultiBucketsAggregation.Bucket
ordering strategy to sort by multiple criteria. - InternalOrder.Parser - Class in org.elasticsearch.search.aggregations
-
Contains logic for parsing a
BucketOrder
from aXContentParser
. - InternalOrder.Streams - Class in org.elasticsearch.search.aggregations
-
Contains logic for reading/writing
BucketOrder
from/to streams. - InternalParseContext(IndexSettings, DocumentMapperParser, DocumentMapper, SourceToParse, XContentParser) - Constructor for class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- InternalPercentilesBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
- InternalPercentilesBucket(String, double[], double[], DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- InternalPercentilesBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
Read from a stream.
- InternalPercentilesBucket.Iter - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
- InternalProfileCollector - Class in org.elasticsearch.search.profile.query
-
This class wraps a Lucene Collector and times the execution of: - setScorer() - collect() - doSetNextReader() - needsScores() InternalProfiler facilitates the linking of the Collector graph
- InternalProfileCollector(Collector, String, List<InternalProfileCollector>) - Constructor for class org.elasticsearch.search.profile.query.InternalProfileCollector
- InternalQueryContext(String, int, boolean) - Constructor for class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- InternalRange<B extends InternalRange.Bucket,R extends InternalRange<B,R>> - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalRange(String, List<B>, DocValueFormat, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- InternalRange(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
Read from a stream.
- InternalRange.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalRange.Factory<B extends InternalRange.Bucket,R extends InternalRange<B,R>> - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalReverseNested - Class in org.elasticsearch.search.aggregations.bucket.nested
-
Result of the
ReverseNestedAggregator
. - InternalReverseNested(String, long, InternalAggregations, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
- InternalReverseNested(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
-
Read from a stream.
- InternalSampler - Class in org.elasticsearch.search.aggregations.bucket.sampler
- InternalSampler(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
-
Read from a stream.
- InternalScriptedMetric - Class in org.elasticsearch.search.aggregations.metrics.scripted
- InternalScriptedMetric(String, Object, Script, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
- InternalScriptedMetric(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
-
Read from a stream.
- InternalScrollSearchRequest - Class in org.elasticsearch.search.internal
- InternalScrollSearchRequest() - Constructor for class org.elasticsearch.search.internal.InternalScrollSearchRequest
- InternalScrollSearchRequest(SearchScrollRequest, long) - Constructor for class org.elasticsearch.search.internal.InternalScrollSearchRequest
- InternalSearchResponse - Class in org.elasticsearch.search.internal
-
SearchResponseSections
subclass that can be serialized over the wire. - InternalSearchResponse(StreamInput) - Constructor for class org.elasticsearch.search.internal.InternalSearchResponse
- InternalSearchResponse(SearchHits, InternalAggregations, Suggest, SearchProfileShardResults, boolean, Boolean, int) - Constructor for class org.elasticsearch.search.internal.InternalSearchResponse
- InternalSettingsPreparer - Class in org.elasticsearch.node
- InternalSettingsPreparer() - Constructor for class org.elasticsearch.node.InternalSettingsPreparer
- InternalSignificantTerms<A extends InternalSignificantTerms<A,B>,B extends InternalSignificantTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.significant
-
Result of the significant terms aggregation.
- InternalSignificantTerms(String, int, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- InternalSignificantTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
Read from a stream.
- InternalSignificantTerms.Bucket<B extends InternalSignificantTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.significant
- InternalSignificantTerms.Bucket.Reader<B extends InternalSignificantTerms.Bucket<B>> - Interface in org.elasticsearch.search.aggregations.bucket.significant
-
Reads a bucket.
- InternalSimpleValue - Class in org.elasticsearch.search.aggregations.pipeline
- InternalSimpleValue(String, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- InternalSimpleValue(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
Read from a stream.
- InternalSingleBucketAggregation - Class in org.elasticsearch.search.aggregations.bucket
-
A base class for all the single bucket aggregations.
- InternalSingleBucketAggregation(String, long, InternalAggregations, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Creates a single bucket aggregation.
- InternalSingleBucketAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Read from a stream.
- internalSourceRef() - Method in class org.elasticsearch.index.get.GetResult
-
Internal source representation, might be compressed....
- internalSourceRef() - Method in class org.elasticsearch.search.lookup.SourceLookup
-
Internal source representation, might be compressed....
- InternalStats - Class in org.elasticsearch.search.aggregations.metrics.stats
- InternalStats(String, long, double, double, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- InternalStats(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
Read from a stream.
- InternalStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
- InternalStatsBucket(String, long, double, double, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
- InternalStatsBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
-
Read from a stream.
- InternalSum - Class in org.elasticsearch.search.aggregations.metrics.sum
- InternalSum(String, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- InternalSum(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
-
Read from a stream.
- InternalTDigestPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- InternalTDigestPercentileRanks(String, double[], TDigestState, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
- InternalTDigestPercentileRanks(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
-
Read from a stream.
- InternalTDigestPercentileRanks.Iter - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- InternalTDigestPercentiles - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- InternalTDigestPercentiles(String, double[], TDigestState, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
- InternalTDigestPercentiles(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
-
Read from a stream.
- InternalTDigestPercentiles.Iter - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- InternalTerms<A extends InternalTerms<A,B>,B extends InternalTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms
- InternalTerms(String, BucketOrder, int, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- InternalTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
Read from a stream.
- InternalTerms.Bucket<B extends InternalTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms
- InternalTerms.Bucket.Reader<B extends InternalTerms.Bucket<B>> - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
Reads a bucket.
- InternalTopHits - Class in org.elasticsearch.search.aggregations.metrics.tophits
-
Results of the
TopHitsAggregator
. - InternalTopHits(String, int, int, TopDocs, SearchHits, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
- InternalTopHits(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
-
Read from a stream.
- InternalValueCount - Class in org.elasticsearch.search.aggregations.metrics.valuecount
-
An internal implementation of
ValueCount
. - InternalValueCount(String, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- InternalValueCount(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
-
Read from a stream.
- InternalWeightedAvg - Class in org.elasticsearch.search.aggregations.metrics.weighted_avg
- InternalWeightedAvg(String, double, double, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- InternalWeightedAvg(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
-
Read from a stream.
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- interruptTask() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Subclasses can override this method to implement interruption of the future's computation.
- intersect(Weight, Weight, Collector, LeafReaderContext) - Static method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext
- intersection(double) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
-
Set the intersection of this line segment to the given position
- intersection(ObjectLookupContainer<T>, ObjectLookupContainer<T>) - Static method in class org.elasticsearch.common.collect.HppcMaps
- intersection(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- intersection(Coordinate, Coordinate, double) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Calculate the intersection of a line segment and a vertical dateline.
- INTERSECTION - org.elasticsearch.index.query.RegexpFlag
-
Enables intersection of the form:
<expression> & <expression>
- INTERSECTION_ORDER - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- intersections(double, ShapeBuilder.Edge[]) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Calculate all intersections of line segments and a vertical line.
- INTERSECTS - org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- INTERSECTS - org.elasticsearch.common.geo.ShapeRelation
- INTERSECTS - org.elasticsearch.index.mapper.MappedFieldType.Relation
- intersectsQuery(String, Object, Object, boolean, boolean) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- interval() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Returns the interval in milliseconds that is set on this source
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
-
Returns the interval that is set on this source
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Get the current interval in milliseconds that is set on this builder.
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Get the current interval that is set on this builder.
- interval(double) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
-
Sets the interval on this source.
- interval(double) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set the interval on this builder, and return the builder so that calls can be chained.
- interval(long) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Sets the interval on this source.
- interval(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set the interval on this builder, and return the builder so that calls can be chained.
- interval(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- interval(TimeValue) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- INTERVAL - org.elasticsearch.index.query.RegexpFlag
-
Enables numerical interval expression:
<n-m>
- INTERVAL_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- intField(FieldInfo, int) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- intPage(boolean) - Method in class org.elasticsearch.common.util.PageCacheRecycler
- intSetting(String, int, int, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, int, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, Setting<Integer>, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, Setting<Integer>, int, Setting.Validator<Integer>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intToBytes(int) - Static method in class org.elasticsearch.common.Numbers
-
Converts an int to a byte array.
- intValue() - Method in class org.elasticsearch.script.ScoreAccessor
- intValue() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
- INVALID_FILENAME_CHARS - Static variable in class org.elasticsearch.common.Strings
- InvalidAggregationPathException - Exception in org.elasticsearch.search.aggregations
- InvalidAggregationPathException(String) - Constructor for exception org.elasticsearch.search.aggregations.InvalidAggregationPathException
- InvalidAggregationPathException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.InvalidAggregationPathException
- InvalidAggregationPathException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.InvalidAggregationPathException
- InvalidAliasNameException - Exception in org.elasticsearch.indices
- InvalidAliasNameException(String, String) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
- InvalidAliasNameException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
- InvalidAliasNameException(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
- invalidate(K) - Method in class org.elasticsearch.common.cache.Cache
-
Invalidate the association for the specified key.
- invalidate(K, V) - Method in class org.elasticsearch.common.cache.Cache
-
Invalidate the entry for the specified key and value.
- invalidateAll() - Method in class org.elasticsearch.common.cache.Cache
-
Invalidate all cache entries.
- INVALIDATED - org.elasticsearch.common.cache.RemovalNotification.RemovalReason
- InvalidIndexNameException - Exception in org.elasticsearch.indices
- InvalidIndexNameException(String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
- InvalidIndexNameException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
- InvalidIndexNameException(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
- InvalidIndexTemplateException - Exception in org.elasticsearch.indices
- InvalidIndexTemplateException(String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexTemplateException
- InvalidIndexTemplateException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidIndexTemplateException
- InvalidSnapshotNameException - Exception in org.elasticsearch.snapshots
-
Thrown on the attempt to create a snapshot with invalid name
- InvalidSnapshotNameException(String, String, String) - Constructor for exception org.elasticsearch.snapshots.InvalidSnapshotNameException
- InvalidSnapshotNameException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.InvalidSnapshotNameException
- InvalidTypeNameException - Exception in org.elasticsearch.indices
- InvalidTypeNameException(String) - Constructor for exception org.elasticsearch.indices.InvalidTypeNameException
- InvalidTypeNameException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidTypeNameException
- IoStats(StreamInput) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.IoStats
- IoStats(FsInfo.DeviceStats[]) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.IoStats
- IP - org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- IP - org.elasticsearch.search.aggregations.support.ValueType
- IP - Static variable in interface org.elasticsearch.search.DocValueFormat
- IP_VALIDATOR - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
-
Validates the IP addresses in a group of
Settings
by looking for the keys "_ip", "_host_ip", and "_publish_ip" and ensuring each of their comma separated values that has no wildcards is a valid IP address. - IpFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for ip addresses. - IpFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- IpFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- IpFieldMapper.IpFieldType - Class in org.elasticsearch.index.mapper
- IpFieldMapper.IpFieldType.IpScriptDocValues - Class in org.elasticsearch.index.mapper
- IpFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- IpFieldType() - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- ipRange(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
IpRangeAggregationBuilder
aggregation with the given name. - IpRangeAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.range
- IpRangeAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- IpRangeAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- IpRangeAggregationBuilder(IpRangeAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- IpRangeAggregationBuilder.Range - Class in org.elasticsearch.search.aggregations.bucket.range
- IpScriptDocValues(SortedSetDocValues) - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- isA(ValueType) - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- isAborted() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
Whether this failure is the result of an abort.
- isAborted() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- isAbortOnVersionConflict() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Whether or not version conflicts cause the action to abort.
- isAccessibleDirectory(Path, Logger) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Check that a directory exists, is a directory and is readable by the current user
- isAcknowledged() - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
-
Returns whether the response is acknowledged or not
- isAcknowledged() - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateResponse
-
Whether the cluster state update was acknowledged or not
- isActive() - Method in class org.elasticsearch.index.shard.IndexShard
- isAfter(JodaCompatibleZonedDateTime) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- isAggregatable() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Whether this field can be aggregated on all indices.
- isAggregatable() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns true if the field is aggregatable.
- isAlias() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
- isAlias() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Index
- isAlias() - Method in interface org.elasticsearch.cluster.metadata.AliasOrIndex
- isAllIndices(Collection<String>) - Static method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Identifies whether the array containing index names given as argument refers to all indices The empty or null array identifies all indices
- isAllOrWildcard(String[]) - Static method in class org.elasticsearch.common.Strings
-
If an array only consists of zero or one element, which is "*" or "_all" return an empty array which is usually used as everything
- isAllowReleaseResources() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- isAllTypes(String[]) - Static method in class org.elasticsearch.cluster.metadata.MetaData
-
Identifies whether the array containing type names given as argument refers to all types The empty or null array identifies all types
- isAlpha() - Method in class org.elasticsearch.Version
-
Returns true iff this version is an alpha version Note: This has been introduced in elasticsearch version 5.
- isAnyContextEnabled() - Method in class org.elasticsearch.script.ScriptService
- isArray(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- isArtificial() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- isAssigned() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Assignment
- isAssigned() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- isAutogenerated(String) - Static method in class org.elasticsearch.index.store.Store
-
Returns true if the file is auto-generated by the store and shouldn't be deleted during cleanup.
- isAutoGeneratedIDsOptimizationEnabled() - Method in class org.elasticsearch.index.engine.EngineConfig
-
returns true if the engine is allowed to optimize indexing operations with an auto-generated ID
- isAutoThrottle() - Method in class org.elasticsearch.index.MergeSchedulerConfig
-
Returns
true
iff auto throttle is enabled. - isAvailable() - Method in class org.elasticsearch.action.main.MainResponse
- isBefore(JodaCompatibleZonedDateTime) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- isBeta() - Method in class org.elasticsearch.Version
- isBoost() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns whether to boost terms in query based on "score" or not.
- isBoostTerms() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- isBuiltinType(String) - Static method in class org.elasticsearch.index.IndexModule
- isCacheable() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Returns
true
iff the result of the processed search request is cacheable. - isCacheable(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- isCancellable() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns true if the task supports cancellation
- isCancelled() - Method in class org.elasticsearch.common.util.CancellableThreads
- isCancelled() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- isCancelled() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- isCancelled() - Method in class org.elasticsearch.search.internal.SearchContext
- isCancelled() - Method in class org.elasticsearch.tasks.CancellableTask
- isCancelled() - Method in interface org.elasticsearch.threadpool.Scheduler.Cancellable
-
Check if the execution has been cancelled
- isCancelled() - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- isChanged() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
-
Returns whether changes were made
- isChanged() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
-
Returns true if any the task list was changed since the builder was created
- isCloseConnectionException(Throwable) - Static method in class org.elasticsearch.common.transport.NetworkExceptionHelper
- isClosed - Variable in class org.elasticsearch.index.engine.Engine
- isClosed() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- isClosed() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- isClosed() - Method in class org.elasticsearch.index.translog.TranslogReader
- isClosed() - Method in class org.elasticsearch.index.translog.TranslogWriter
- isClosed() - Method in class org.elasticsearch.node.Node
-
Returns
true
if the node is closed. - isClosed() - Method in class org.elasticsearch.transport.CloseableConnection
- isClosed() - Method in interface org.elasticsearch.transport.Transport.Connection
- isCoerce(GeoValidationMethod) - Static method in enum org.elasticsearch.index.query.GeoValidationMethod
-
Returns whether or not to try and fix broken/wrapping bounding boxes.
- isCommitted() - Method in class org.elasticsearch.index.engine.Segment
- isCompatible(Version) - Method in class org.elasticsearch.Version
-
Returns
true
iff both version are compatible. - isComplete() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- isCompleted() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- isCompleted() - Method in class org.elasticsearch.tasks.TaskResult
- isCompound() - Method in class org.elasticsearch.index.engine.Segment
- isCompress() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns true if metadata and snapshot files should be compressed
- isCompress() - Method in class org.elasticsearch.repositories.fs.FsRepository
- isCompress(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- isCompressed(BytesReference) - Method in interface org.elasticsearch.common.compress.Compressor
- isCompressed(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
- isCompressed(BytesReference) - Method in class org.elasticsearch.common.compress.DeflateCompressor
- isConcrete(Class<?>) - Static method in class org.elasticsearch.common.Classes
- isConnectException(Throwable) - Static method in class org.elasticsearch.common.transport.NetworkExceptionHelper
- isConstant() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
-
Is this a constant binding? This returns true for constant bindings as well as toInstance() bindings.
- isConstructing() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- isContentConsumed() - Method in class org.elasticsearch.rest.RestRequest
- isContextEnabled(ScriptContext) - Method in class org.elasticsearch.script.ScriptService
- isCorruptionException(Throwable) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns
true
iff the given exception or one of it's causes is an instance ofCorruptIndexException
,IndexFormatTooOldException
, orIndexFormatTooNewException
otherwisefalse
. - isCorruptMarkerFileIsPresent(Directory) - Static method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- isCountDesc(BucketOrder) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Determine if the ordering strategy is sorting on bucket count descending.
- isCountedDown() - Method in class org.elasticsearch.common.util.concurrent.CountDown
-
Returns
true
iff the count-down has reached zero. - isCreated() - Method in class org.elasticsearch.index.engine.Engine.IndexResult
- isCrossClusterSearchEnabled() - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns
true
if at least one remote cluster is configured - isCurrent(Translog.TranslogGeneration) - Method in class org.elasticsearch.index.translog.Translog
-
Returns
true
iff the given generation is the current generation of this translog - isCustomDataPath() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- isCustomDataPath() - Method in class org.elasticsearch.index.shard.ShardPath
-
Returns
true
iff the data location is a custom data location and therefore outside of the nodes configured data paths. - isDataNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Should this node hold data (shards) or not.
- isDataNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- isDataOnlyNode(ClusterState) - Static method in class org.elasticsearch.gateway.GatewayMetaState
- isDateTimeFormatterSet() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
-
Whether an explicit format for this date field has been set already.
- isDecisionTaken() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Returns
true
if a decision was taken by the allocator,false
otherwise. - isDecisionTaken() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- isDecisionTaken() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- isDecisionTaken() - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
-
Returns
true
if either an allocation decision or a move decision was taken for the shard. - isDefaultAllowUnmappedFields() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if queries should be lenient about unmapped fields. - isDefaultEnabled() - Method in enum org.elasticsearch.script.ScriptType
- isDefaultProfile - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- isDelayed() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns true if allocation of this shard is delayed due to
UnassignedInfo.INDEX_DELAYED_NODE_LEFT_TIMEOUT_SETTING
- isDeleteOnExit() - Method in class org.elasticsearch.common.PidFile
-
Returns
true
iff the process id file is deleted on system exit. - isDeprecated() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting is deprecated, otherwisefalse
- isDeprecatedPattern(String) - Static method in class org.elasticsearch.common.joda.JodaDeprecationPatterns
-
Checks if date parsing pattern is deprecated.
- isDesktopServicesStore(Path) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Check whether the file denoted by the given path is a desktop services store created by Finder on macOS.
- isDone() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- isDryRun() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- isDryRun() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns if the rollover execution was skipped even when conditions were met
- isDynamic() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting is dynamically updateable, otherwisefalse
- isDynamicSetting(String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns
true
if the setting for the given key is dynamically updateable. - isEagerSingleton(Stage) - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns true if this scope is a singleton that should be loaded eagerly in
stage
. - isEmpty() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- isEmpty() - Method in class org.elasticsearch.cluster.RestoreInProgress
- isEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- isEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns
true
iff this collection contains one or more non-ignored unassigned shards. - isEmpty() - Method in class org.elasticsearch.common.collect.EvictingQueue
- isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- isEmpty() - Method in class org.elasticsearch.common.collect.MapBuilder
- isEmpty() - Method in class org.elasticsearch.common.geo.parsers.CoordinateNode
- isEmpty() - Method in class org.elasticsearch.common.settings.Settings
-
Returns
true
if this settings object contains no settings - isEmpty() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- isEmpty() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- isEmpty() - Method in class org.elasticsearch.script.DeprecationMap
- isEmpty() - Method in class org.elasticsearch.search.lookup.FieldLookup
- isEmpty() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- isEmpty() - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
- isEmpty() - Method in class org.elasticsearch.search.lookup.SourceLookup
- isEmpty(CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Check that the given CharSequence is either
null
or of length 0. - isEmpty(Object[]) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Checks if the given array contains any elements.
- isEnabled() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- isEnabled() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- isEnabled() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- isEnabled(String) - Method in class org.elasticsearch.common.lucene.LoggerInfoStream
- isEnableGcDeletes() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns
true
iff delete garbage collection in the engine should be enabled. - isEqual(JodaCompatibleZonedDateTime) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- isError(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- isExecuting() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- isExecutorShutdown() - Method in exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
-
Checks if the thread pool that rejected the execution was terminated shortly after the rejection.
- isExists() - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- isExists() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsResponse
- isExists() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsResponse
- isExists() - Method in class org.elasticsearch.action.explain.ExplainResponse
- isExists() - Method in class org.elasticsearch.action.get.GetResponse
-
Does the document exists.
- isExists() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- isExists() - Method in class org.elasticsearch.index.get.GetResult
-
Does the document exist.
- isExplain() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- isExplicitAllType(String[]) - Static method in class org.elasticsearch.cluster.metadata.MetaData
-
Identifies whether the array containing type names given as argument explicitly refers to all types The empty or null array doesn't explicitly map to all types
- isExplicitlyScoped() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns true if this scope was explicitly applied.
- isFailed() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
Is this a failed execution of an operation.
- isFailed() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
Is this a failed execution?
- isFailed() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
Is this a failed execution?
- isFailure() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
-
Is it a failed search?
- isFailure() - Method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- isFieldWithinQuery(IndexReader, Object, Object, boolean, boolean, DateTimeZone, DateMathParser, QueryRewriteContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- isFieldWithinQuery(IndexReader, Object, Object, boolean, boolean, DateTimeZone, DateMathParser, QueryRewriteContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Return whether all values of the given
IndexReader
are within the range, outside the range or cross the range. - isFilter() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Deprecated.The distinction between query and filter context is removed in the next major version.
- isFiltered() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting must be filtered, otherwisefalse
- isFinal() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting is final, otherwisefalse
- isFinalReduce() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
Returns
true
iff the current reduce phase is the final reduce phase. - isFinalSetting(String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns
true
if the setting for the given key is final. - isFloatingPoint() - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
-
Whether the underlying data is floating-point or not.
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- isFloatingPoint() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- isForceExecution() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
Should the runnable force its execution in case it gets rejected?
- isForceExecution() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- isFound() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- isFound() - Method in class org.elasticsearch.index.engine.Engine.DeleteResult
- isFragment() - Method in class org.elasticsearch.index.seqno.RetentionLease
- isFragment() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- isFragment() - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- isFreed() - Method in class org.elasticsearch.action.search.SearchTransportService.SearchFreeContextResponse
- isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- isGlobalStateEquals(MetaData, MetaData) - Static method in class org.elasticsearch.cluster.metadata.MetaData
- isHardLimit() - Method in class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- isHeldByCurrentThread() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
- isHeldByCurrentThread(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Returns
true
iff the caller thread holds the lock for the given key - isHidden(Path) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Check whether the file denoted by the given path is hidden.
- isHighlighted() - Method in class org.apache.lucene.search.uhighlight.Snippet
- isHttpEnabled() - Method in class org.elasticsearch.common.network.NetworkModule
- isIgnoredEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns
true
iff any unassigned shards are marked as temporarily ignored. - isIgnoreFailure() - Method in class org.elasticsearch.ingest.CompoundProcessor
- isIgnoreMalformed(GeoValidationMethod) - Static method in enum org.elasticsearch.index.query.GeoValidationMethod
-
Returns whether or not to skip bounding box validation.
- isIgnoreUnmapped() - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Whether to include inner hits in the search response hits if required mappings is missing
- isIncludeInParent() - Method in class org.elasticsearch.index.mapper.ObjectMapper.Nested
- isIncludeInRoot() - Method in class org.elasticsearch.index.mapper.ObjectMapper.Nested
- isIndicesOptions(String) - Static method in class org.elasticsearch.action.support.IndicesOptions
-
Returns true if the name represents a valid name for one of the indices option false otherwise
- isInetAddress(String) - Static method in class org.elasticsearch.common.network.InetAddresses
- isIngestNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Returns a boolean that tells whether this an ingest node or not
- isIngestNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- isInnerClass(Class<?>) - Static method in class org.elasticsearch.common.Classes
- isInSync() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Returns
true
if the shard copy is in-sync and contains the latest data. - isInternalIndex() - Method in class org.elasticsearch.common.settings.Setting
- isKeyAsc(BucketOrder) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Determine if the ordering strategy is sorting on bucket key ascending.
- isKeyDesc(BucketOrder) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Determine if the ordering strategy is sorting on bucket key descending.
- isKeyed() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- isKeyed() - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- isKeyOrder(BucketOrder) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Determine if the ordering strategy is sorting on bucket key (ascending or descending).
- isKnownWord(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- isKnownWord(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- isKnownWord(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
- isLangSupported(String) - Method in class org.elasticsearch.script.ScriptService
- isLeader() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Returns true if this task is a leader for other slice subtasks
- isLive - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndSeqNo
- isLoaded() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
- isLoaded() - Method in interface org.elasticsearch.common.settings.SecureSettings
-
Returns true iff the settings are loaded and retrievable.
- isLocalNodeElectedMaster() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- isLocalNodeElectedMaster() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns
true
if the local node is the elected master node. - isMapped() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- isMapped() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- isMapped() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- isMapped() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Return true if this aggregation is mapped, and can lead a reduction.
- isMappingSourceTyped(String, Map<String, Object>) - Static method in class org.elasticsearch.index.mapper.MapperService
-
Returns
true
if the givenmappingSource
includes a type as a top-level object. - isMappingSourceTyped(String, CompressedXContent) - Static method in class org.elasticsearch.index.mapper.MapperService
- isMarkedCorrupted() - Method in class org.elasticsearch.index.store.Store
- isMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Can this node become master or not.
- isMasterNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- isMatch() - Method in class org.elasticsearch.action.explain.ExplainResponse
- isMatchAllPattern(String) - Static method in class org.elasticsearch.common.regex.Regex
- isMemoryLocked() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns true if we were able to lock the process's address space.
- isMergedSegment(LeafReader) - Static method in class org.elasticsearch.index.engine.Engine
-
Returns whether a leaf reader comes from a merge (versus flush or addIndexes).
- isMetadataField() - Method in class org.elasticsearch.common.document.DocumentField
- isMetadataField(String) - Static method in class org.elasticsearch.index.mapper.MapperService
- isMetaDataField(String) - Method in class org.elasticsearch.indices.IndicesService
-
Returns true if the provided field is a registered metadata field (including ones registered via plugins), false otherwise.
- isMetaDataField(String) - Method in class org.elasticsearch.indices.mapper.MapperRegistry
-
Returns true if the provide field is a registered metadata field, false otherwise
- isMlockall() - Method in class org.elasticsearch.monitor.process.ProcessInfo
- isMultiValued(SortedSetDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns whether the provided values *might* be multi-valued.
- isNativesAvailable() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns true if we successfully loaded native libraries.
- isNested() - Method in class org.elasticsearch.index.mapper.ObjectMapper.Nested
- isNewCluster() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Determines whether or not the current cluster state represents an entirely new cluster, either when a node joins a cluster for the first time or when the node receives a cluster state update from a brand new cluster (different UUID from the previous cluster), which will happen when a master node is elected that has never been part of the cluster before.
- isNoScope() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns true if this is the default scope.
- isNoStopwords(Settings) - Static method in class org.elasticsearch.index.analysis.Analysis
- isNotA(ValueType) - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- isNull() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
- isNullable() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns true if null is a legal value for this dependency.
- isNullOrEmpty(String) - Static method in class org.elasticsearch.common.Strings
- isNumeric() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- ISO8601 - org.elasticsearch.common.time.FormatNames
- isObject(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- isOpen() - Method in interface org.elasticsearch.common.network.CloseableChannel
-
Indicates whether a channel is currently open
- isOpen() - Method in class org.elasticsearch.env.ShardLock
-
Returns true if this lock is still open ie.
- isOpen() - Method in class org.elasticsearch.index.translog.Translog
-
Returns
true
if thisTranslog
is still open. - isOptional() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns true if this injection point shall be skipped if the injector cannot resolve bindings for all required dependencies.
- isParent(String) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- isPartitionBased() - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- isPrefix - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- isPrefix() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
-
Returns if the context should be treated as a prefix
- isPreserveExisting() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Returns
true
iff the settings update should only add but not update settings. - isPreserveExisting() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Returns
true
iff the settings update should only add but not update settings. - isPrimary() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns
true
if explaining the primary shard for the shard id (seeClusterAllocationExplainRequest.getShard()
),false
if explaining a replica shard copy for the shard id, ornull
to use any unassigned shard (seeClusterAllocationExplainRequest.useAnyUnassignedShard()
). - isPrimary() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns
true
if the explained shard is primary,false
otherwise. - isPrimaryActive() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- isPrimaryMode() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns whether the replication tracker is in primary mode, i.e., whether the current shard is acting as primary from the point of view of replication.
- isPrimaryRelocation() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- isPrivate() - Method in interface org.elasticsearch.cluster.ClusterState.Custom
-
Returns
true
iff thisClusterState.Custom
is private to the cluster and should never be send to a client. - isPrivateIndex() - Method in class org.elasticsearch.common.settings.Setting
- isPrivateSetting(String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns
true
iff the setting is a private setting ie. - isPrivateSetting(String) - Method in class org.elasticsearch.common.settings.IndexScopedSettings
- isProfile() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- isProfile() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
Returns true if this shard search is being profiled or not
- isProfile() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- isProxyAction(String) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Returns
true
iff the given action is a proxy action - isProxyRequest(TransportRequest) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Returns
true
iff the given request is a proxy request - isQueryStringAllowLeadingWildcard() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if the query string parser should allow leading wildcards. - isQueryStringAnalyzeWildcard() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if the query string should analyze wildcards. - isQueryStringLenient() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if query string parsing should be lenient. - isRC() - Method in class org.elasticsearch.Version
- isReadAllowed() - Method in class org.elasticsearch.index.shard.IndexShard
-
returns true if the
IndexShardState
allows reading - isReadFromTranslog() - Method in class org.elasticsearch.index.engine.Engine.Get
- isReadOnly() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- isReadOnly() - Method in class org.elasticsearch.repositories.FilterRepository
- isReadOnly() - Method in interface org.elasticsearch.repositories.Repository
-
Returns true if the repository supports only read operations
- isReadOverrideException(Exception) - Static method in class org.elasticsearch.action.support.TransportActions
-
If a failure is already present, should this failure override it or not for read operations.
- isRecovering() - Method in class org.elasticsearch.index.engine.Engine
-
Returns
true
iff this engine is currently recovering from translog. - isRecovering() - Method in class org.elasticsearch.index.engine.InternalEngine
- isRecovery() - Method in enum org.elasticsearch.index.engine.Engine.Operation.Origin
- isRecycled() - Method in class org.elasticsearch.common.recycler.NoneRecycler.NV
- isRecycled() - Method in interface org.elasticsearch.common.recycler.Recycler.V
-
Whether this instance has been recycled (true) or newly allocated (false).
- isRefresh() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Call refresh on the indexes we've written to after the request ends?
- isRefreshNeeded() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns
true
iff one or more changes to the engine are not visible to via the current searcher *or* there are pending refresh listeners. - isRegexBased() - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- isRegistered(Class<? extends Throwable>, Version) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns
true
iff the given class is a registered for an exception to be read. - isRelease() - Method in class org.elasticsearch.Version
- isRelocated() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns whether the replication tracker has relocated away to another shard copy.
- isRelocatedPrimary() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns whether the shard is a relocated primary, i.e.
- isRelocationSourceOf(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if the routing is the relocation source for the given routing
- isRelocationTarget() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
if this shard is a relocation target for another shard (i.e., was created withShardRouting.initializeTargetRelocatingShard()
- isRelocationTargetOf(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if the routing is the relocation target of the given routing
- isRepositoryInUse(ClusterState, String) - Static method in class org.elasticsearch.snapshots.RestoreService
-
Checks if a repository is currently in use by one of the snapshots
- isRepositoryInUse(ClusterState, String) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Checks if a repository is currently in use by one of the snapshots
- isRequest(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- isRescored(int) - Method in class org.elasticsearch.search.rescore.RescoreContext
- isRetainedAtRuntime(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Returns true if the given annotation is retained at runtime.
- isRetry() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns
true
if this request has been sent to a shard copy more than once. - isRetry() - Method in class org.elasticsearch.index.engine.Engine.Index
-
Returns
true
if this index requests has been retried on the coordinating node and can therefor be delivered multiple times. - isRetryFailed() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Returns the current retry failed flag
- isRolledOver() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns true if the rollover was not simulated and the conditions were met
- isRoutingPartitionedIndex() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- isRunning() - Method in class org.elasticsearch.common.StopWatch
-
Return whether the stop watch is currently running.
- isSame(BlobStoreIndexShardSnapshot.FileInfo) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Checks if a file in a store is the same file
- isSame(StoreFileMetaData) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Checks if a file in a store is the same file
- isSame(StoreFileMetaData) - Method in class org.elasticsearch.index.store.StoreFileMetaData
-
Returns
true
iff the length and the checksums are the same. - isSameAllocation(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if this routing has the same allocation ID as another.
- isSameUUID(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Test whether the current index UUID is the same as the given one.
- isScheduled() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- isScopeAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Annotations
- isSearch() - Method in class org.elasticsearch.index.engine.Segment
- isSearchable() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Whether this field is indexed for search on all indices.
- isSearchable() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns true if the field is searchable.
- isSearchThrottled() - Method in class org.elasticsearch.index.IndexSettings
-
Returns true if the this index should be searched throttled ie.
- isSeqNoAndPrimaryTerm() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- isServerChannel() - Method in interface org.elasticsearch.transport.TcpChannel
-
Indicates if the channel is an inbound server channel.
- isSet() - Method in class org.elasticsearch.tasks.TaskId
- isSet(CommonStatsFlags.Flag) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- isShardNotAvailableException(Throwable) - Static method in class org.elasticsearch.action.support.TransportActions
- isShardsAcked() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
-
Deprecated.
- isShardsAcked() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Deprecated.
- isShardsAcked() - Method in class org.elasticsearch.cluster.ack.CreateIndexClusterStateUpdateResponse
-
Deprecated.
- isShardsAcknowledged() - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
-
Returns true if the requisite number of shards were started before returning from the index creation operation.
- isShardsAcknowledged() - Method in class org.elasticsearch.cluster.ack.CreateIndexClusterStateUpdateResponse
- isShardsAcknowledged() - Method in class org.elasticsearch.cluster.ack.OpenIndexClusterStateUpdateResponse
-
Returns whether the requisite number of shard copies started before the completion of the operation.
- isSimpleMatchPattern(String) - Static method in class org.elasticsearch.common.regex.Regex
-
Is the str a simple match pattern.
- isSingleType() - Method in class org.elasticsearch.index.IndexSettings
-
Returns whether the index enforces at most one type.
- isSkipDuplicates() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- isSkipUnavailable() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- isSnapshot() - Method in class org.elasticsearch.Build
- isSoftDeleteEnabled() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if soft-delete is enabled. - isSourceEmpty() - Method in class org.elasticsearch.action.get.GetResponse
-
Is the source empty (not available) or not.
- isSourceEmpty() - Method in class org.elasticsearch.index.get.GetResult
-
Is the source empty (not available) or not.
- isSubAction() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- isSubAction() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
Tells whether the action is a main one or a subaction.
- isSubAction() - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- isSucceeded() - Method in class org.elasticsearch.action.search.ClearScrollResponse
- isSuccess() - Method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- isSuccess() - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
- isSuggestOnly() - Method in class org.elasticsearch.action.search.SearchRequest
- isSuggestOnly() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- isSyncNeeded() - Method in class org.elasticsearch.index.shard.IndexShard
-
Checks if the underlying storage sync is required.
- isSynthetic() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- isSystemCallFilterInstalled() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns true if system call filter is installed (supported systems only)
- isSystemContext() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns
true
iff this context is a system context - isTempBlobName(String) - Static method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
-
Returns true if the blob is a leftover temporary blob.
- isTerminatedEarly() - Method in class org.elasticsearch.action.search.SearchResponse
-
Has the search operation terminated early due to reaching
terminateAfter
- isThrottled() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the
true
iff this engine is currently under index throttling. - isThrottled() - Method in class org.elasticsearch.index.engine.InternalEngine
- isThrottled() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- isThrottled() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
Returns if the index is under merge throttling control
- isTimedOut() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
true
if the waitForXXX has timeout out and did not match. - isTimedOut() - Method in class org.elasticsearch.action.search.SearchResponse
-
Has the search operation timed out.
- isTimedOut() - Method in class org.elasticsearch.cluster.ClusterStateObserver
-
indicates whether this observer has timed out
- isTimedOut() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
Did any of the sub-requests that were part of this request timeout?
- isTimedOut() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
Did this batch time out?
- isTrackScores() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- isTranslogSyncNeeded() - Method in class org.elasticsearch.index.engine.Engine
-
Checks if the underlying storage sync is required.
- isTranslogSyncNeeded() - Method in class org.elasticsearch.index.engine.InternalEngine
- isTranslogSyncNeeded() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- isTransportClient() - Method in class org.elasticsearch.common.network.NetworkModule
- isTransportStoppedForAction(Throwable, String) - Static method in class org.elasticsearch.ExceptionsHelper
- isTransportThread(Thread) - Static method in enum org.elasticsearch.transport.Transports
-
Utility method to detect whether a thread is a network thread.
- isTranspositions() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns if transpositions option is set if transpositions is set, then swapping one character for another counts as one edit instead of two.
- isTypeEnabled(ScriptType) - Method in class org.elasticsearch.script.ScriptService
- isUnicodeAware() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns if all measurements (like edit distance, transpositions and lengths) are in unicode code points (actual letters) instead of bytes.
- isValid() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- isValid() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
-
A boolean denoting whether the query is valid.
- isValidActionName(String) - Static method in class org.elasticsearch.transport.TransportService
-
Returns
true
iff the action name starts with a valid prefix. - isValidDouble(double) - Static method in class org.elasticsearch.common.Numbers
-
Returns true if value is neither NaN nor infinite.
- isValidKey(String) - Static method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns
true
iff the given key is a valid settings key otherwisefalse
- isValidLatitude(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Returns true if latitude is actually a valid latitude value.
- isValidLongitude(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Returns true if longitude is actually a valid longitude value.
- isValidPattern(String) - Static method in class org.elasticsearch.common.settings.SettingsFilter
-
Returns
true
iff the given string is either a valid settings key pattern or a simple regular expression - isVerbose() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- isVerbose() - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- isVersion() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- isVersionConflictForReads(long, long) - Method in enum org.elasticsearch.index.VersionType
-
Checks whether the current version conflicts with the expected version, based on the current version type.
- isVersionConflictForWrites(long, long, boolean) - Method in enum org.elasticsearch.index.VersionType
-
Checks whether the current version conflicts with the expected version, based on the current version type.
- isWaitForTimedOut() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
-
Returns whether the request timed out waiting for a cluster state with a metadata version equal or higher than the specified metadata.
- isWarmerEnabled() - Method in class org.elasticsearch.index.IndexSettings
-
Returns true if index warmers are enabled, otherwise
false
- isWeightRanked() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
Is the weight assigned for the node?
- isWithinCopyTo() - Method in class org.elasticsearch.index.mapper.ParseContext
- isWithinMultiField() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- isWithinMultiFields() - Method in class org.elasticsearch.index.mapper.ParseContext
- isWorker() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Returns true if this task is a worker task that performs search requests.
- Item() - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
- Item() - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- Item(String, String, String) - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
-
Constructs a single get item.
- Item(String, String, String) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Constructor for a given item / document request
- Item(String, String, XContentBuilder) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Constructor for an artificial document request, that is not present in the index.
- Item(SearchResponse, Exception) - Constructor for class org.elasticsearch.action.search.MultiSearchResponse.Item
- items() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- Iter(double[], double[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket.Iter
- Iter(double[], TDigestState) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks.Iter
- Iter(double[], TDigestState) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles.Iter
- Iter(double[], DoubleHistogram) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks.Iter
- Iter(double[], DoubleHistogram) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles.Iter
- iterableAsArrayList(Iterable<? extends E>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- Iterables - Class in org.elasticsearch.common.util.iterable
- Iterables() - Constructor for class org.elasticsearch.common.util.iterable.Iterables
- iterate(PortsRange.PortCallback) - Method in class org.elasticsearch.common.transport.PortsRange
- iterator() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- iterator() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- iterator() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- iterator() - Method in class org.elasticsearch.action.admin.indices.segments.IndexSegments
- iterator() - Method in class org.elasticsearch.action.admin.indices.segments.IndexShardSegments
- iterator() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- iterator() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- iterator() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- iterator() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- iterator() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- iterator() - Method in class org.elasticsearch.action.bulk.BulkResponse
- iterator() - Method in class org.elasticsearch.action.get.GetResponse
-
Deprecated.Use
GetResponse.getSource()
instead - iterator() - Method in class org.elasticsearch.action.get.MultiGetRequest
- iterator() - Method in class org.elasticsearch.action.get.MultiGetResponse
- iterator() - Method in class org.elasticsearch.action.search.MultiSearchResponse
- iterator() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- iterator() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- iterator() - Method in class org.elasticsearch.action.termvectors.TermVectorsFields
- iterator() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- iterator() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- iterator() - Method in class org.elasticsearch.cluster.metadata.MetaData
- iterator() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- iterator() - Method in class org.elasticsearch.cluster.RestoreInProgress
- iterator() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
- iterator() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- iterator() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- iterator() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- iterator() - Method in class org.elasticsearch.common.blobstore.BlobPath
- iterator() - Method in class org.elasticsearch.common.bytes.BytesReference
-
Returns a BytesRefIterator for this BytesReference.
- iterator() - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- iterator() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- iterator() - Method in class org.elasticsearch.common.collect.EvictingQueue
- iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns a cursor over the entries (key-value pairs) in this map.
- iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a cursor over the entries (key-value pairs) in this map.
- iterator() - Method in class org.elasticsearch.common.document.DocumentField
- iterator() - Method in class org.elasticsearch.common.FieldMemoryStats
- iterator() - Method in class org.elasticsearch.common.inject.ModulesBuilder
- iterator() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- iterator() - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- iterator() - Method in class org.elasticsearch.index.get.GetResult
- iterator() - Method in class org.elasticsearch.index.IndexService
- iterator() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
- iterator() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- iterator() - Method in class org.elasticsearch.index.mapper.FieldMapper
- iterator() - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- iterator() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- iterator() - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- iterator() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- iterator() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- iterator() - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- iterator() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
- iterator() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- iterator() - Method in class org.elasticsearch.indices.IndicesService
- iterator() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- iterator() - Method in class org.elasticsearch.monitor.fs.FsInfo
- iterator() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
- iterator() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- iterator() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Iterates over the
Aggregation
s. - iterator() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- iterator() - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- iterator() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentileRanks
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentiles
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentileRanks
- iterator() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- iterator() - Method in class org.elasticsearch.search.SearchHit
- iterator() - Method in class org.elasticsearch.search.SearchHits
- iterator() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
- iterator() - Method in class org.elasticsearch.search.suggest.Suggest
- iterator() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- iterator() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- iterator() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
- iterator() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
- Iterators - Class in org.elasticsearch.common.collect
- Iterators() - Constructor for class org.elasticsearch.common.collect.Iterators
J
- JARO_WINKLER - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
String distance algorithm based on Jaro-Winkler algorithm.
- JavaDateMathParser - Class in org.elasticsearch.common.time
-
A parser for date/time formatted text with optional date math.
- JLHScore - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- JLHScore() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
- JLHScore(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
-
Read from a stream.
- JLHScore.JLHScoreBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- JLHScoreBuilder() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore.JLHScoreBuilder
- Joda - Class in org.elasticsearch.common.joda
- Joda() - Constructor for class org.elasticsearch.common.joda.Joda
- Joda.EpochTimeParser - Class in org.elasticsearch.common.joda
- Joda.EpochTimePrinter - Class in org.elasticsearch.common.joda
- JodaCompatibleZonedDateTime - Class in org.elasticsearch.script
-
A wrapper around ZonedDateTime that exposes joda methods for backcompat.
- JodaCompatibleZonedDateTime(Instant, ZoneId) - Constructor for class org.elasticsearch.script.JodaCompatibleZonedDateTime
- JodaDateFormatter - Class in org.elasticsearch.common.joda
- JodaDateFormatter(String, DateTimeFormatter, DateTimeFormatter) - Constructor for class org.elasticsearch.common.joda.JodaDateFormatter
- JodaDateMathParser - Class in org.elasticsearch.common.joda
-
A parser for date/time formatted text with optional date math.
- JodaDateMathParser(JodaDateFormatter) - Constructor for class org.elasticsearch.common.joda.JodaDateMathParser
- JodaDeprecationPatterns - Class in org.elasticsearch.common.joda
- JodaDeprecationPatterns() - Constructor for class org.elasticsearch.common.joda.JodaDeprecationPatterns
- join(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
- join(BytesRef, BytesRefBuilder, BytesRef...) - Static method in class org.elasticsearch.search.suggest.phrase.WordScorer
- join(BytesRef, BytesRefBuilder, BytesRef, BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
- join(BytesRef, BytesRef, BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
- JOIN_RETRY_ATTEMPTS_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- JOIN_RETRY_DELAY_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- JOIN_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- joinField(String) - Static method in class org.elasticsearch.index.mapper.ParentFieldMapper
- joiningCluster() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
returns true if zen discovery is started and there is a currently a background thread active for (re)joining the cluster used for testing.
- JoinRequest() - Constructor for class org.elasticsearch.discovery.zen.MembershipAction.JoinRequest
- JoinTaskExecutor(Settings, AllocationService, ElectMasterService, Logger) - Constructor for class org.elasticsearch.discovery.zen.NodeJoinController.JoinTaskExecutor
- JTS_AVAILABLE - Static variable in class org.elasticsearch.common.geo.ShapesAvailability
- jtsGeometry(Geometry) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- jvm() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node JVM be returned.
- jvm() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node JVM be returned.
- jvm(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node JVM be returned.
- jvm(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node JVM be returned.
- JvmGcMonitorService - Class in org.elasticsearch.monitor.jvm
- JvmGcMonitorService(Settings, ThreadPool) - Constructor for class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- jvmInfo() - Static method in class org.elasticsearch.monitor.jvm.JvmInfo
- JvmInfo - Class in org.elasticsearch.monitor.jvm
- JvmInfo(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmInfo
- JvmInfo.Mem - Class in org.elasticsearch.monitor.jvm
- jvmService() - Method in class org.elasticsearch.monitor.MonitorService
- JvmService - Class in org.elasticsearch.monitor.jvm
- JvmService(Settings) - Constructor for class org.elasticsearch.monitor.jvm.JvmService
- jvmStats() - Static method in class org.elasticsearch.monitor.jvm.JvmStats
- JvmStats - Class in org.elasticsearch.monitor.jvm
- JvmStats(long, long, JvmStats.Mem, JvmStats.Threads, JvmStats.GarbageCollectors, List<JvmStats.BufferPool>, JvmStats.Classes) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats
- JvmStats(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats
- JvmStats.BufferPool - Class in org.elasticsearch.monitor.jvm
- JvmStats.Classes - Class in org.elasticsearch.monitor.jvm
- JvmStats.GarbageCollector - Class in org.elasticsearch.monitor.jvm
- JvmStats.GarbageCollectors - Class in org.elasticsearch.monitor.jvm
- JvmStats.Mem - Class in org.elasticsearch.monitor.jvm
- JvmStats.MemoryPool - Class in org.elasticsearch.monitor.jvm
- JvmStats.Threads - Class in org.elasticsearch.monitor.jvm
K
- KB - org.elasticsearch.common.unit.ByteSizeUnit
- keepAlive() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- keepAlive() - Method in class org.elasticsearch.search.internal.SearchContext
- keepAlive() - Method in class org.elasticsearch.search.Scroll
-
How long the resources will be kept open to support the scroll request.
- keepAlive(long) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- keepAlive(long) - Method in class org.elasticsearch.search.internal.SearchContext
- keepAlive(long) - Method in class org.elasticsearch.search.internal.SubSearchContext
- KEEPALIVE_INTERVAL_SETTING - Static variable in class org.elasticsearch.search.SearchService
- keepTaskList(boolean) - Method in class org.elasticsearch.common.StopWatch
-
Determine whether the TaskInfo array is built over time.
- key - Variable in class org.elasticsearch.common.settings.Setting.SimpleKey
- key - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
- key - Variable in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- key - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- key - Variable in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- key() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- key() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- key(boolean) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy that sorts buckets by their keys (ascending or descending).
- Key<T> - Class in org.elasticsearch.common.inject
-
Binding key consisting of an injection type and an optional annotation.
- Key() - Constructor for class org.elasticsearch.common.inject.Key
-
Constructs a new key.
- Key(Annotation) - Constructor for class org.elasticsearch.common.inject.Key
-
Constructs a new key.
- Key(Class<? extends Annotation>) - Constructor for class org.elasticsearch.common.inject.Key
-
Constructs a new key.
- KEY - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- KEY - Static variable in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- KEY_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- KEY_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- KEY_IN_SYNC_ALLOCATIONS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- KEY_PRIMARY_TERMS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- KeyComparable<T extends MultiBucketsAggregation.Bucket & KeyComparable<T>> - Interface in org.elasticsearch.search.aggregations
-
Defines behavior for comparing
bucket keys
to imposes a total ordering of buckets of the same type. - keyed - Variable in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- keyed - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- keyed - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- keyed - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- keyed - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- keyed - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- keyed - Variable in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return whether buckets should be returned as a hash.
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Return whether buckets should be returned as a hash.
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- keyed() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
-
Get whether the XContent response should be keyed
- keyed() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Get whether the XContent response should be keyed
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set whether to return buckets as a hash or as an array, and return the builder so that calls can be chained.
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set whether to return buckets as a hash or as an array, and return the builder so that calls can be chained.
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
-
Set whether the XContent response should be keyed
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Set whether the XContent response should be keyed
- KEYED_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- KEYED_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- KEYED_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- KeyedFilter(String, QueryBuilder) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- KeyedFilter(String, QueryBuilder) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- KeyedFilter(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
-
Read from a stream.
- KeyedFilter(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
-
Read from a stream.
- KeyedLock<T> - Class in org.elasticsearch.common.util.concurrent
-
This class manages locks.
- KeyedLock() - Constructor for class org.elasticsearch.common.util.concurrent.KeyedLock
-
Creates a non-fair lock
- KeyedLock(boolean) - Constructor for class org.elasticsearch.common.util.concurrent.KeyedLock
-
Creates a new lock
- keys - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- keys - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- keys() - Method in class org.elasticsearch.common.cache.Cache
-
An LRU sequencing of the keys in the cache that supports removal.
- keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns a specialized view of the keys of this associated container.
- keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a specialized view of the keys of this associated container.
- keys() - Method in class org.elasticsearch.common.settings.Settings.Builder
- keys() - Method in interface org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricValue
- keys() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- keys() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.ParsedBucketMetricValue
- keySerializer - Variable in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- keySet() - Method in class org.elasticsearch.common.settings.Settings
-
Returns the fully qualified setting names contained in this settings object.
- keySet() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- keySet() - Method in class org.elasticsearch.script.DeprecationMap
- keySet() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- keySet() - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
- keySet() - Method in class org.elasticsearch.search.lookup.SourceLookup
- keysIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns a direct iterator over the keys.
- keysIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a direct iterator over the keys.
- KeyStoreCli - Class in org.elasticsearch.common.settings
-
A cli tool for managing secrets in the elasticsearch keystore.
- keystorePath(Path) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Returns a path representing the ES keystore in the given config dir.
- KeyStoreWrapper - Class in org.elasticsearch.common.settings
-
A disk based container for sensitive settings in Elasticsearch.
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantLongTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantStringTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- keyTypeIsSet() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- KEYWORD - org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- KEYWORD_ANALYZER - Static variable in class org.elasticsearch.common.lucene.Lucene
- KeywordAnalyzerProvider - Class in org.elasticsearch.index.analysis
- KeywordAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeywordAnalyzerProvider
- KeywordFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper for keywords.
- KeywordFieldMapper(String, MappedFieldType, MappedFieldType, int, Boolean, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper
- KeywordFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- KeywordFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- KeywordFieldMapper.KeywordFieldType - Class in org.elasticsearch.index.mapper
- KeywordFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- KeywordFieldType() - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- KeywordFieldType(KeywordFieldMapper.KeywordFieldType) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- kilo() - Method in class org.elasticsearch.common.unit.SizeValue
- KILO - org.elasticsearch.common.unit.SizeUnit
- kiloFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- KILOMETERS - org.elasticsearch.common.unit.DistanceUnit
L
- label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Get the description label for this decision.
- label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- lag() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
-
Gets the lag to use when calculating the serial difference.
- lag(int) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
-
Sets the lag to use when calculating the serial difference.
- LANG_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for lang on the inner level. - LANG_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for lang on the inner level. - LANGUID - org.elasticsearch.common.Priority
- Laplace - Class in org.elasticsearch.search.suggest.phrase
-
An additive smoothing model.
- Laplace(double) - Constructor for class org.elasticsearch.search.suggest.phrase.Laplace
-
Creates a Laplace smoothing model.
- Laplace(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.Laplace
-
Read from a stream.
- last() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- lastAccessTime() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
return the last time this RecoveryStatus was used (based on System.nanoTime()
- lastAccessTime() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- lastAccessTime() - Method in class org.elasticsearch.search.internal.SearchContext
- lastChunk() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
-
Returns
true
if this chunk is the last chunk in the stream. - lastEmittedDoc - Variable in class org.elasticsearch.search.internal.ScrollContext
- lastEmittedDoc() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- lastPathElement() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- lastRefreshTimestamp - Variable in class org.elasticsearch.common.util.SingleObjectCache
- lastTaskName() - Method in class org.elasticsearch.common.StopWatch
-
Return the name of the last task.
- lastTaskTime() - Method in class org.elasticsearch.common.StopWatch
-
Return the time taken by the last task.
- lastWriteNanos - Variable in class org.elasticsearch.index.engine.Engine
- lat() - Method in class org.elasticsearch.common.geo.GeoPoint
- LatchedActionListener<T> - Class in org.elasticsearch.action
-
An action listener that allows passing in a
CountDownLatch
that will be counted down after onResponse or onFailure is called - LatchedActionListener(ActionListener<T>, CountDownLatch) - Constructor for class org.elasticsearch.action.LatchedActionListener
- LATEST_CODEC - Static variable in class org.elasticsearch.common.lucene.Lucene
- LATEST_DOC_VALUES_FORMAT - Static variable in class org.elasticsearch.common.lucene.Lucene
- LATEST_POSTINGS_FORMAT - Static variable in class org.elasticsearch.common.lucene.Lucene
- latitude() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- LATITUDE - Static variable in class org.elasticsearch.common.geo.GeoUtils
- LatLonPointDVIndexFieldData(Index, String) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointDVIndexFieldData.LatLonPointDVIndexFieldData
- LazyInitializable<T,E extends java.lang.Exception> - Class in org.elasticsearch.common.util
-
Encapsulates a
CheckedSupplier
which is lazily invoked once on the first call to#getOrCompute()
. - LazyInitializable(CheckedSupplier<T, E>) - Constructor for class org.elasticsearch.common.util.LazyInitializable
-
Creates the simple LazyInitializable instance.
- LazyInitializable(CheckedSupplier<T, E>, Consumer<T>, Consumer<T>) - Constructor for class org.elasticsearch.common.util.LazyInitializable
-
Creates the complete LazyInitializable instance.
- LeaderBulkByScrollTaskState - Class in org.elasticsearch.index.reindex
-
Tracks the state of sliced subtasks and provides unified status information for a sliced BulkByScrollRequest.
- LeaderBulkByScrollTaskState(BulkByScrollTask, int) - Constructor for class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
- LeafBucketCollector - Class in org.elasticsearch.search.aggregations
-
Per-leaf bucket collector.
- LeafBucketCollector() - Constructor for class org.elasticsearch.search.aggregations.LeafBucketCollector
- LeafBucketCollectorBase - Class in org.elasticsearch.search.aggregations
-
A
LeafBucketCollector
that delegates all calls to the sub leaf aggregator and sets the scorer on its source of values if it implementsScorerAware
. - LeafBucketCollectorBase(LeafBucketCollector, Object) - Constructor for class org.elasticsearch.search.aggregations.LeafBucketCollectorBase
- LeafDocLookup - Class in org.elasticsearch.search.lookup
- LeafFieldsLookup - Class in org.elasticsearch.search.lookup
- LeafOnly(String, ValuesSourceType, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
- LeafOnly(String, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder.LeafOnly
- LeafOnly(StreamInput, ValuesSourceType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
-
Read an aggregation from a stream that serializes its targetValueType.
- LeafOnly(StreamInput, ValuesSourceType, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
-
Read an aggregation from a stream that does not serialize its targetValueType.
- LeafOnly(StreamInput, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder.LeafOnly
-
Read from a stream that does not serialize its targetValueType.
- LeafOnly(MultiValuesSourceAggregationBuilder.LeafOnly<VS, AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder.LeafOnly
- LeafOnly(ValuesSourceAggregationBuilder.LeafOnly<VS, AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
- LeafScoreFunction - Class in org.elasticsearch.common.lucene.search.function
-
Per-leaf
ScoreFunction
. - LeafScoreFunction() - Constructor for class org.elasticsearch.common.lucene.search.function.LeafScoreFunction
- LeafSearchLookup - Class in org.elasticsearch.search.lookup
-
Per-segment version of
SearchLookup
. - LeafSearchLookup(LeafReaderContext, LeafDocLookup, SourceLookup, LeafFieldsLookup) - Constructor for class org.elasticsearch.search.lookup.LeafSearchLookup
- leases() - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
The underlying collection of retention leases
- LeaveRequest() - Constructor for class org.elasticsearch.discovery.zen.MembershipAction.LeaveRequest
- LEFT - org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
- LEGACY_QUADTREE - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.PrefixTrees
-
Deprecated.
- legacyBase64UUID() - Static method in class org.elasticsearch.common.UUIDs
-
Legacy implementation of
UUIDs.base64UUID()
, for pre 6.0 indices. - LegacyGeoShapeFieldMapper - Class in org.elasticsearch.index.mapper
-
Deprecated.
- LegacyGeoShapeFieldMapper(String, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Explicit<ShapeBuilder.Orientation>, Explicit<Boolean>, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper
-
Deprecated.
- LegacyGeoShapeFieldMapper.Builder - Class in org.elasticsearch.index.mapper
-
Deprecated.
- LegacyGeoShapeFieldMapper.DeprecatedParameters - Class in org.elasticsearch.index.mapper
-
Deprecated.
- LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults - Class in org.elasticsearch.index.mapper
-
Deprecated.
- LegacyGeoShapeFieldMapper.DeprecatedParameters.Names - Class in org.elasticsearch.index.mapper
-
Deprecated.
- LegacyGeoShapeFieldMapper.DeprecatedParameters.PrefixTrees - Class in org.elasticsearch.index.mapper
-
Deprecated.
- LegacyGeoShapeFieldMapper.GeoShapeFieldType - Class in org.elasticsearch.index.mapper
-
Deprecated.
- length - Variable in class org.elasticsearch.index.translog.TranslogReader
- length - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- length() - Method in interface org.elasticsearch.common.blobstore.BlobMetaData
-
Gets the size of the blob in bytes.
- length() - Method in class org.elasticsearch.common.blobstore.support.PlainBlobMetaData
- length() - Method in class org.elasticsearch.common.bytes.ByteBufferReference
- length() - Method in class org.elasticsearch.common.bytes.BytesArray
- length() - Method in class org.elasticsearch.common.bytes.BytesReference
-
The length.
- length() - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- length() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- length() - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- length() - Method in class org.elasticsearch.common.settings.SecureString
- length() - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
The size of the expected results, including potential null values.
- length() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
File length
- length() - Method in class org.elasticsearch.index.store.StoreFileMetaData
-
the actual file size on "disk", if compressed, the compressed size
- length() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- length() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
-
file length *
- LENGTH_REQUIRED - org.elasticsearch.rest.RestStatus
-
The server refuses to accept the request without a defined Content-Length.
- lenient - Variable in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- lenient - Variable in class org.elasticsearch.index.search.MatchQuery
- lenient() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets leniency setting that controls if format based failures will be ignored.
- lenient() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- lenient() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- lenient() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns whether query parsing should be lenient.
- lenient() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Returns whether to use lenient parsing.
- lenient(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets whether format based failures will be ignored.
- lenient(boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets whether format based failures will be ignored.
- lenient(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specifies whether query parsing should be lenient.
- lenient(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Specifies whether to use lenient parsing, defaults to false.
- lenient(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Sets the query string parser to be lenient when parsing field values, defaults to the index setting and if not set, defaults to false.
- LENIENT_EXPAND_OPEN - Static variable in class org.elasticsearch.action.support.IndicesOptions
- LENIENT_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- lenientExpandOpen() - Static method in class org.elasticsearch.action.support.IndicesOptions
- lessThan(B, B) - Method in class org.elasticsearch.search.aggregations.bucket.terms.BucketPriorityQueue
- lessThan(SignificantTerms.Bucket, SignificantTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.significant.BucketSignificancePriorityQueue
- level() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Get the level of detail for the health information to be returned.
- level(ClusterHealthRequest.Level) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Set the level of detail for the health information to be returned.
- levels() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- LEVENSHTEIN - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
String distance algorithm based on Levenshtein edit distance algorithm.
- libFile() - Method in class org.elasticsearch.env.Environment
- lifecycle - Variable in class org.elasticsearch.common.component.AbstractLifecycleComponent
- Lifecycle - Class in org.elasticsearch.common.component
-
Lifecycle state.
- Lifecycle() - Constructor for class org.elasticsearch.common.component.Lifecycle
- Lifecycle.State - Enum in org.elasticsearch.common.component
- LifecycleComponent - Interface in org.elasticsearch.common.component
- LifecycleListener - Class in org.elasticsearch.common.component
- LifecycleListener() - Constructor for class org.elasticsearch.common.component.LifecycleListener
- lifecycleState() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- lifecycleState() - Method in interface org.elasticsearch.common.component.LifecycleComponent
- lifecycleState() - Method in class org.elasticsearch.repositories.FilterRepository
- like(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a query that will return docs like the passed lucene document ID.
- like(String, Reader...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a query that will return docs like the passed Readers.
- like(Fields...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a query that will return docs like the passed Fields.
- like(Terms...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a query that will return docs like the passed Terms.
- likeItems() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- likeTexts() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- LIMIT - Static variable in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- LIMIT_FOREIGN_PORTS_COUNT - Static variable in class org.elasticsearch.discovery.zen.SettingsBasedHostsProvider
- LIMIT_HEAP_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- LIMIT_LOCAL_PORTS_COUNT - Static variable in class org.elasticsearch.discovery.zen.SettingsBasedHostsProvider
- line(LineStringBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- LINEAR_DECAY_FUNCTION - Static variable in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- linearDecayFunction(String, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- linearDecayFunction(String, Object, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- linearDecayFunction(String, Object, Object, Object, double) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- LinearDecayFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
- LinearDecayFunctionBuilder(String, Object, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- LinearDecayFunctionBuilder(String, Object, Object, Object, double) - Constructor for class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- LinearDecayFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
-
Read from a stream.
- LinearInterpolatingScorer - Class in org.elasticsearch.search.suggest.phrase
- LinearInterpolatingScorer(IndexReader, Terms, String, double, BytesRef, double, double, double) - Constructor for class org.elasticsearch.search.suggest.phrase.LinearInterpolatingScorer
- LinearInterpolation - Class in org.elasticsearch.search.suggest.phrase
-
Linear interpolation smoothing model.
- LinearInterpolation(double, double, double) - Constructor for class org.elasticsearch.search.suggest.phrase.LinearInterpolation
-
Creates a linear interpolation smoothing model.
- LinearInterpolation(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.LinearInterpolation
-
Read from a stream.
- LinearModel - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
-
Calculate a linearly weighted moving average, such that older values are linearly less important.
- LinearModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- LinearModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
-
Read from a stream.
- LinearModel.LinearModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
- LinearModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel.LinearModelBuilder
- linearRing(List<Coordinate>) - Static method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- linearRingS4J(GeometryFactory, List<Coordinate>) - Static method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- linearWeightedAvg(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Calculate a linearly weighted moving average, such that older values are linearly less important.
- linestring(LineStringBuilder) - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- LINESTRING - org.elasticsearch.common.geo.GeoShapeType
- LineStringBuilder - Class in org.elasticsearch.common.geo.builders
- LineStringBuilder(List<Coordinate>) - Constructor for class org.elasticsearch.common.geo.builders.LineStringBuilder
-
Construct a new LineString.
- LineStringBuilder(CoordinatesBuilder) - Constructor for class org.elasticsearch.common.geo.builders.LineStringBuilder
- LineStringBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.LineStringBuilder
-
Read from a stream.
- LinkedBindingBuilder<T> - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - LinkedBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- LinkedBindingImpl(Object, Key<T>, Scoping, Key<? extends T>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- LinkedBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Key<? extends T>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- LinkedKeyBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a linked key.
- LinkedProviderBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- LinkedProviderBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Key<? extends Provider<? extends T>>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- list(String[], TimeValue) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- list(ShardId, DiscoveryNode[], ActionListener<NodesResponse>) - Method in interface org.elasticsearch.gateway.AsyncShardFetch.Lister
- list(ShardId, DiscoveryNode[], ActionListener<TransportNodesListGatewayStartedShards.NodesGatewayStartedShards>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- list(ShardId, DiscoveryNode[], ActionListener<TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData>) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
- listBlobs() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Lists all blobs in the container.
- listBlobs() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- listBlobsByPrefix(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Lists all blobs in the container that match the specified prefix.
- listBlobsByPrefix(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- listedNodes() - Method in class org.elasticsearch.client.transport.TransportClient
-
Returns the listed nodes in the transport client (ones added to it).
- ListenableActionFuture<T> - Interface in org.elasticsearch.action
-
An
ActionFuture
that listeners can be added to. - ListenableFuture<V> - Class in org.elasticsearch.common.util.concurrent
-
A future implementation that allows for the result to be passed to listeners waiting for notification.
- ListenableFuture() - Constructor for class org.elasticsearch.common.util.concurrent.ListenableFuture
- listener - Variable in class org.elasticsearch.action.ActionRunnable
- Listener() - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection.Listener
- LISTENER - org.elasticsearch.action.ThreadingModel
- LISTENER - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- listeners - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- listeners() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Returns a list of listeners
- ListenerTimeouts - Class in org.elasticsearch.action.support
- ListenerTimeouts() - Constructor for class org.elasticsearch.action.support.ListenerTimeouts
- listenForUpdates(ClusterSettings) - Method in class org.elasticsearch.transport.RemoteClusterAware
-
Registers this instance to listen to updates on the cluster settings.
- listenForUpdates(ClusterSettings) - Method in class org.elasticsearch.transport.RemoteClusterService
- ListKey(String) - Constructor for class org.elasticsearch.common.settings.Setting.ListKey
- listOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type modelling a
List
whose elements are of typeelementType
. - listSetting(String, Function<String, T>, Function<Settings, List<String>>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, List<String>, Function<String, T>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, Setting<List<T>>, Function<String, T>, Function<Settings, List<String>>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, Setting<List<T>>, Function<String, T>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listTasks(ListTasksRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
List tasks
- listTasks(ListTasksRequest, ActionListener<ListTasksResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
List active tasks
- ListTasksAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
Action for retrieving a list of currently running tasks
- listTasksRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes tasks request against all the nodes.
- ListTasksRequest - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
A request to get node tasks
- ListTasksRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- ListTasksRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- ListTasksRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
Builder for the request to retrieve the list of tasks running on the specified nodes
- ListTasksRequestBuilder(ElasticsearchClient, ListTasksAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequestBuilder
- ListTasksResponse - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
Returns the list of tasks currently running on the nodes
- ListTasksResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- ListTasksResponse(List<TaskInfo>, List<TaskOperationFailure>, List<? extends ElasticsearchException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- listTasksResponseListener(Supplier<DiscoveryNodes>, String, RestChannel) - Static method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
-
Standard listener for extensions of
ListTasksResponse
that supportsgroup_by=nodes
. - littleQuery() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- littleQuery() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- LivenessRequest - Class in org.elasticsearch.action.admin.cluster.node.liveness
-
Transport level private response for the transport handler registered under "cluster:monitor/nodes/liveness"
- LivenessRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.LivenessRequest
- LivenessResponse - Class in org.elasticsearch.action.admin.cluster.node.liveness
-
Transport level private response for the transport handler registered under "cluster:monitor/nodes/liveness"
- LivenessResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- LivenessResponse(ClusterName, DiscoveryNode) - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- LN - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LN1P - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LN2P - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- load(InputStream) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- load(Object, Version) - Static method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Loads
ContextMappings
from configuration Expected configuration: List of maps representingContextMapping
[{"name": .., "type": .., ..}, {..}] - load(String, Map<String, Object>) - Static method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
-
Loads a
name
dCategoryContextMapping
instance from a map. - load(String, Map<String, Object>) - Static method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- load(Path) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Loads information about the Elasticsearch keystore from the provided config directory.
- load(K) - Method in interface org.elasticsearch.common.cache.CacheLoader
- load(DirectoryReader, IFD) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
- load(DirectoryReader, IFD) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- load(LeafReaderContext) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Loads the atomic field data for the reader, possibly cached.
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointDVIndexFieldData.LatLonPointDVIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.UidIndexFieldData
- load(LeafReaderContext, IFD) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
- load(LeafReaderContext, IFD) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- load(DataInput) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- loadDirect(LeafReaderContext) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Loads directly the atomic field data for the reader, ignoring any caching involved.
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointDVIndexFieldData.LatLonPointDVIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.UidIndexFieldData
- loadDocIdAndSeqNo(IndexReader, Term) - Static method in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver
-
Loads the internal docId and sequence number of the latest copy for a given uid from the provided reader.
- loadDocIdAndVersion(IndexReader, Term, boolean) - Static method in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver
-
Load the internal doc ID and version for the uid from the reader, returning null if the uid wasn't found, a doc ID and a version otherwise
- loadFieldValues(String[], DocIdSetIterator, int) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- loadFieldValues(MappedFieldType, SearchContextHighlight.Field, SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- loadFieldValues(SearchContextHighlight.Field, MappedFieldType, SearchContext, FetchSubPhase.HitContext) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils
-
Load field values for highlighting.
- loadFromPath(Path) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Loads settings from a url that represents them using
Settings.fromXContent(XContentParser)
Note: Loading from a path doesn't allownull
values in the incoming xcontent - loadFromSource(String, XContentType) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Loads settings from the actual string content that represents them using
Settings.fromXContent(XContentParser)
- loadFromStream(String, InputStream, boolean) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Loads settings from a stream that represents them using
Settings.fromXContent(XContentParser)
- loadGlobal(DirectoryReader) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Global
- loadGlobal(DirectoryReader) - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
-
Load a global view of the ordinals for the given
IndexReader
, potentially from a cache. - loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
- loadIndexState(Index) - Method in class org.elasticsearch.gateway.MetaStateService
-
Loads the index state for the provided index name, returning null if doesn't exists.
- loadIntoContext(ShardSearchRequest, SearchContext, QueryPhase) - Method in class org.elasticsearch.indices.IndicesService
-
Loads the cache result, computing it if needed by executing the query phase and otherwise deserializing the cached value into the
context's query result
. - loadLatestState(Logger, NamedXContentRegistry, Path...) - Method in class org.elasticsearch.gateway.MetaDataStateFormat
-
Tries to load the latest state from the given data-locations.
- loadLatestStateWithGeneration(Logger, NamedXContentRegistry, Path...) - Method in class org.elasticsearch.gateway.MetaDataStateFormat
-
Tries to load the latest state from the given data-locations.
- loadLog4jPlugins() - Static method in class org.elasticsearch.common.logging.LogConfigurator
-
Load logging plugins so we can have
node_name
in the pattern. - loadMetaState() - Method in class org.elasticsearch.gateway.GatewayMetaState
- loadRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Loads the latest retention leases from their dedicated state file.
- loadRetentionLeases(Path) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Loads the latest retention leases from their dedicated state file.
- loadSeqNoInfo(IndexCommit) - Static method in class org.elasticsearch.index.store.Store
-
Loads the maximum sequence number and local checkpoint from the given Lucene commit point or the latest if not provided.
- loadSeqNoInfoFromLuceneCommit(Iterable<Map.Entry<String, String>>) - Static method in class org.elasticsearch.index.seqno.SequenceNumbers
-
Reads the sequence number stats from the commit data (maximum sequence number and local checkpoint).
- loadShardPath(Logger, NodeEnvironment, ShardId, IndexSettings) - Static method in class org.elasticsearch.index.shard.ShardPath
-
This method walks through the nodes shard paths to find the data and state path for the given shard.
- loadShardPath(Logger, ShardId, IndexSettings, Path[], int, Path) - Static method in class org.elasticsearch.index.shard.ShardPath
-
This method walks through the nodes shard paths to find the data and state path for the given shard.
- loadWordList(Reader, String) - Static method in class org.elasticsearch.index.analysis.Analysis
- local - Variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- local - Variable in class org.elasticsearch.action.support.master.MasterNodeReadRequest
- local() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- local() - Method in class org.elasticsearch.action.support.master.MasterNodeReadRequest
-
Return local information, do not retrieve the state from master node (default: false).
- local(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
Indicate whether the receiving node should operate based on local index information or forward requests, where needed, to other nodes.
- local(boolean) - Method in class org.elasticsearch.action.support.master.MasterNodeReadRequest
- LOCAL - org.elasticsearch.cluster.routing.Preference
-
Route to local node, if possible
- LOCAL_CHECKPOINT_KEY - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
- LOCAL_CLUSTER_GROUP_KEY - Static variable in class org.elasticsearch.transport.RemoteClusterAware
- LOCAL_RESET - org.elasticsearch.index.engine.Engine.Operation.Origin
- LOCAL_SHARDS - org.elasticsearch.cluster.routing.RecoverySource.Type
- LOCAL_TIME_FORMATTER - Static variable in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- LOCAL_TRANSLOG_RECOVERY - org.elasticsearch.index.engine.Engine.Operation.Origin
- LocalAllocateDangledIndices - Class in org.elasticsearch.gateway
- LocalAllocateDangledIndices(TransportService, ClusterService, AllocationService, MetaDataIndexUpgradeService) - Constructor for class org.elasticsearch.gateway.LocalAllocateDangledIndices
- LocalAllocateDangledIndices.AllocateDangledRequest - Class in org.elasticsearch.gateway
- LocalAllocateDangledIndices.AllocateDangledResponse - Class in org.elasticsearch.gateway
- LocalAllocateDangledIndices.Listener - Interface in org.elasticsearch.gateway
- localCheckpoint - Variable in class org.elasticsearch.index.seqno.SequenceNumbers.CommitInfo
- localCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the local checkpoint on the primary shard.
- localCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.ReplicaResponse
-
The local checkpoint for the shard.
- localCheckpoint() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- LocalCheckpointTracker - Class in org.elasticsearch.index.seqno
-
This class generates sequences numbers and keeps track of the so-called "local checkpoint" which is the highest number for which all previous sequence numbers have been processed (inclusive).
- LocalCheckpointTracker(long, long) - Constructor for class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Initialize the local checkpoint service.
- LocalClusterUpdateTask - Class in org.elasticsearch.cluster
-
Used to apply state updates on nodes that are not necessarily master
- LocalClusterUpdateTask() - Constructor for class org.elasticsearch.cluster.LocalClusterUpdateTask
- LocalClusterUpdateTask(Priority) - Constructor for class org.elasticsearch.cluster.LocalClusterUpdateTask
- localDateOptionalTimeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO datetime parser where the date is mandatory and the time is optional.
- localDateParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO date parser for parsing local dates.
- locale() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- locale() - Method in interface org.elasticsearch.common.time.DateFormatter
-
Returns the configured locale of the date formatter
- locale(Locale) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- locale(Locale) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- LocaleUtils - Class in org.elasticsearch.common.util
-
Utilities for for dealing with
Locale
objects - LocaleUtils() - Constructor for class org.elasticsearch.common.util.LocaleUtils
- localExecute(Request) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- localExecute(Request) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- localGlobalDirect(DirectoryReader) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Global
- localGlobalDirect(DirectoryReader) - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
-
Load a global view of the ordinals for the given
IndexReader
. - localGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- localGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- localGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- localGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
- localNode() - Method in class org.elasticsearch.cluster.service.ClusterService
-
The local node.
- localNodeId(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- localNodeMaster() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the local node is the mater node of the cluster. - LocalNodeMasterListener - Interface in org.elasticsearch.cluster
-
Enables listening to master changes events of the local node (when the local node becomes the master, and when the local node cease being a master).
- localShardFailed(ShardRouting, String, Exception, ActionListener<Void>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
Send a shard failed request to the master node to update the cluster state when a shard on the local node failed.
- localShardFailed(ShardRouting, String, Exception, ActionListener<Void>, ClusterState) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
Send a shard failed request to the master node to update the cluster state when a shard on the local node failed.
- localTimeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO time parser for parsing local times.
- location - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- location - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
- location() - Method in class org.elasticsearch.index.translog.Translog
-
Returns all translog locations as absolute paths.
- Location(long, long, int) - Constructor for class org.elasticsearch.index.translog.Translog.Location
- LOCATION_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- locationToSync(Translog.Location, Translog.Location) - Static method in class org.elasticsearch.action.support.replication.TransportWriteAction
- lock() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- lock(ShardId, long) - Method in interface org.elasticsearch.env.NodeEnvironment.ShardLocker
- lockAllForIndex(Index, IndexSettings, long) - Method in class org.elasticsearch.env.NodeEnvironment
-
Tries to lock all local shards for the given index.
- locked(Recycler<T>) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Wrap the provided recycler so that calls to
Recycler.obtain()
andReleasable.close()
are protected by a lock. - LOCKED - org.elasticsearch.rest.RestStatus
-
The 423 (Locked) status code means the source or destination resource of a method is locked.
- lockedShards() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all currently lock shards.
- lockInterruptibly() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- LOG - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LOG_DEFAULT_LEVEL_SETTING - Static variable in class org.elasticsearch.common.logging.Loggers
- LOG_LEVEL_SETTING - Static variable in class org.elasticsearch.common.logging.Loggers
- LOG1P - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LOG2P - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LogConfigurator - Class in org.elasticsearch.common.logging
- LogConfigurator() - Constructor for class org.elasticsearch.common.logging.LogConfigurator
- logger - Variable in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- logger - Variable in class org.elasticsearch.client.support.AbstractClient
- logger - Variable in class org.elasticsearch.cluster.ClusterStateObserver
- logger - Variable in class org.elasticsearch.common.component.AbstractComponent
-
Deprecated.
- logger - Variable in class org.elasticsearch.common.settings.AbstractScopedSettings
- logger - Variable in class org.elasticsearch.gateway.AsyncShardFetch
- logger - Variable in class org.elasticsearch.gateway.BaseGatewayShardAllocator
- logger - Variable in class org.elasticsearch.index.AbstractIndexComponent
- logger - Variable in class org.elasticsearch.index.engine.Engine
- logger - Variable in class org.elasticsearch.index.reindex.ScrollableHitSource
- logger - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- logger - Static variable in class org.elasticsearch.index.translog.TruncateTranslogAction
- logger - Variable in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- logger - Static variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- logger() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
- LOGGER - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- LoggerInfoStream - Class in org.elasticsearch.common.lucene
-
An InfoStream (for Lucene's IndexWriter) that redirects messages to "lucene.iw.ifd" and "lucene.iw" Logger.trace.
- LoggerInfoStream(Logger) - Constructor for class org.elasticsearch.common.lucene.LoggerInfoStream
- LoggerMessageFormat - Class in org.elasticsearch.common.logging
-
Format string for Elasticsearch log messages.
- LoggerMessageFormat() - Constructor for class org.elasticsearch.common.logging.LoggerMessageFormat
- Loggers - Class in org.elasticsearch.common.logging
-
A set of utilities around Logging.
- Loggers() - Constructor for class org.elasticsearch.common.logging.Loggers
- LoggingAwareCommand - Class in org.elasticsearch.cli
-
A command that is aware of logging.
- LoggingAwareCommand(String) - Constructor for class org.elasticsearch.cli.LoggingAwareCommand
-
Construct the command with the specified command description.
- LoggingAwareMultiCommand - Class in org.elasticsearch.cli
-
A multi-command that is aware of logging.
- LoggingAwareMultiCommand(String) - Constructor for class org.elasticsearch.cli.LoggingAwareMultiCommand
-
Construct the command with the specified command description.
- LoggingDeprecationHandler - Class in org.elasticsearch.common.xcontent
-
Logs deprecations to the
DeprecationLogger
. - LoggingTaskListener<Response> - Class in org.elasticsearch.tasks
-
A TaskListener that just logs the response at the info level.
- logIfNecessary() - Static method in class org.elasticsearch.common.network.IfConfig
-
log interface configuration at debug level, if its enabled
- logMinimumMasterNodesWarningIfNecessary(ClusterState, ClusterState) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- logsFile() - Method in class org.elasticsearch.env.Environment
- lon() - Method in class org.elasticsearch.common.geo.GeoPoint
- LONG - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- LONG - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- LONG - org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- LONG - org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- LONG - org.elasticsearch.search.aggregations.support.ValueType
- LONG_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- LongAccessor() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
- LongArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of long values.
- longEncode(double, double, int) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode lon/lat to the geohash based long format (lon/lat interleaved, 4 least significant bits = level)
- longEncode(long, int) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode an existing geohash long to the provided precision
- longestOnly() - Method in class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
- longField(FieldInfo, long) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- LongFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.LongFilter
- LongHash - Class in org.elasticsearch.common.util
-
Specialized hash table implementation similar to BytesRefHash that maps long values to ids.
- LongHash(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.LongHash
- LongHash(long, BigArrays) - Constructor for class org.elasticsearch.common.util.LongHash
- longitude() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- LONGITUDE - Static variable in class org.elasticsearch.common.geo.GeoUtils
- LongObjectPagedHashMap<T> - Class in org.elasticsearch.common.util
-
A hash table from native longs to objects.
- LongObjectPagedHashMap(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap
- LongObjectPagedHashMap(long, BigArrays) - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap
- LongObjectPagedHashMap(BigArrays) - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap
- LongObjectPagedHashMap.Cursor<T> - Class in org.elasticsearch.common.util
- longPage(boolean) - Method in class org.elasticsearch.common.util.PageCacheRecycler
- Longs(SortedNumericDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
-
Standard constructor.
- longSetting(String, long, long, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- LongTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the
TermsAggregator
when the field is some kind of whole number like a integer, long, or a date. - LongTerms(String, BucketOrder, int, long, List<PipelineAggregator>, Map<String, Object>, DocValueFormat, int, boolean, long, List<LongTerms.Bucket>, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- LongTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
-
Read from a stream.
- LongTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- LongTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
- LongTermsAggregator(String, AggregatorFactories, ValuesSource.Numeric, DocValueFormat, BucketOrder, TermsAggregator.BucketCountThresholds, SearchContext, Aggregator, Aggregator.SubAggCollectionMode, boolean, IncludeExclude.LongFilter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- longToBytes(long) - Static method in class org.elasticsearch.common.Numbers
-
Converts a long to a byte array.
- longValue() - Method in class org.elasticsearch.script.ScoreAccessor
- longValue() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
-
Get the current
SortedNumericDocValues
. - longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- LongValuesComparatorSource - Class in org.elasticsearch.index.fielddata.fieldcomparator
-
Comparator source for long values.
- LongValuesComparatorSource(IndexNumericFieldData, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- lookup() - Method in class org.elasticsearch.index.query.QueryShardContext
- lookup() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- lookup() - Method in class org.elasticsearch.search.internal.SearchContext
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- lookup(String, XContentLocation, DeprecationHandler) - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Lookup a value from the registry by name while checking that the name matches the ParseField.
- lookupGlobalOrd - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- lookupOrd(long) - Method in interface org.elasticsearch.index.fielddata.ordinals.Ordinals.ValuesHolder
- lookupReturningNullIfNotFound(String, DeprecationHandler) - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Lookup a value from the registry by name while checking that the name matches the ParseField.
- LOW - org.elasticsearch.common.Priority
- LOW - org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Defaults to 60 seconds
- LOW_LEVEL_CANCELLATION_SETTING - Static variable in class org.elasticsearch.search.SearchService
-
Enables low-level, frequent search cancellation checks.
- LOWER - org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats.Bounds
- lowFreqMinimumShouldMatch() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- lowFreqMinimumShouldMatch(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Sets the minimum number of low frequent query terms that need to match in order to produce a hit.
- lowFreqOperator() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- lowFreqOperator(Operator) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Sets the operator to use for terms with a low document frequency (less than
CommonTermsQueryBuilder.cutoffFrequency(float)
. - lowLevelCancellation() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- lowLevelCancellation() - Method in class org.elasticsearch.search.internal.SearchContext
-
Indicates if the current index should perform frequent low level search cancellation check.
- LPAREN - Static variable in class org.elasticsearch.common.geo.parsers.GeoWKTParser
- lt(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- LT_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- lte(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- LTE_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- Lucene - Class in org.elasticsearch.common.lucene
- LUCENE - org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
- LUCENE_DEFAULT_CODEC - Static variable in class org.elasticsearch.index.codec.CodecService
-
the raw unfiltered lucene default.
- luceneVersion - Variable in class org.elasticsearch.Version
- luceneVersion(String, boolean, BiFunction<Reader, Version, Reader>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Create a pre-configured token filter that may vary based on the Lucene version.
- luceneVersion(String, boolean, BiFunction<TokenStream, Version, TokenStream>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Create a pre-configured token filter that may vary based on the Lucene version.
- luceneVersion(String, Function<Version, Tokenizer>, Function<Version, TokenFilterFactory>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
-
Create a pre-configured tokenizer that may vary based on the Lucene version.
M
- MacAddressProvider - Class in org.elasticsearch.common
- MacAddressProvider() - Constructor for class org.elasticsearch.common.MacAddressProvider
- main(String[]) - Static method in class org.elasticsearch.common.settings.KeyStoreCli
- main(String[]) - Static method in class org.elasticsearch.index.shard.ShardToolCli
- main(String[]) - Static method in class org.elasticsearch.index.translog.TranslogToolCli
-
Deprecated.
- main(String[]) - Static method in class org.elasticsearch.Version
- MainAction - Class in org.elasticsearch.action.main
- MainAction() - Constructor for class org.elasticsearch.action.main.MainAction
- MainRequest - Class in org.elasticsearch.action.main
- MainRequest() - Constructor for class org.elasticsearch.action.main.MainRequest
- MainRequestBuilder - Class in org.elasticsearch.action.main
- MainRequestBuilder(ElasticsearchClient, MainAction) - Constructor for class org.elasticsearch.action.main.MainRequestBuilder
- MainResponse - Class in org.elasticsearch.action.main
- MainResponse(String, Version, ClusterName, String, Build, boolean) - Constructor for class org.elasticsearch.action.main.MainResponse
- major - Variable in class org.elasticsearch.Version
- majorDeviceNumber - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
- makeAllocationDecision(ShardRouting, RoutingAllocation, Logger) - Method in class org.elasticsearch.gateway.BaseGatewayShardAllocator
-
Make a decision on the allocation of an unassigned shard.
- makeAllocationDecision(ShardRouting, RoutingAllocation, Logger) - Method in class org.elasticsearch.gateway.PrimaryShardAllocator
- makeAllocationDecision(ShardRouting, RoutingAllocation, Logger) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
- makeFragment(StringBuilder, int[], Field[], FieldFragList.WeightedFragInfo, String[], String[], Encoder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SimpleFragmentsBuilder
- makeFragment(StringBuilder, int[], Field[], FieldFragList.WeightedFragInfo, String[], String[], Encoder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SourceScoreOrderFragmentsBuilder
- makeKeySafe(TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns an equivalent type that's safe for use in a key.
- makeWrapper(ResponseCollectorService) - Static method in class org.elasticsearch.action.search.SearchExecutionStatsCollector
- MANAGEMENT - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- MANDATORY_SETTING - Static variable in class org.elasticsearch.plugins.PluginsService
- MANUAL_ALLOCATION - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Forced manually to allocate
- map() - Method in class org.elasticsearch.common.collect.MapBuilder
- MAP - org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- MAP - org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory.ExecutionMode
- MAP - org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
- MapBinder<K,V> - Class in org.elasticsearch.common.inject.multibindings
-
An API to bind multiple map entries separately, only to later inject them as a complete map.
- MapBinder.RealMapBinder<K,V> - Class in org.elasticsearch.common.inject.multibindings
-
The actual mapbinder plays several roles:
- MapBinder.RealMapBinder.MapBinderProviderWithDependencies<K,V> - Class in org.elasticsearch.common.inject.multibindings
- MapBuilder<K,V> - Class in org.elasticsearch.common.collect
- MapBuilder() - Constructor for class org.elasticsearch.common.collect.MapBuilder
- MapBuilder(Map<K, V>) - Constructor for class org.elasticsearch.common.collect.MapBuilder
- MapDiff(DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.MapDiff
- MapDiff(DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>, List<K>, Map<K, Diff<T>>, Map<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.MapDiff
- MapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.MapDiff
- mapOf(Type, Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type modelling a
Map
whose keys are of typekeyType
and whose values are of typevalueType
. - MappedFieldType - Class in org.elasticsearch.index.mapper
-
This defines the core properties and functions to operate on a field.
- MappedFieldType() - Constructor for class org.elasticsearch.index.mapper.MappedFieldType
- MappedFieldType(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.MappedFieldType
- MappedFieldType.Relation - Enum in org.elasticsearch.index.mapper
-
An enum used to describe the relation between the range of terms in a shard when compared with a query range
- Mapper - Class in org.elasticsearch.index.mapper
- Mapper(String) - Constructor for class org.elasticsearch.index.mapper.Mapper
- Mapper.Builder<T extends Mapper.Builder,Y extends Mapper> - Class in org.elasticsearch.index.mapper
- Mapper.BuilderContext - Class in org.elasticsearch.index.mapper
- Mapper.TypeParser - Interface in org.elasticsearch.index.mapper
- Mapper.TypeParser.ParserContext - Class in org.elasticsearch.index.mapper
- MapperException - Exception in org.elasticsearch.index.mapper
- MapperException(String) - Constructor for exception org.elasticsearch.index.mapper.MapperException
- MapperException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.MapperException
- MapperException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.mapper.MapperException
- MapperException(StreamInput) - Constructor for exception org.elasticsearch.index.mapper.MapperException
- MapperParsingException - Exception in org.elasticsearch.index.mapper
- MapperParsingException(String) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
- MapperParsingException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
- MapperParsingException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
- MapperParsingException(StreamInput) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
- MapperPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to add custom mappers - MapperRegistry - Class in org.elasticsearch.indices.mapper
-
A registry for all field mappers.
- MapperRegistry(Map<String, Mapper.TypeParser>, Map<String, MetadataFieldMapper.TypeParser>, Function<String, Predicate<String>>) - Constructor for class org.elasticsearch.indices.mapper.MapperRegistry
- mappers() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- mappersBuilders - Variable in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- mapperService() - Method in class org.elasticsearch.index.IndexService
- mapperService() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- mapperService() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- mapperService() - Method in class org.elasticsearch.index.mapper.ParseContext
- mapperService() - Method in class org.elasticsearch.index.shard.IndexShard
- mapperService() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- mapperService() - Method in class org.elasticsearch.search.internal.SearchContext
- mapperService() - Method in class org.elasticsearch.search.lookup.DocLookup
- mapperService() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- MapperService - Class in org.elasticsearch.index.mapper
- MapperService(IndexSettings, IndexAnalyzers, NamedXContentRegistry, SimilarityService, MapperRegistry, Supplier<QueryShardContext>) - Constructor for class org.elasticsearch.index.mapper.MapperService
- MapperService.MergeReason - Enum in org.elasticsearch.index.mapper
-
The reason why a mapping is being merged.
- mapping() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- mapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- mapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- mapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- mapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- mapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- mapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- mapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, Map) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds mapping that will be added when the index gets created.
- Mapping - Class in org.elasticsearch.index.mapper
-
Wrapper around everything that defines a mapping, without references to utility classes like MapperService, ...
- Mapping(Version, RootObjectMapper, MetadataFieldMapper[], Map<String, Object>) - Constructor for class org.elasticsearch.index.mapper.Mapping
- MAPPING_RECOVERY - org.elasticsearch.index.mapper.MapperService.MergeReason
-
Recovery of an existing mapping, for instance because of a restart, if a shard was moved to a different node or for administrative purposes.
- MAPPING_UPDATE - org.elasticsearch.index.mapper.MapperService.MergeReason
-
Create or update a mapping.
- MAPPING_UPDATE_REQUIRED - org.elasticsearch.index.engine.Engine.Result.Type
- mappingForName(String, String) - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- MappingMetaData - Class in org.elasticsearch.cluster.metadata
-
Mapping configuration for a type.
- MappingMetaData(String, Map<String, Object>) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
- MappingMetaData(CompressedXContent) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
- MappingMetaData(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
- MappingMetaData(DocumentMapper) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
- MappingMetaData.Routing - Class in org.elasticsearch.cluster.metadata
- mappingOrDefault(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Sometimes, the default mapping exists and an actual mapping is not created yet (introduced), in this case, we want to return the default mapping in case it has some default mapping definitions.
- MappingRequestValidator - Interface in org.elasticsearch.action.admin.indices.mapping.put
-
A validator that validates a
PutMappingRequest
before executing it. - mappingRequestValidators() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Returns a collection of validators that are used by
TransportPutMappingAction.RequestValidators
to validate aPutMappingRequest
before the executing it. - mappings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- mappings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- mappings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- mappings() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
-
returns the retrieved field mapping.
- mappings() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- mappings() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- mappings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- mappings(Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- mappings(Map<String, String>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- MAPPINGS - org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- MAPPINGS - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- mappingSource() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- mappingType(String) - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- mappingUpdate(Mapper) - Method in class org.elasticsearch.index.mapper.Mapping
-
Generate a mapping update for the given root object mapper.
- mappingUpdate(Mapper) - Method in class org.elasticsearch.index.mapper.ObjectMapper
-
Build a mapping update with the provided sub mapping update.
- mappingUpdate(Mapper) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- MappingUpdatedAction - Class in org.elasticsearch.cluster.action.index
-
Called by shards in the cluster when their mapping was dynamically updated and it needs to be updated in the cluster state meta data (and broadcast to all members).
- MappingUpdatedAction(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction
- MappingUpdatePerformer - Interface in org.elasticsearch.action.bulk
- mappingVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- mappingVersion(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- mapScript() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Get the
map
script. - mapScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Set the
map
script. - MapScript(Map<String, Object>, Object, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- mark(int) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- mark(int) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- mark(int) - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- mark(int) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- markAllocationIdAsInSync(String, long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Marks the shard with the provided allocation ID as in-sync with the primary shard.
- markAllocationIdAsInSync(String, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Marks the shard with the provided allocation ID as in-sync with the primary shard.
- markAsCommitted(String, PendingClusterStatesQueue.StateProcessedListener) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
Mark a previously added cluster state as committed.
- markAsCompleted() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- markAsDone() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
mark the current recovery as done
- markAsFailed(Exception) - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- markAsFailed(ClusterState, Exception) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
mark that the processing of the given state has failed.
- markAsProcessed(ClusterState) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
indicates that a cluster state was successfully processed.
- markAsRecovering(String, RecoveryState) - Method in class org.elasticsearch.index.shard.IndexShard
-
Marks the shard as recovering based on a recovery state, fails with exception is recovering is not allowed to be set.
- markAsRequired() - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- markAsStale() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
-
Whether or not to mark the shard as stale (eg.
- markAsSystemContext() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Marks this thread context as an internal system context.
- MARKER_BYTES_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- markIndicesReadOnly(Set<String>) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdMonitor
- markRecoveryAsDone(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
mark the recovery with the given id as done (if found)
- markSeqNoAsCompleted(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Marks the processing of the provided sequence number as completed as updates the checkpoint if possible.
- markSeqNoAsNoop(long, String) - Method in class org.elasticsearch.index.shard.IndexShard
- markSeqNoAsSeen(long) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Marks the given seq_no as seen and advances the max_seq_no of this engine to at least that value.
- markShardCopyAsStaleIfNeeded(ShardId, String, ActionListener<Void>) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Replicas
-
Marks shard copy as stale if needed, removing its allocation id from the set of in-sync allocation ids.
- markShardCopyAsStaleIfNeeded(ShardId, String, ActionListener<Void>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicasProxy
- markStoreCorrupted(IOException) - Method in class org.elasticsearch.index.store.Store
-
Marks this store as corrupted.
- markSupported() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- markSupported() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- markSupported() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- markSupported() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- master() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
the current master of the node
- MASTER - org.elasticsearch.cluster.node.DiscoveryNode.Role
- MASTER_ELECTION_IGNORE_NON_MASTER_PINGS_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- MASTER_ELECTION_WAIT_FOR_JOINS_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- MASTER_NODE - org.elasticsearch.cluster.ClusterState.Metric
- MASTER_PING_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.MasterFaultDetection
- MASTER_UPDATE_THREAD_NAME - Static variable in class org.elasticsearch.cluster.service.MasterService
- MasterCandidate(DiscoveryNode, long) - Constructor for class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- MasterFaultDetection - Class in org.elasticsearch.discovery.zen
-
A fault detection that pings the master periodically to see if its alive.
- MasterFaultDetection(Settings, ThreadPool, TransportService, Supplier<ClusterState>, MasterService, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.MasterFaultDetection
- MasterFaultDetection.Listener - Interface in org.elasticsearch.discovery.zen
- MasterFaultDetection.MasterPingRequest - Class in org.elasticsearch.discovery.zen
- masterNode() - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- masterNode() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- masterNodeChanged() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- MasterNodeChangePredicate - Class in org.elasticsearch.cluster
- masterNodeId(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- MasterNodeOperationRequestBuilder<Request extends MasterNodeRequest<Request>,Response extends ActionResponse,RequestBuilder extends MasterNodeOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.master
-
Base request builder for master node operations
- MasterNodeOperationRequestBuilder(ElasticsearchClient, Action<Request, Response, RequestBuilder>, Request) - Constructor for class org.elasticsearch.action.support.master.MasterNodeOperationRequestBuilder
- MasterNodeReadOperationRequestBuilder<Request extends MasterNodeReadRequest<Request>,Response extends ActionResponse,RequestBuilder extends MasterNodeReadOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.master
-
Base request builder for master node read operations that can be executed on the local node as well
- MasterNodeReadOperationRequestBuilder(ElasticsearchClient, Action<Request, Response, RequestBuilder>, Request) - Constructor for class org.elasticsearch.action.support.master.MasterNodeReadOperationRequestBuilder
- MasterNodeReadRequest<Request extends MasterNodeReadRequest<Request>> - Class in org.elasticsearch.action.support.master
-
Base request for master based read operations that allows to read the cluster state from the local node if needed
- MasterNodeReadRequest() - Constructor for class org.elasticsearch.action.support.master.MasterNodeReadRequest
- MasterNodeReadRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.MasterNodeReadRequest
- MasterNodeRequest<Request extends MasterNodeRequest<Request>> - Class in org.elasticsearch.action.support.master
-
A based request for master based operation.
- MasterNodeRequest() - Constructor for class org.elasticsearch.action.support.master.MasterNodeRequest
- MasterNodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.MasterNodeRequest
- masterNodeTimeout - Variable in class org.elasticsearch.action.support.master.MasterNodeRequest
- masterNodeTimeout() - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
- masterNodeTimeout() - Method in interface org.elasticsearch.cluster.ack.AckedRequest
-
Returns the timeout for the request to be completed on the master node
- masterNodeTimeout() - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Returns the maximum time interval to wait for the request to be completed on the master node
- masterNodeTimeout(String) - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
-
A timeout value in case the master has not been discovered yet or disconnected.
- masterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
-
A timeout value in case the master has not been discovered yet or disconnected.
- masterNodeTimeout(TimeValue) - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Sets the master node timeout
- MasterNotDiscoveredException - Exception in org.elasticsearch.discovery
- MasterNotDiscoveredException() - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
- MasterNotDiscoveredException(String) - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
- MasterNotDiscoveredException(Throwable) - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
- MasterNotDiscoveredException(StreamInput) - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
- masterOperation(ClusterAllocationExplainRequest, ClusterState, ActionListener<ClusterAllocationExplainResponse>) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- masterOperation(ClusterHealthRequest, ClusterState, ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- masterOperation(DeleteRepositoryRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
- masterOperation(GetRepositoriesRequest, ClusterState, ActionListener<GetRepositoriesResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- masterOperation(PutRepositoryRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
- masterOperation(VerifyRepositoryRequest, ClusterState, ActionListener<VerifyRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
- masterOperation(ClusterRerouteRequest, ClusterState, ActionListener<ClusterRerouteResponse>) - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
- masterOperation(ClusterUpdateSettingsRequest, ClusterState, ActionListener<ClusterUpdateSettingsResponse>) - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
- masterOperation(ClusterSearchShardsRequest, ClusterState, ActionListener<ClusterSearchShardsResponse>) - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- masterOperation(CreateSnapshotRequest, ClusterState, ActionListener<CreateSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
- masterOperation(DeleteSnapshotRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
- masterOperation(GetSnapshotsRequest, ClusterState, ActionListener<GetSnapshotsResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- masterOperation(RestoreSnapshotRequest, ClusterState, ActionListener<RestoreSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
- masterOperation(SnapshotsStatusRequest, ClusterState, ActionListener<SnapshotsStatusResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
- masterOperation(ClusterStateRequest, ClusterState, ActionListener<ClusterStateResponse>) - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- masterOperation(DeleteStoredScriptRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportDeleteStoredScriptAction
- masterOperation(GetStoredScriptRequest, ClusterState, ActionListener<GetStoredScriptResponse>) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetStoredScriptAction
- masterOperation(PutStoredScriptRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportPutStoredScriptAction
- masterOperation(PendingClusterTasksRequest, ClusterState, ActionListener<PendingClusterTasksResponse>) - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
- masterOperation(GetAliasesRequest, ClusterState, ActionListener<AliasesExistResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
- masterOperation(GetAliasesRequest, ClusterState, ActionListener<GetAliasesResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
- masterOperation(IndicesAliasesRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
- masterOperation(CloseIndexRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- masterOperation(CreateIndexRequest, ClusterState, ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
- masterOperation(DeleteIndexRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- masterOperation(IndicesExistsRequest, ClusterState, ActionListener<IndicesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
- masterOperation(TypesExistsRequest, ClusterState, ActionListener<TypesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
- masterOperation(PutMappingRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
- masterOperation(OpenIndexRequest, ClusterState, ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- masterOperation(RolloverRequest, ClusterState, ActionListener<RolloverResponse>) - Method in class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- masterOperation(GetSettingsRequest, ClusterState, ActionListener<GetSettingsResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
- masterOperation(UpdateSettingsRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
- masterOperation(IndicesShardStoresRequest, ClusterState, ActionListener<IndicesShardStoresResponse>) - Method in class org.elasticsearch.action.admin.indices.shards.TransportIndicesShardStoresAction
- masterOperation(ResizeRequest, ClusterState, ActionListener<ResizeResponse>) - Method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- masterOperation(DeleteIndexTemplateRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- masterOperation(GetIndexTemplatesRequest, ClusterState, ActionListener<GetIndexTemplatesResponse>) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- masterOperation(PutIndexTemplateRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
- masterOperation(UpgradeSettingsRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeSettingsAction
- masterOperation(DeletePipelineRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.ingest.DeletePipelineTransportAction
- masterOperation(GetPipelineRequest, ClusterState, ActionListener<GetPipelineResponse>) - Method in class org.elasticsearch.action.ingest.GetPipelineTransportAction
- masterOperation(PutPipelineRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.ingest.PutPipelineTransportAction
- masterOperation(CompletionPersistentTaskAction.Request, ClusterState, ActionListener<PersistentTaskResponse>) - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.TransportAction
- masterOperation(RemovePersistentTaskAction.Request, ClusterState, ActionListener<PersistentTaskResponse>) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.TransportAction
- masterOperation(StartPersistentTaskAction.Request, ClusterState, ActionListener<PersistentTaskResponse>) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.TransportAction
- masterOperation(UpdatePersistentTaskStatusAction.Request, ClusterState, ActionListener<PersistentTaskResponse>) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.TransportAction
- masterOperation(Task, ClusterHealthRequest, ClusterState, ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- masterOperation(Task, CloseIndexRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- masterOperation(Task, Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
-
Override this operation if access to the task parameter is needed
- masterOperation(Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
- masterOperation(Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- MasterPingRequest() - Constructor for class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingRequest
- MasterService - Class in org.elasticsearch.cluster.service
- MasterService(String, Settings, ThreadPool) - Constructor for class org.elasticsearch.cluster.service.MasterService
- MasterService.TaskInputs - Class in org.elasticsearch.cluster.service
-
Represents a set of tasks to be processed together with their executor
- masterTimeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- masterTimeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveRequest
- match(int) - Method in class org.apache.lucene.search.XFilteredDocIdSetIterator
-
Validation method to determine whether a docid should be in the result set.
- match(String) - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- match(String) - Method in class org.elasticsearch.common.settings.Setting.GroupKey
- match(String) - Method in interface org.elasticsearch.common.settings.Setting.Key
- match(String) - Method in class org.elasticsearch.common.settings.Setting.ListKey
- match(String) - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
iff the given key matches the settings key or if this setting is a group setting if the given key is part of the settings group. - match(String) - Method in class org.elasticsearch.common.settings.Setting.SimpleKey
- match(String) - Method in enum org.elasticsearch.index.IndexModule.Type
-
Returns true iff this settings matches the type.
- match(String, String, DynamicTemplate.XContentFieldType) - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- match(URI) - Method in class org.elasticsearch.common.util.URIPattern
-
Returns true if the given uri matches the pattern
- match(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
- match(URIPattern[], URI) - Static method in class org.elasticsearch.common.util.URIPattern
- match(Task) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- match(Task) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- MATCH - org.elasticsearch.search.profile.query.QueryTimingType
- MATCH_ANY - Static variable in class org.elasticsearch.common.lucene.uid.Versions
-
used to indicate the write operation should succeed regardless of current version
- MATCH_DELETED - Static variable in class org.elasticsearch.common.lucene.uid.Versions
-
used to indicate that the write operation should be executed if the document is currently deleted i.e., not found in the index and/or found as deleted (with version) in the version map
- matchAllQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that matches on all documents.
- MatchAllQueryBuilder - Class in org.elasticsearch.index.query
-
A query that matches on all documents.
- MatchAllQueryBuilder() - Constructor for class org.elasticsearch.index.query.MatchAllQueryBuilder
- MatchAllQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchAllQueryBuilder
-
Read from a stream.
- matched - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Result
- MATCHED_FIELDS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- matchedFields() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- matchedFields(String...) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
-
Set the matched fields to highlight against this field data.
- matchedQueries(String[]) - Method in class org.elasticsearch.search.SearchHit
- MatchedQueriesFetchSubPhase - Class in org.elasticsearch.search.fetch.subphase
- MatchedQueriesFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.MatchedQueriesFetchSubPhase
- Matcher<T> - Interface in org.elasticsearch.common.inject.matcher
-
Returns
true
orfalse
for a given input. - MatcherAndConverter - Class in org.elasticsearch.common.inject.internal
- MatcherAndConverter(Matcher<? super TypeLiteral<?>>, TypeConverter, Object) - Constructor for class org.elasticsearch.common.inject.internal.MatcherAndConverter
- Matchers - Class in org.elasticsearch.common.inject.matcher
-
Matcher implementations.
- matches(String) - Method in enum org.elasticsearch.common.time.FormatNames
- matches(String, String) - Method in enum org.elasticsearch.index.mapper.DynamicTemplate.MatchType
-
Whether
value
matchesregex
. - matches(T) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
-
Returns
true
if this matchest
,false
otherwise. - matchesIndex(String, String, ClusterState) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Returns
true
iff the given expression resolves to the given index name otherwisefalse
- MatchNoneQueryBuilder - Class in org.elasticsearch.index.query
-
A query that matches no document.
- MatchNoneQueryBuilder() - Constructor for class org.elasticsearch.index.query.MatchNoneQueryBuilder
- MatchNoneQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchNoneQueryBuilder
-
Read from a stream.
- matchPhrasePrefixQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a match query with type "PHRASE_PREFIX" for the provided field name and text.
- MatchPhrasePrefixQueryBuilder - Class in org.elasticsearch.index.query
-
Match query is a query that analyzes the text and constructs a phrase prefix query as the result of the analysis.
- MatchPhrasePrefixQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- MatchPhrasePrefixQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Read from a stream.
- matchPhraseQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a text query with type "PHRASE" for the provided field name and text.
- MatchPhraseQueryBuilder - Class in org.elasticsearch.index.query
-
Match query is a query that analyzes the text and constructs a phrase query as the result of the analysis.
- MatchPhraseQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- MatchPhraseQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Read from a stream.
- matchQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a match query with type "BOOLEAN" for the provided field name and text.
- MatchQuery - Class in org.elasticsearch.index.search
- MatchQuery(QueryShardContext) - Constructor for class org.elasticsearch.index.search.MatchQuery
- MatchQuery.Type - Enum in org.elasticsearch.index.search
- MatchQuery.ZeroTermsQuery - Enum in org.elasticsearch.index.search
- MatchQueryBuilder - Class in org.elasticsearch.index.query
-
Match query is a query that analyzes the text and constructs a query as the result of the analysis.
- MatchQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.MatchQueryBuilder
-
Constructs a new match query.
- MatchQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchQueryBuilder
-
Read from a stream.
- matchQueryType() - Method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- max - Variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- max - Variable in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- max(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Find the maximum value in a window of values.
- max(long, long) - Static method in class org.elasticsearch.index.seqno.SequenceNumbers
-
Compute the maximum of the given current maximum sequence number and the specified sequence number, accounting for the fact that the current maximum sequence number could be
SequenceNumbers.NO_OPS_PERFORMED
orSequenceNumbers.UNASSIGNED_SEQ_NO
. - max(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Max
aggregation with the given name. - max(Version, Version) - Static method in class org.elasticsearch.Version
-
Returns the maximum version between the 2
- Max - org.elasticsearch.search.rescore.QueryRescoreMode
- Max - Interface in org.elasticsearch.search.aggregations.metrics.max
-
An aggregation that computes the maximum of the values in the current bucket.
- MAX - org.elasticsearch.common.lucene.search.function.CombineFunction
- MAX - org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- MAX - org.elasticsearch.search.MultiValueMode
-
Pick the highest value.
- MAX - org.elasticsearch.search.sort.SortMode
-
pick the highest value
- MAX_ADJACENCY_MATRIX_FILTERS_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum number of filters clauses that can be used in an adjacency_matrix aggregation.
- MAX_ANALYZED_OFFSET_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
A setting describing the maximum number of characters that will be analyzed for a highlight request.
- MAX_BOOST_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- MAX_BUCKET_SETTING - Static variable in class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- MAX_BYTES_VLONG - Static variable in enum org.elasticsearch.common.util.ByteUtils
- MAX_CHILDREN_FIELD - Static variable in class org.elasticsearch.search.sort.NestedSortBuilder
- MAX_CONCURRENT_GROUP_REQUESTS_FIELD - Static variable in class org.elasticsearch.search.collapse.CollapseBuilder
- MAX_CONCURRENT_SEARCH_REQUESTS_DEFAULT - Static variable in class org.elasticsearch.action.search.MultiSearchRequest
- MAX_COORDINATE - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
- MAX_DOCS_PER_VALUE_DEFAULT - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- MAX_DOCS_PER_VALUE_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- MAX_DOCVALUE_FIELDS_SEARCH_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum value of allowed `docvalue_fields`that can be retrieved per search request.
- MAX_EDITS_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MAX_EXPANSIONS_FIELD - Static variable in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- MAX_EXPANSIONS_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- MAX_FIELD - Static variable in class org.elasticsearch.search.slice.SliceBuilder
- MAX_HIT_COUNT - Static variable in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- MAX_INDEX_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
Only applies when
indices.memory.index_buffer_size
is a %, to set a ceiling on the actual size in bytes (default: not set). - MAX_INDEX_NAME_BYTES - Static variable in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
- MAX_INNER_RESULT_WINDOW_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum value of from + size on an individual inner hit definition or top hits aggregation.
- MAX_INPUT_LENGTH - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- MAX_INSPECTIONS_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MAX_KEEPALIVE_SETTING - Static variable in class org.elasticsearch.search.SearchService
- MAX_LAT - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Maximum valid latitude in degrees.
- MAX_LOCAL_STORAGE_NODES_SETTING - Static variable in class org.elasticsearch.env.NodeEnvironment
-
Maximum number of data nodes that should run in an environment.
- MAX_LON - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Maximum valid longitude in degrees.
- MAX_MERGE_COUNT_SETTING - Static variable in class org.elasticsearch.index.MergeSchedulerConfig
- MAX_NGRAM_DIFF_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing for NGramTokenizer and NGramTokenFilter the maximum difference between max_gram (maximum length of characters in a gram) and min_gram (minimum length of characters in a gram).
- MAX_NUM_SEGMENTS - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest.Defaults
- MAX_OPEN_SCROLL_CONTEXT - Static variable in class org.elasticsearch.search.SearchService
- MAX_PENDING_CLUSTER_STATES_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- MAX_PINGS_FROM_ANOTHER_MASTER_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- MAX_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- MAX_REFRESH_LISTENERS_PER_SHARD - Static variable in class org.elasticsearch.index.IndexSettings
-
The maximum number of refresh listeners allows on this shard.
- MAX_REGEX_LENGTH_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
The maximum length of regex string allowed in a regexp query.
- MAX_RESCORE_WINDOW_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum size of the rescore window.
- MAX_RESULT_WINDOW_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum value of from + size on a query.
- MAX_REWRITE_ROUNDS - Static variable in interface org.elasticsearch.index.query.Rewriteable
- MAX_SCORE - Static variable in class org.elasticsearch.search.SearchHits.Fields
- MAX_SCRIPT_FIELDS_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum value of allowed `script_fields`that can be retrieved per search request.
- MAX_SEQ_NO - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
- MAX_SHINGLE_DIFF_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing for ShingleTokenFilter the maximum difference between max_shingle_size and min_shingle_size.
- MAX_SLICES_PER_SCROLL - Static variable in class org.elasticsearch.index.IndexSettings
-
The maximum number of slices allowed in a scroll request
- MAX_TERM_FREQ_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MAX_TERMS_COUNT_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum number of terms that can be used in Terms Query.
- MAX_THREAD_COUNT_SETTING - Static variable in class org.elasticsearch.index.MergeSchedulerConfig
- MAX_UNSAFE_AUTO_ID_TIMESTAMP_COMMIT_ID - Static variable in class org.elasticsearch.index.engine.Engine
- MaxAgeCondition - Class in org.elasticsearch.action.admin.indices.rollover
-
Condition for index maximum age.
- MaxAgeCondition(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- MaxAgeCondition(TimeValue) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- MaxAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.max
- MaxAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- MaxAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
-
Read from a stream.
- MaxAggregationBuilder(MaxAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- MaxAggregator - Class in org.elasticsearch.search.aggregations.metrics.max
- MaxAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.max
- MaxAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.MaxAggregatorFactory
- maxBoost() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the maximum boost that will be applied by function score.
- maxBoost(float) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Sets the maximum boost that will be applied by function score.
- maxBound() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Get the current maximum bound that is set on this builder.
- maxBucket() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- maxBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- maxBucketOrd() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Return an upper bound of the maximum bucket ordinal seen so far.
- MaxBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max
- MaxBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- MaxBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
-
Read from a stream.
- MaxBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max
- MaxBucketPipelineAggregator(String, String[], BucketHelpers.GapPolicy, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
- MaxBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
-
Read from a stream.
- maxConcurrentSearchRequests() - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Returns the amount of search requests specified in this multi search requests are allowed to be ran concurrently.
- maxConcurrentSearchRequests(int) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Sets how many search requests specified in this multi search requests are allowed to be ran concurrently.
- maxContentLength() - Method in class org.elasticsearch.http.HttpInfo
- maxDeterminizedStates() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- maxDeterminizedStates() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- maxDeterminizedStates(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Protects against too-difficult regular expression queries.
- maxDeterminizedStates(int) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
-
Sets the regexp maxDeterminizedStates.
- maxDoc() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the maximum document ID this builder can associate with an ordinal
- maxDoc() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
- maxDoc() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- maxDoc(int) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- maxDocFreq - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- maxDocFreq() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- maxDocFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Set the maximum frequency in which words may still appear.
- MaxDocsCondition - Class in org.elasticsearch.action.admin.indices.rollover
-
Condition for maximum index docs.
- MaxDocsCondition(Long) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- MaxDocsCondition(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- maxDocsPerValue() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Get the max num docs to be returned per value.
- maxDocsPerValue(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Set the max num docs to be returned per value.
- maxEdits() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxEdits() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the maximum edit distance setting.
- maxEdits(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxEdits(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets the maximum edit distance candidate suggestions can have in order to be considered as a suggestion.
- maxEdits(Integer) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets the maximum edit distance candidate suggestions can have in order to be considered as a suggestion.
- maxErrors() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the maxErrors setting
- maxErrors(float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the maximum percentage of the terms that at most considered to be misspellings in order to form a correction.
- MAXERRORS_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- maxExpansions - Variable in class org.elasticsearch.index.search.MatchQuery
- maxExpansions() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- maxExpansions() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Get the (optional) number of term expansions when using fuzzy or prefix type query.
- maxExpansions() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Get the (optional) number of term expansions when using fuzzy or prefix type query.
- maxExpansions() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- maxExpansions(int) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- maxExpansions(int) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
The number of term expansions to use.
- maxExpansions(int) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
When using fuzzy or prefix type query, the number of term expansions to use.
- maxExpansions(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
When using fuzzy or prefix type query, the number of term expansions to use.
- maxInputLength(int) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- maxInspections() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxInspections() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the factor for inspecting more candidate suggestions setting.
- maxInspections(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxInspections(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
A factor that is used to multiply with the size in order to inspect more candidate suggestions.
- maxInspections(Integer) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
A factor that is used to multiply with the size in order to inspect more candidate suggestions.
- maxNumSegments() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Will merge the index down to <= maxNumSegments.
- maxNumSegments(int) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Will merge the index down to <= maxNumSegments.
- maxNumTerms - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- maxQueryTerms() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- maxQueryTerms(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the maximum number of query terms that will be included in any generated query.
- maxRadialDistanceMeters(double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Returns the maximum distance/radius (in meters) from the point 'center' before overlapping
- MaxRetryAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that prevents shards from being allocated on any node if the shards allocation has been retried N times without success.
- MaxRetryAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- maxScore - Variable in class org.elasticsearch.search.internal.ScrollContext
- maxSeenAutoIdTimestampOnPrimary() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- maxSeqNo - Variable in class org.elasticsearch.index.seqno.SequenceNumbers.CommitInfo
- maxSeqNoOfUpdatesOrDeletes() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the maximum seq_no of updates (index operations overwrite Lucene) or deletes on the primary.
- maxSeqNoOfUpdatesOrDeletesOnPrimary() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- MaxSizeCondition - Class in org.elasticsearch.action.admin.indices.rollover
-
A size-based condition for an index size.
- MaxSizeCondition(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- MaxSizeCondition(ByteSizeValue) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- maxSurfaceFormsPerAnalyzedForm() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
- maxTermFreq - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- maxTermFreq() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxTermFreq() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the maximum term frequency threshold setting.
- maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets a maximum threshold in number of documents a suggest text token can exist in order to be corrected.
- maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets a maximum threshold in number of documents a suggest text token can exist in order to be corrected.
- maxValue() - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- maxWordLength - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- maxWordLength() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- maxWordLength(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the maximum word length above which words will be ignored.
- maybeApplyMinimumShouldMatch(Query, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
Potentially apply minimum should match value if we have a query that it can be applied to, otherwise return the original query.
- maybeDieOnAnotherThread(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
If the specified cause is an unrecoverable error, this method will rethrow the cause on a separate thread so that it can not be caught and bubbles up to the uncaught exception handler.
- maybeError(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
- maybeError(Throwable, Logger) - Static method in class org.elasticsearch.ExceptionsHelper
-
Unwrap the specified throwable looking for any suppressed errors or errors as a root cause of the specified throwable.
- maybeFailEngine(String, Exception) - Method in class org.elasticsearch.index.engine.Engine
-
Check whether the engine should be failed
- maybeFailEngine(String, Exception) - Method in class org.elasticsearch.index.engine.InternalEngine
- maybeOverrideConnectionProfile(ConnectionProfile) - Method in class org.elasticsearch.transport.TcpTransport
- maybePause(int) - Method in class org.elasticsearch.common.util.CombinedRateLimiter
- maybePruneDeletes() - Method in class org.elasticsearch.index.engine.Engine
-
Tries to prune buffered deletes from the version map.
- maybePruneDeletes() - Method in class org.elasticsearch.index.engine.InternalEngine
- maybePruneDeletes() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- maybeSyncGlobalCheckpoint(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Syncs the global checkpoint to the replicas if the global checkpoint on at least one replica is behind the global checkpoint on the primary.
- maybeThrowRuntimeAndSuppress(List<T>) - Static method in class org.elasticsearch.ExceptionsHelper
-
Throws a runtime exception with all given exceptions added as suppressed.
- MB - org.elasticsearch.common.unit.ByteSizeUnit
- md5() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Returns a
MessageDigest
instance for MD5 digests; note that the instance returned is thread local and must not be shared amongst threads. - mean() - Method in class org.elasticsearch.common.metrics.MeanMetric
- MeanMetric - Class in org.elasticsearch.common.metrics
- MeanMetric() - Constructor for class org.elasticsearch.common.metrics.MeanMetric
- MEDIAN - org.elasticsearch.search.MultiValueMode
-
Pick the median of the values.
- MEDIAN - org.elasticsearch.search.sort.SortMode
-
Use the median of all values as sort value.
- medianAbsoluteDeviation(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
MedianAbsoluteDeviation
aggregation with the given name - MedianAbsoluteDeviation - Interface in org.elasticsearch.search.aggregations.metrics.mad
-
An aggregation that approximates the median absolute deviation of a numeric field
- MedianAbsoluteDeviationAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.mad
- MedianAbsoluteDeviationAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- MedianAbsoluteDeviationAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- MedianAbsoluteDeviationAggregationBuilder(MedianAbsoluteDeviationAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- MedianAbsoluteDeviationAggregator - Class in org.elasticsearch.search.aggregations.metrics.mad
- MedianAbsoluteDeviationAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.mad
- MEDIUM - org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Defaults to 30 seconds
- mega() - Method in class org.elasticsearch.common.unit.SizeValue
- MEGA - org.elasticsearch.common.unit.SizeUnit
- megaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- Mem(long) - Constructor for class org.elasticsearch.monitor.process.ProcessStats.Mem
- Mem(long, long) - Constructor for class org.elasticsearch.monitor.os.OsStats.Mem
- Mem(long, long, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- Mem(long, long, long, long, long, List<JvmStats.MemoryPool>) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Mem
- Mem(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- Mem(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Mem
- Mem(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsStats.Mem
- Mem(StreamInput) - Constructor for class org.elasticsearch.monitor.process.ProcessStats.Mem
- memberKey(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
- members() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
- MembershipAction - Class in org.elasticsearch.discovery.zen
- MembershipAction(TransportService, MembershipAction.MembershipListener, Collection<BiConsumer<DiscoveryNode, ClusterState>>) - Constructor for class org.elasticsearch.discovery.zen.MembershipAction
- MembershipAction.JoinCallback - Interface in org.elasticsearch.discovery.zen
- MembershipAction.JoinRequest - Class in org.elasticsearch.discovery.zen
- MembershipAction.LeaveRequest - Class in org.elasticsearch.discovery.zen
- MembershipAction.MembershipListener - Interface in org.elasticsearch.discovery.zen
- MembersInjector<T> - Interface in org.elasticsearch.common.inject
-
Injects dependencies into the fields and methods on instances of type
T
. - MembersInjectorLookup<T> - Class in org.elasticsearch.common.inject.spi
-
A lookup of the members injector for a type.
- MembersInjectorLookup(Object, TypeLiteral<T>) - Constructor for class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- memberType(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns
Field.class
,Method.class
orConstructor.class
. - MEMORY - org.elasticsearch.common.breaker.CircuitBreaker.Type
- MEMORY - org.elasticsearch.index.query.GeoExecType
- MEMORY_LOCK_SETTING - Static variable in class org.elasticsearch.bootstrap.BootstrapSettings
- memoryInBytes - Variable in class org.elasticsearch.index.engine.Segment
- MemoryPool(String, long, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- MemoryPool(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- memorySizeSetting(String, String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a setting which specifies a memory size.
- memorySizeSetting(String, Function<Settings, String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a setting which specifies a memory size.
- memorySizeSetting(String, ByteSizeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a setting which specifies a memory size.
- MemorySizeValue - Enum in org.elasticsearch.common.unit
-
Utility methods to get memory sizes.
- memoryUsage(int) - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
-
Return the expected per-bucket memory usage for the given precision.
- MergableCustomMetaData<T extends MetaData.Custom> - Interface in org.elasticsearch.cluster
-
Interface to allow merging
MetaData.Custom
. - merge - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- merge() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- merge(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- merge(boolean, SearchPhaseController.ReducedQueryPhase, Collection<? extends SearchPhaseResult>, IntFunction<SearchPhaseResult>) - Method in class org.elasticsearch.action.search.SearchPhaseController
-
Enriches search hits and completion suggestion hits from
sortedDocs
usingfetchResultsArr
, merges suggestions, aggregations and profile results Expects sortedDocs to have top search docs across all shards, optionally followed by top suggest docs for each named completion suggestion ordered by suggestion name - merge(long, HyperLogLogPlusPlus, long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- merge(String, CompressedXContent, MapperService.MergeReason, boolean) - Method in class org.elasticsearch.index.mapper.MapperService
- merge(Collection<Message>) - Method in class org.elasticsearch.common.inject.internal.Errors
- merge(Map<String, Map<String, Object>>, MapperService.MergeReason, boolean) - Method in class org.elasticsearch.index.mapper.MapperService
- merge(Sort, int, int, CollapseTopFieldDocs[], boolean) - Static method in class org.apache.lucene.search.grouping.CollapseTopFieldDocs
-
Returns a new CollapseTopDocs, containing topN collapsed results across the provided CollapseTopDocs, sorting by score.
- merge(IndexMetaData, MapperService.MergeReason, boolean) - Method in class org.elasticsearch.index.mapper.MapperService
- merge(Errors) - Method in class org.elasticsearch.common.inject.internal.Errors
- merge(FieldMapper.MultiFields) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- merge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- merge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper
- merge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.Mapper
-
Return the merge of
mergeWith
into this. - merge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
- merge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- merge(Mapper, boolean) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- merge(Mapping, boolean) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- merge(Mapping, boolean) - Method in class org.elasticsearch.index.mapper.Mapping
- merge(IncludeExclude, IncludeExclude) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- merge(InternalCardinality) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- merge(Suggest.Suggestion.Entry<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
-
Merge any extra fields for this subtype.
- merge(Suggest.Suggestion.Entry<Suggest.Suggestion.Entry.Option>) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- merge(T) - Method in interface org.elasticsearch.cluster.MergableCustomMetaData
-
Merges this custom metadata with other, returning either this or
other
custom metadata. - Merge - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- mergeBuckets(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
- mergeBuckets(long[], long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- mergeDefaults(Map<String, Object>, Map<String, Object>) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Merges the defaults provided as the second parameter into the content of the first.
- mergeFieldValues(List<Object>, char) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- mergeId - Variable in class org.elasticsearch.index.engine.Segment
- mergeInto(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- mergeInto(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- mergeInto(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- MergePolicyConfig - Class in org.elasticsearch.index
-
A shard in elasticsearch is a Lucene index, and a Lucene index is broken down into segments.
- MergeSchedulerConfig - Class in org.elasticsearch.index
-
The merge scheduler (
ConcurrentMergeScheduler
) controls the execution of merge operations once they are needed (according to the merge policy). - mergeStats() - Method in class org.elasticsearch.index.shard.IndexShard
- MergeStats - Class in org.elasticsearch.index.merge
- MergeStats() - Constructor for class org.elasticsearch.index.merge.MergeStats
- MergingBucketsDeferringCollector - 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. - MergingBucketsDeferringCollector(SearchContext) - Constructor for class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
- message(String, String) - Method in class org.elasticsearch.common.lucene.LoggerInfoStream
- Message - Class in org.elasticsearch.common.inject.spi
-
An error message and the context in which it occurred.
- Message(Object, String) - Constructor for class org.elasticsearch.common.inject.spi.Message
- Message(Object, Throwable) - Constructor for class org.elasticsearch.common.inject.spi.Message
- Message(String) - Constructor for class org.elasticsearch.common.inject.spi.Message
- Message(List<Object>, String, Throwable) - Constructor for class org.elasticsearch.common.inject.spi.Message
- MESSAGE_LENGTH_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- MessageDigests - Class in org.elasticsearch.common.hash
-
This MessageDigests class provides convenience methods for obtaining thread local
MessageDigest
instances for MD5, SHA-1, and SHA-256 message digests. - MessageDigests() - Constructor for class org.elasticsearch.common.hash.MessageDigests
- messageReceived(LivenessRequest, TransportChannel) - Method in class org.elasticsearch.action.admin.cluster.node.liveness.TransportLivenessAction
- messageReceived(TransportReplicationAction.ConcreteReplicaRequest<ReplicaRequest>, TransportChannel) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaOperationTransportHandler
- messageReceived(TransportReplicationAction.ConcreteReplicaRequest<ReplicaRequest>, TransportChannel, Task) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaOperationTransportHandler
- messageReceived(TransportReplicationAction.ConcreteShardRequest<Request>, TransportChannel) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryOperationTransportHandler
- messageReceived(TransportReplicationAction.ConcreteShardRequest<Request>, TransportChannel, Task) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryOperationTransportHandler
- messageReceived(BytesReference, TcpChannel) - Method in class org.elasticsearch.transport.TcpTransport
-
This method handles the message receive part for both request and responses
- messageReceived(Request, TransportChannel) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.OperationTransportHandler
- messageReceived(Request, TransportChannel, Task) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.OperationTransportHandler
- messageReceived(T, TransportChannel) - Method in class org.elasticsearch.transport.TaskAwareTransportRequestHandler
- messageReceived(T, TransportChannel) - Method in interface org.elasticsearch.transport.TransportRequestHandler
- messageReceived(T, TransportChannel, Task) - Method in interface org.elasticsearch.transport.TransportRequestHandler
-
Override this method if access to the Task parameter is needed
- meta() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- meta(Map<String, Object>) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
- META - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- META_ADDRESS - Static variable in class org.elasticsearch.common.transport.TransportAddress
-
A non-routeable v4 meta transport address that can be used for testing or in scenarios where targets should be marked as non-applicable from a transport perspective.
- metadata - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- metadata - Variable in class org.elasticsearch.search.aggregations.ParsedAggregation
- metadata() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns the StoreFileMetaData for this file info.
- metadata() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- metaData - Variable in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- metaData - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
- metaData - Variable in class org.elasticsearch.search.aggregations.InternalAggregation
- metaData - Variable in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- metaData() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- metaData() - Method in class org.elasticsearch.bootstrap.BootstrapContext
- metaData() - Method in class org.elasticsearch.cluster.ClusterState
- metaData() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get metadata of routing nodes
- metaData() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeGatewayMetaState
- metaData() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- metaData() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- metaData(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- metaData(MetaData) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- metaData(MetaData.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- MetaData - Class in org.elasticsearch.cluster.metadata
- METADATA - org.elasticsearch.cluster.ClusterState.Metric
- METADATA_READ - org.elasticsearch.cluster.block.ClusterBlockLevel
- METADATA_WRITE - org.elasticsearch.cluster.block.ClusterBlockLevel
- MetaData.Builder - Class in org.elasticsearch.cluster.metadata
- MetaData.Custom - Interface in org.elasticsearch.cluster.metadata
- MetaData.XContentContext - Enum in org.elasticsearch.cluster.metadata
- metaDataChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the metadata for the cluster has changed between the previous cluster state and the new cluster state. - MetaDataCreateIndexService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting create index requests
- MetaDataCreateIndexService(Settings, ClusterService, IndicesService, AllocationService, AliasValidator, Environment, IndexScopedSettings, ThreadPool, NamedXContentRegistry, boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
- MetaDataDeleteIndexService - Class in org.elasticsearch.cluster.metadata
-
Deletes indices.
- MetaDataDeleteIndexService(Settings, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService
- MetadataFieldMapper - Class in org.elasticsearch.index.mapper
-
A mapper for a builtin field containing metadata about a document.
- MetadataFieldMapper(String, MappedFieldType, MappedFieldType, Settings) - Constructor for class org.elasticsearch.index.mapper.MetadataFieldMapper
- MetadataFieldMapper.Builder<T extends MetadataFieldMapper.Builder,Y extends MetadataFieldMapper> - Class in org.elasticsearch.index.mapper
- MetadataFieldMapper.TypeParser - Interface in org.elasticsearch.index.mapper
- MetaDataIndexAliasesService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting add and remove aliases requests
- MetaDataIndexAliasesService(ClusterService, IndicesService, AliasValidator, MetaDataDeleteIndexService, NamedXContentRegistry) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService
- MetaDataIndexStateService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting open/close index requests
- MetaDataIndexStateService(ClusterService, AllocationService, MetaDataIndexUpgradeService, IndicesService, ThreadPool, TransportVerifyShardBeforeCloseAction) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexStateService
- MetaDataIndexTemplateService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting index templates updates
- MetaDataIndexTemplateService(ClusterService, MetaDataCreateIndexService, AliasValidator, IndicesService, IndexScopedSettings, NamedXContentRegistry) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService
- MetaDataIndexTemplateService.PutListener - Interface in org.elasticsearch.cluster.metadata
- MetaDataIndexTemplateService.PutRequest - Class in org.elasticsearch.cluster.metadata
- MetaDataIndexTemplateService.PutResponse - Class in org.elasticsearch.cluster.metadata
- MetaDataIndexTemplateService.RemoveListener - Interface in org.elasticsearch.cluster.metadata
- MetaDataIndexTemplateService.RemoveRequest - Class in org.elasticsearch.cluster.metadata
- MetaDataIndexTemplateService.RemoveResponse - Class in org.elasticsearch.cluster.metadata
- MetaDataIndexUpgradeService - Class in org.elasticsearch.cluster.metadata
-
This service is responsible for upgrading legacy index metadata to the current version
- MetaDataIndexUpgradeService(Settings, NamedXContentRegistry, MapperRegistry, IndexScopedSettings, Collection<UnaryOperator<IndexMetaData>>) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexUpgradeService
- metadataMapper(Class<T>) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- metadataMapper(Class<T>) - Method in class org.elasticsearch.index.mapper.Mapping
-
Get the root mapper with the given class.
- MetaDataMappingService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting mapping changes
- MetaDataMappingService(ClusterService, IndicesService) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataMappingService
- metadataSnapshot() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- MetadataSnapshot(Map<String, StoreFileMetaData>, Map<String, String>, long) - Constructor for class org.elasticsearch.index.store.Store.MetadataSnapshot
- MetadataSnapshot(StreamInput) - Constructor for class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Read from a stream.
- MetaDataStateFormat<T> - Class in org.elasticsearch.gateway
-
MetaDataStateFormat is a base class to write checksummed XContent based files to one or more directories in a standardized directory structure.
- MetaDataStateFormat(String) - Constructor for class org.elasticsearch.gateway.MetaDataStateFormat
-
Creates a new
MetaDataStateFormat
instance - metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.FailedNodeException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.common.ParsingException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.ElasticsearchException
-
Renders additional per exception information into the XContent
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.script.ScriptException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.search.SearchParseException
- MetaDataUpdateSettingsService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting update index settings requests
- MetaDataUpdateSettingsService(ClusterService, AllocationService, IndexScopedSettings, IndicesService, ThreadPool) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService
- MetaDataUpgrader - Class in org.elasticsearch.plugins
- MetaDataUpgrader(Collection<UnaryOperator<Map<String, MetaData.Custom>>>, Collection<UnaryOperator<Map<String, IndexTemplateMetaData>>>) - Constructor for class org.elasticsearch.plugins.MetaDataUpgrader
- MetaStateService - Class in org.elasticsearch.gateway
-
Handles writing and loading both
MetaData
andIndexMetaData
- MetaStateService(NodeEnvironment, NamedXContentRegistry) - Constructor for class org.elasticsearch.gateway.MetaStateService
- METERS - org.elasticsearch.common.unit.DistanceUnit
- method() - Method in class org.elasticsearch.rest.RestRequest
- method() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- method() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- method(PercentilesMethod) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- method(PercentilesMethod) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- METHOD_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- METHOD_NOT_ALLOWED - org.elasticsearch.rest.RestStatus
-
The method specified in the Request-Line is not allowed for the resource identified by the Request-URI.
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.SingleValue
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregator
- metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
- metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregator
- metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregator
- metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregator
- metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregator
- metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
- Metric - Interface in org.elasticsearch.common.metrics
- MetricsAggregator - Class in org.elasticsearch.search.aggregations.metrics
- MetricsAggregator(String, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.MetricsAggregator
- mightMatchNestedDocs(Query) - Method in class org.elasticsearch.index.search.NestedHelper
-
Returns true if the given query might match nested documents.
- mightMatchNonNestedDocs(Query, String) - Method in class org.elasticsearch.index.search.NestedHelper
-
Returns true if the given query might match parent documents or documents that are nested under a different path.
- MILES - org.elasticsearch.common.unit.DistanceUnit
- MILLIMETERS - org.elasticsearch.common.unit.DistanceUnit
- min - Variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- min - Variable in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- min(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Find the minimum value in a window of values If all values are missing/null/NaN, the return value will be NaN
- min(long, long) - Static method in class org.elasticsearch.index.seqno.SequenceNumbers
-
Compute the minimum of the given current minimum sequence number and the specified sequence number, accounting for the fact that the current minimum sequence number could be
SequenceNumbers.NO_OPS_PERFORMED
orSequenceNumbers.UNASSIGNED_SEQ_NO
. - min(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Min
aggregation with the given name. - min(Version, Version) - Static method in class org.elasticsearch.Version
-
Returns the minimum version between the 2.
- Min - org.elasticsearch.search.rescore.QueryRescoreMode
- Min - Interface in org.elasticsearch.search.aggregations.metrics.min
-
An aggregation that computes the minimum of the values in the current bucket.
- MIN - org.elasticsearch.common.lucene.search.function.CombineFunction
- MIN - org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- MIN - org.elasticsearch.search.MultiValueMode
-
Pick the lowest value.
- MIN - org.elasticsearch.search.sort.SortMode
-
pick the lowest value
- MIN_DOC_COUNT_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- MIN_DOC_COUNT_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- MIN_DOC_FREQ_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MIN_INDEX_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
Only applies when
indices.memory.index_buffer_size
is a %, to set a floor on the actual size in bytes (default: 48 MB). - MIN_LAT - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Minimum valid latitude in degrees.
- MIN_LON - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Minimum valid longitude in degrees.
- MIN_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- MIN_RETAINED_SEQNO - Static variable in class org.elasticsearch.index.engine.Engine
- MIN_SCORE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- MIN_SCORE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- MIN_WORD_LENGTH_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MinAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.min
- MinAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- MinAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
-
Read from a stream.
- MinAggregationBuilder(MinAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- MinAggregator - Class in org.elasticsearch.search.aggregations.metrics.min
- MinAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.min
- MinAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.MinAggregatorFactory
- minBound() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Get the current minimum bound that is set on this builder.
- minBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- MinBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min
- MinBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- MinBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
-
Read from a stream.
- MinBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min
- MinBucketPipelineAggregator(String, String[], BucketHelpers.GapPolicy, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
- MinBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
-
Read from a stream.
- minDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- minDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return the minimum count of documents that buckets need to have in order to be included in the response.
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Return the minimum count of documents that buckets need to have in order to be included in the response.
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Returns the minimum document count required per term
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set the minimum count of matching documents that buckets need to have and return this builder so that calls can be chained.
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set the minimum count of matching documents that buckets need to have and return this builder so that calls can be chained.
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
-
Set the minimum document count terms should have in order to appear in the response.
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
-
Set the minimum document count terms should have in order to appear in the response.
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set the minimum document count terms should have in order to appear in the response.
- minDocFreq - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- minDocFreq() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- minDocFreq() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- minDocFreq() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the minimal threshold for the frequency of a term appearing in the document set setting.
- minDocFreq(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- minDocFreq(float) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets a minimal threshold in number of documents a suggested term should appear in.
- minDocFreq(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets a minimal threshold in number of documents a suggested term should appear in.
- minDocFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the frequency at which words will be ignored which do not occur in at least this many docs.
- MinDocQuery - Class in org.apache.lucene.queries
-
A
Query
that only matches documents that are greater than or equal to a configured doc ID. - MinDocQuery(int) - Constructor for class org.apache.lucene.queries.MinDocQuery
-
Sole constructor.
- minimize() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Gets whether the model should be fit to the data using a cost minimizing algorithm.
- minimize(boolean) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Sets whether the model should be fit to the data using a cost minimizing algorithm.
- minimize(MovAvgModel, EvictingQueue<Double>, double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.movavg.SimulatedAnealingMinimizer
-
Runs the simulated annealing algorithm and produces a model with new coefficients that, theoretically fit the data better and generalizes to future forecasts without overfitting.
- minimizeByDefault() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- minimizeByDefault() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Should this model be fit to the data via a cost minimizing algorithm by default?
- MINIMUM_SHOULD_MATCH_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- minimumCompatibilityVersion() - Method in class org.elasticsearch.Version
-
Returns the minimum compatible version based on the current version.
- minimumCompatibleVersion() - Method in class org.elasticsearch.index.shard.IndexShard
- minimumIndexCompatibilityVersion() - Method in class org.elasticsearch.Version
-
Returns the minimum created index version that this version supports.
- minimumMasterNodes() - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- minimumMasterNodes(int) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- minimumMasterNodesOnPublishingMaster(int) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- minimumScore() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- minimumScore() - Method in class org.elasticsearch.search.internal.SearchContext
- minimumScore(float) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- minimumScore(float) - Method in class org.elasticsearch.search.internal.SearchContext
- minimumScore(float) - Method in class org.elasticsearch.search.internal.SubSearchContext
- MinimumScoreCollector - Class in org.elasticsearch.common.lucene
- MinimumScoreCollector(Collector, float) - Constructor for class org.elasticsearch.common.lucene.MinimumScoreCollector
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets the minimumShouldMatch value
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the minimumShouldMatch to apply to the resulting query should that be a Boolean query.
- minimumShouldMatch(int) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Specifies a minimum number of the optional (should) boolean clauses which must be satisfied.
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Sets the minimum should match parameter using the special syntax (for example, supporting percentage).
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets optional minimumShouldMatch value to apply to the query
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specifies the minimumShouldMatch to apply to the resulting query should that be a Boolean query.
- minor - Variable in class org.elasticsearch.Version
- minorDeviceNumber - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
- minScore() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the minimum score below which docs will be filtered out.
- minScore(float) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the minimum score below which docs will be filtered out.
- minTermFreq - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- minTermFreq() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- minTermFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
The frequency below which terms will be ignored in the source doc.
- minus(long, TemporalUnit) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minus(TemporalAmount) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusDays(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusHours(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusMinutes(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusMonths(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusNanos(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusSeconds(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusWeeks(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusYears(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- MINUTE - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- minutes(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- MINUTES_OF_HOUR - org.elasticsearch.common.rounding.DateTimeUnit
- minValue() - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- minWordLength - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- minWordLength() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- minWordLength() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- minWordLength() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the minimum length of a text term to be corrected setting.
- minWordLength(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the minimum word length below which words will be ignored.
- minWordLength(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- minWordLength(int) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
The minimum length a suggest text term must have in order to be corrected.
- minWordLength(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
The minimum length a suggest text term must have in order to be corrected.
- misplacedBindingAnnotation(Member, Annotation) - Method in class org.elasticsearch.common.inject.internal.Errors
- missing - Variable in class org.elasticsearch.index.store.Store.RecoveryDiff
-
Files that exist in the source but not in the target
- missing() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- missing() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Deprecated.
- missing() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the value to use when the aggregation finds a missing value in a document
- missing() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- missing() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the value used when a field is missing in a doc.
- missing(double) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
-
Value used instead of the field value for documents that don't have that field defined.
- missing(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Deprecated.Use
CompositeValuesSourceBuilder.missingBucket(boolean)
instead. - missing(Object) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the value to use when the aggregation finds a missing value in a document
- missing(Object) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- missing(Object) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Sets the value when a field is missing in a doc.
- missing(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Missing
aggregation with the given name. - Missing - Interface in org.elasticsearch.search.aggregations.bucket.missing
-
A
missing
aggregation. - MISSING - org.elasticsearch.cluster.SnapshotsInProgress.State
- MISSING - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Only suggest terms in the suggest text that aren't in the index.
- MISSING - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- MissingAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.missing
- MissingAggregationBuilder(String, ValueType) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- MissingAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
-
Read from a stream.
- MissingAggregationBuilder(MissingAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- MissingAggregator - Class in org.elasticsearch.search.aggregations.bucket.missing
- MissingAggregator(String, AggregatorFactories, ValuesSource, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
- MissingAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.missing
- MissingAggregatorFactory(String, ValuesSourceConfig<ValuesSource>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- missingBucket() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
False if documents with missing values are ignored, otherwise missing values are represented by an explicit `null` value.
- missingBucket(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
If true an explicit `null bucket will represent documents with missing values.
- missingConstantValues() - Method in class org.elasticsearch.common.inject.internal.Errors
- missingConstructor(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- MissingHistoryOperationsException - Exception in org.elasticsearch.index.engine
-
Exception indicating that not all requested operations from
LuceneChangesSnapshot
are available. - missingImplementation(Key) - Method in class org.elasticsearch.common.inject.internal.Errors
-
We use a fairly generic error message here.
- missingObject(Object, boolean) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Return the missing object value according to the reduced type of the comparator.
- missingRuntimeRetention(Object) - Method in class org.elasticsearch.common.inject.internal.Errors
- missingScopeAnnotation() - Method in class org.elasticsearch.common.inject.internal.Errors
- missingValue - Variable in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- missingValue(boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- missingValue(boolean) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Return a missing value that is understandable by
SortField.setMissingValue(Object)
. - MissingValues - Enum in org.elasticsearch.search.aggregations.support
-
Utility class that allows to return views of
ValuesSource
s that replace the missing value with a configured value. - MMAPFS - org.elasticsearch.index.IndexModule.Type
- mode - Variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- model() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Gets a MovAvgModel for the Moving Average.
- model(MovAvgModel) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Sets a MovAvgModel for the Moving Average.
- MODEL - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- modelBuilder(MovAvgModelBuilder) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Sets a MovAvgModel for the Moving Average.
- modifier() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- modifier(FieldValueFactorFunction.Modifier) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- Module - Interface in org.elasticsearch.common.inject
-
A module contributes configuration information, typically interface bindings, which will be used to create an
Injector
. - Modules - Class in org.elasticsearch.common.inject.util
-
Static utility methods for creating and working with instances of
Module
. - Modules.OverriddenModuleBuilder - Interface in org.elasticsearch.common.inject.util
-
See the EDSL example at
override()
. - ModulesBuilder - Class in org.elasticsearch.common.inject
- ModulesBuilder() - Constructor for class org.elasticsearch.common.inject.ModulesBuilder
- modulesFile() - Method in class org.elasticsearch.env.Environment
- MonitorService - Class in org.elasticsearch.monitor
- MonitorService(Settings, NodeEnvironment, ThreadPool, ClusterInfoService) - Constructor for class org.elasticsearch.monitor.MonitorService
- MONTH - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- MONTH_OF_YEAR - org.elasticsearch.common.rounding.DateTimeUnit
- moreLikeThisQuery(String[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A more like this query that finds documents that are "like" the provided texts which is checked against the "_all" field.
- moreLikeThisQuery(String[], String[], MoreLikeThisQueryBuilder.Item[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A more like this query that finds documents that are "like" the provided texts or documents which is checked against the fields the query is constructed with.
- moreLikeThisQuery(String[], MoreLikeThisQueryBuilder.Item[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A more like this query that finds documents that are "like" the provided texts or documents which is checked against the "_all" field.
- moreLikeThisQuery(MoreLikeThisQueryBuilder.Item[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A more like this query that finds documents that are "like" the provided documents which is checked against the "_all" field.
- MoreLikeThisQuery - Class in org.elasticsearch.common.lucene.search
- MoreLikeThisQuery() - Constructor for class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- MoreLikeThisQuery(String, String[], Analyzer) - Constructor for class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- MoreLikeThisQueryBuilder - Class in org.elasticsearch.index.query
-
A more like this query that finds documents that are "like" the provided set of document(s).
- MoreLikeThisQueryBuilder(String[], String[], MoreLikeThisQueryBuilder.Item[]) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the field names that will be used when generating the 'More Like This' query.
- MoreLikeThisQueryBuilder(String[], MoreLikeThisQueryBuilder.Item[]) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Constructs a new more like this query which uses the "_all" field.
- MoreLikeThisQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Read from a stream.
- MoreLikeThisQueryBuilder.Item - Class in org.elasticsearch.index.query
-
A single item to be used for a
MoreLikeThisQueryBuilder
. - MoreTypes - Class in org.elasticsearch.common.inject.internal
-
Static methods for working with types that we aren't publishing in the public
Types
API. - MoreTypes.GenericArrayTypeImpl - Class in org.elasticsearch.common.inject.internal
- MoreTypes.MemberImpl - Class in org.elasticsearch.common.inject.internal
-
We cannot serialize the built-in Java member classes, which prevents us from using Members in our exception types.
- MoreTypes.ParameterizedTypeImpl - Class in org.elasticsearch.common.inject.internal
- MoreTypes.WildcardTypeImpl - Class in org.elasticsearch.common.inject.internal
-
The WildcardType interface supports multiple upper bounds and multiple lower bounds.
- mortonEncode(long) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode to a morton long value from a given geohash long value
- mortonEncode(String) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode to a morton long value from a given geohash string
- MOST_FIELDS - org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the sum of the matching boolean fields to score the query
- MovAvgModel - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
- MovAvgModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
- MovAvgModel.AbstractModelParser - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
-
Abstract class which also provides some concrete parsing functionality.
- MovAvgModelBuilder - Interface in org.elasticsearch.search.aggregations.pipeline.movavg.models
-
Represents the common interface that all moving average models share.
- MovAvgPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.movavg
- MovAvgPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- MovAvgPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Read from a stream.
- MovAvgPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.movavg
- MovAvgPipelineAggregator(String, String[], DocValueFormat, BucketHelpers.GapPolicy, int, int, MovAvgModel, boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
- MovAvgPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
-
Read from a stream.
- moveActiveReplicaToPrimary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Make the active shard primary unless it's not primary
- MoveAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
A command that moves a shard from a specific node to another node.
Note: The shard needs to be in the stateShardRoutingState.STARTED
in order to be moved. - MoveAllocationCommand(String, int, String, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- MoveAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
-
Read from a stream.
- moveBlobAtomic(String, String, boolean) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- MOVED_PERMANENTLY - org.elasticsearch.rest.RestStatus
-
The requested resource has been assigned a new permanent URI and any future references to this resource SHOULD use one of the returned URIs.
- MoveDecision - Class in org.elasticsearch.cluster.routing.allocation
-
Represents a decision to move a started shard, either because it is no longer allowed to remain on its current node or because moving it to another node will form a better cluster balance.
- MoveDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.MoveDecision
- moveShards() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Move started shards that can not be allocated to a node anymore For each shard to be moved this function executes a move operation to the minimal eligible node with respect to the weight function.
- moveToClosed() - Method in class org.elasticsearch.common.component.Lifecycle
- moveToDone(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- moveToFailed(long, String) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- moveToFinalize(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- moveToStarted() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Set the shards state to
STARTED
. - moveToStarted() - Method in class org.elasticsearch.common.component.Lifecycle
- moveToStarted(long, int, int, long, long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- moveToStopped() - Method in class org.elasticsearch.common.component.Lifecycle
- moveToUnassigned(UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Moves the shard to unassigned state.
- moveUnassignedFromPrimary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Set the unassigned primary shard to non-primary
- MovFnPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.movfn
- MovFnPipelineAggregationBuilder(String, String, Script, int) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- MovFnPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- MovFnPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.movfn
-
This pipeline aggregation gives the user the ability to script functions that "move" across a window of data, instead of single data points.
- MovFnPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregator
- movingAvg(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
-
Deprecated.
- movingFunction(String, Script, String, int) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- MovingFunctions - Class in org.elasticsearch.search.aggregations.pipeline.movfn
-
Provides a collection of static utility methods that can be referenced from MovingFunction script contexts
- MovingFunctions() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
- MovingFunctionScript - Class in org.elasticsearch.search.aggregations.pipeline.movfn
-
This class provides a custom script context for the Moving Function pipeline aggregation, so that we can expose a number of pre-baked moving functions like min, max, movavg, etc
- MovingFunctionScript() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctionScript
- MovingFunctionScript.Factory - Interface in org.elasticsearch.search.aggregations.pipeline.movfn
- Multi() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- MULTI_ALLOW_EXPLICIT_INDEX - Static variable in class org.elasticsearch.rest.BaseRestHandler
- MULTI_POLYGON_MAY_OVERLAP - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
It's possible that some geometries in a MULTI* shape might overlap.
- MULTI_STATUS - org.elasticsearch.rest.RestStatus
-
The 207 (Multi-Status) status code provides status for multiple independent operations (see Section 13 for more information).
- MULTI_VALUE_MODE - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionParser
- Multibinder<T> - Class in org.elasticsearch.common.inject.multibindings
-
An API to bind multiple values separately, only to later inject them as a complete collection.
- Multibinder.RealMultibinder<T> - Class in org.elasticsearch.common.inject.multibindings
-
The actual multibinder plays several roles:
- MultiBucketAggregationBuilder - Interface in org.elasticsearch.search.aggregations.bucket
-
Marker interface to indicate that the
AggregationBuilder
is for a multi-bucket aggregation. - MultiBucketCollector - Class in org.elasticsearch.search.aggregations
-
A
BucketCollector
which allows running a bucket collection with severalBucketCollector
s. - multiBucketConsumer() - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
-
Returns a consumer for multi bucket aggregation that checks the total number of buckets created in the response
- MultiBucketConsumer(int) - Constructor for class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- MultiBucketConsumerService - Class in org.elasticsearch.search.aggregations
-
An aggregation service that creates instances of
MultiBucketConsumerService.MultiBucketConsumer
. - MultiBucketConsumerService(ClusterService, Settings) - Constructor for class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- MultiBucketConsumerService.MultiBucketConsumer - Class in org.elasticsearch.search.aggregations
-
An
IntConsumer
that throws aMultiBucketConsumerService.TooManyBucketsException
when the sum of the provided values is above the limit (`search.max_buckets`). - MultiBucketConsumerService.TooManyBucketsException - Exception in org.elasticsearch.search.aggregations
- MultiBucketsAggregation - Interface in org.elasticsearch.search.aggregations.bucket
-
An aggregation that returns multiple buckets
- MultiBucketsAggregation.Bucket - Interface in org.elasticsearch.search.aggregations.bucket
-
A bucket represents a criteria to which all documents that fall in it adhere to.
- MultiCandidateGeneratorWrapper - Class in org.elasticsearch.search.suggest.phrase
- MultiCandidateGeneratorWrapper(int, CandidateGenerator...) - Constructor for class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
- multiFields - Variable in class org.elasticsearch.index.mapper.FieldMapper
- multiFieldsBuilder - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- MultiFileWriter - Class in org.elasticsearch.indices.recovery
- MultiFileWriter(Store, RecoveryState.Index, String, Logger, Runnable) - Constructor for class org.elasticsearch.indices.recovery.MultiFileWriter
- MultiGeoPointValues - Class in org.elasticsearch.index.fielddata
-
A stateful lightweight per document set of
GeoPoint
values. - MultiGeoPointValues() - Constructor for class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Creates a new
MultiGeoPointValues
instance - multiGet(MultiGetRequest) - Method in interface org.elasticsearch.client.Client
-
Multi get documents.
- multiGet(MultiGetRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- multiGet(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in interface org.elasticsearch.client.Client
-
Multi get documents.
- multiGet(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- MultiGetAction - Class in org.elasticsearch.action.get
- MultiGetItemResponse - Class in org.elasticsearch.action.get
-
A single multi get response.
- MultiGetItemResponse(GetResponse, MultiGetResponse.Failure) - Constructor for class org.elasticsearch.action.get.MultiGetItemResponse
- MultiGetRequest - Class in org.elasticsearch.action.get
- MultiGetRequest() - Constructor for class org.elasticsearch.action.get.MultiGetRequest
- MultiGetRequest.Item - Class in org.elasticsearch.action.get
-
A single get item.
- MultiGetRequestBuilder - Class in org.elasticsearch.action.get
-
A multi get document action request builder.
- MultiGetRequestBuilder(ElasticsearchClient, MultiGetAction) - Constructor for class org.elasticsearch.action.get.MultiGetRequestBuilder
- MultiGetResponse - Class in org.elasticsearch.action.get
- MultiGetResponse(MultiGetItemResponse[]) - Constructor for class org.elasticsearch.action.get.MultiGetResponse
- MultiGetResponse.Failure - Class in org.elasticsearch.action.get
-
Represents a failure.
- MultiGetShardRequest - Class in org.elasticsearch.action.get
- MultiGetShardRequest() - Constructor for class org.elasticsearch.action.get.MultiGetShardRequest
- MultiGetShardResponse - Class in org.elasticsearch.action.get
- multiLine(MultiLineStringBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- MULTILINESTRING - org.elasticsearch.common.geo.GeoShapeType
- MultiLineStringBuilder - Class in org.elasticsearch.common.geo.builders
- MultiLineStringBuilder() - Constructor for class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- MultiLineStringBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
-
Read from a stream.
- multiMatchQuery(Object, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a match query with type "BOOLEAN" for the provided field name and text.
- MultiMatchQuery - Class in org.elasticsearch.index.search
- MultiMatchQuery(QueryShardContext) - Constructor for class org.elasticsearch.index.search.MultiMatchQuery
- MultiMatchQueryBuilder - Class in org.elasticsearch.index.query
-
Same as
MatchQueryBuilder
but supports multiple fields. - MultiMatchQueryBuilder(Object, String...) - Constructor for class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Constructs a new text query.
- MultiMatchQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Read from a stream.
- MultiMatchQueryBuilder.Type - Enum in org.elasticsearch.index.query
- MultiOrdinals - Class in org.elasticsearch.index.fielddata.ordinals
-
Ordinals
implementation which is efficient at storing field data ordinals for multi-valued or sparse fields. - MultiOrdinals(OrdinalsBuilder, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
- MultiPhrasePrefixQuery - Class in org.elasticsearch.common.lucene.search
- MultiPhrasePrefixQuery(String) - Constructor for class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- multiPhraseQuery(TokenStream, int, boolean) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- multiPhraseQuery(TokenStream, int, boolean) - Method in class org.elasticsearch.index.mapper.StringFieldType
- multiPhraseQuery(TokenStream, int, boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- MULTIPLE_CHOICES - org.elasticsearch.rest.RestStatus
-
The requested resource corresponds to any one of a set of representations, each with its own specific location, and agent-driven negotiation information (section 12) is being provided so that the user (or user agent) can select a preferred representation and redirect its request to that location.
- MULTIPLICATIVE - org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.SeasonalityType
- Multiply - org.elasticsearch.search.rescore.QueryRescoreMode
- MULTIPLY - org.elasticsearch.common.lucene.search.function.CombineFunction
- MULTIPLY - org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- multiPoint(MultiPointBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- MULTIPOINT - org.elasticsearch.common.geo.GeoShapeType
- MultiPointBuilder - Class in org.elasticsearch.common.geo.builders
- MultiPointBuilder(List<Coordinate>) - Constructor for class org.elasticsearch.common.geo.builders.MultiPointBuilder
-
Create a new
MultiPointBuilder
. - MultiPointBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.MultiPointBuilder
-
Read from a stream.
- multiPolygon(MultiPolygonBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- MULTIPOLYGON - org.elasticsearch.common.geo.GeoShapeType
- MultiPolygonBuilder - Class in org.elasticsearch.common.geo.builders
- MultiPolygonBuilder() - Constructor for class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
Build a MultiPolygonBuilder with RIGHT orientation.
- MultiPolygonBuilder(ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
Build a MultiPolygonBuilder with an arbitrary orientation.
- MultiPolygonBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
Read from a stream.
- multipolygonLucene(Coordinate[][][]) - Static method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- multipolygonS4J(GeometryFactory, Coordinate[][][]) - Static method in class org.elasticsearch.common.geo.builders.PolygonBuilder
-
Create a Multipolygon from a set of coordinates.
- multiSearch(MultiSearchRequest) - Method in interface org.elasticsearch.client.Client
-
Performs multiple search requests.
- multiSearch(MultiSearchRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- multiSearch(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in interface org.elasticsearch.client.Client
-
Performs multiple search requests.
- multiSearch(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- MultiSearchAction - Class in org.elasticsearch.action.search
- MultiSearchRequest - Class in org.elasticsearch.action.search
-
A multi search API request.
- MultiSearchRequest() - Constructor for class org.elasticsearch.action.search.MultiSearchRequest
- MultiSearchRequestBuilder - Class in org.elasticsearch.action.search
-
A request builder for multiple search requests.
- MultiSearchRequestBuilder(ElasticsearchClient, MultiSearchAction) - Constructor for class org.elasticsearch.action.search.MultiSearchRequestBuilder
- MultiSearchResponse - Class in org.elasticsearch.action.search
-
A multi search response.
- MultiSearchResponse(MultiSearchResponse.Item[]) - Constructor for class org.elasticsearch.action.search.MultiSearchResponse
- MultiSearchResponse.Item - Class in org.elasticsearch.action.search
-
A search response item, holding the actual search response, or an error message if it failed.
- MultiTermAwareComponent - Interface in org.elasticsearch.index.analysis
-
Elasticsearch counterpart of
MultiTermAwareComponent
. - MultiTermQueryBuilder - Interface in org.elasticsearch.index.query
- multiTermVectors(MultiTermVectorsRequest) - Method in interface org.elasticsearch.client.Client
-
Multi get term vectors.
- multiTermVectors(MultiTermVectorsRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- multiTermVectors(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in interface org.elasticsearch.client.Client
-
Multi get term vectors.
- multiTermVectors(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- MultiTermVectorsAction - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsItemResponse - Class in org.elasticsearch.action.termvectors
-
A single multi get response.
- MultiTermVectorsItemResponse(TermVectorsResponse, MultiTermVectorsResponse.Failure) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
- MultiTermVectorsRequest - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsRequest() - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- MultiTermVectorsRequestBuilder - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsRequestBuilder(ElasticsearchClient, MultiTermVectorsAction) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- MultiTermVectorsResponse - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsResponse(MultiTermVectorsItemResponse[]) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- MultiTermVectorsResponse.Failure - Class in org.elasticsearch.action.termvectors
-
Represents a failure.
- MultiTermVectorsShardRequest - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsShardRequest() - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- MultiTermVectorsShardResponse - Class in org.elasticsearch.action.termvectors
- MULTIVAL_SEP_CHAR - Static variable in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- MultiValue(String, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- MultiValue(String, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
- MultiValue(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
-
Read from a stream.
- MultiValueMode - Enum in org.elasticsearch.search
-
Defines what values to pick in the case a document contains multiple values for a particular field.
- MultiValuesSource<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.support
-
Class to encapsulate a set of ValuesSource objects labeled by field name
- MultiValuesSource() - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSource
- MultiValuesSource.BytesMultiValuesSource - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSource.GeoPointValuesSource - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSource.NumericMultiValuesSource - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceAggregationBuilder<VS extends ValuesSource,AB extends MultiValuesSourceAggregationBuilder<VS,AB>> - Class in org.elasticsearch.search.aggregations.support
-
Similar to
ValuesSourceAggregationBuilder
, except it references multiple ValuesSources (e.g. - MultiValuesSourceAggregationBuilder(String, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- MultiValuesSourceAggregationBuilder(StreamInput, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- MultiValuesSourceAggregationBuilder(MultiValuesSourceAggregationBuilder<VS, AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- MultiValuesSourceAggregationBuilder.LeafOnly<VS extends ValuesSource,AB extends MultiValuesSourceAggregationBuilder<VS,AB>> - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceAggregatorFactory<VS extends ValuesSource,AF extends MultiValuesSourceAggregatorFactory<VS,AF>> - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceAggregatorFactory(String, Map<String, ValuesSourceConfig<VS>>, DocValueFormat, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- MultiValuesSourceFieldConfig - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceFieldConfig(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- MultiValuesSourceFieldConfig.Builder - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceParseHelper - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceParseHelper() - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceParseHelper
- Murmur3HashFunction - Class in org.elasticsearch.cluster.routing
-
Hash function based on the Murmur3 algorithm, which is the default as of Elasticsearch 2.0.
- MurmurHash3 - Enum in org.elasticsearch.common.hash
-
MurmurHash3 hashing functions.
- MurmurHash3.Hash128 - Class in org.elasticsearch.common.hash
-
A 128-bits hash.
- must() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Gets the queries that must appear in the matching documents.
- must(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Adds a query that must appear in the matching documents and will contribute to scoring.
- mustAck(DiscoveryNode) - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Called to determine which nodes the acknowledgement is expected from.
- mustAck(DiscoveryNode) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Called to determine which nodes the acknowledgement is expected from
- mustNot() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Gets the queries that must not appear in the matching documents.
- mustNot(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Adds a query that must not appear in the matching documents.
- mustReschedule() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Test any external conditions that determine whether the task should be scheduled.
- mustVisitAllDocs() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- mutableIterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- MutualInformation - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- MutualInformation(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
- MutualInformation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
-
Read from a stream.
- MutualInformation.MutualInformationBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- MutualInformationBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation.MutualInformationBuilder
N
- name - Variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest.NameOrDefinition
- name - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition
- name - Variable in class org.elasticsearch.common.io.stream.NamedWriteableRegistry.Entry
-
A name for the writeable which is unique to the
NamedWriteableRegistry.Entry.categoryClass
. - name - Variable in class org.elasticsearch.index.mapper.Mapper.Builder
- name - Variable in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- name - Variable in class org.elasticsearch.script.ScriptContext
-
A unique identifier for this context.
- name - Variable in class org.elasticsearch.search.aggregations.AggregationBuilder
- name - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- name - Variable in class org.elasticsearch.search.aggregations.AggregatorFactories.AggParseContext
- name - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
- name - Variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- name - Variable in class org.elasticsearch.search.aggregations.InternalAggregation
- name - Variable in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- name - Variable in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- name - Variable in class org.elasticsearch.search.suggest.completion.context.ContextBuilder
- name - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- name - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
- name() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
-
The name of the repository.
- name() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
The name of the repository.
- name() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
-
The name of the repository.
- name() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the alias name
- name() - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- name() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
-
The index template name to delete.
- name() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The name of the index template.
- name() - Method in class org.elasticsearch.action.GenericAction
-
The name of the action.
- name() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- name() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
-
Returns repository name
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- name() - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
-
Get the name of the command
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- name() - Method in interface org.elasticsearch.common.blobstore.BlobMetaData
-
Gets the name of the blob.
- name() - Method in class org.elasticsearch.common.blobstore.support.PlainBlobMetaData
- name() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
- name() - Method in class org.elasticsearch.index.analysis.AbstractCharFilterFactory
- name() - Method in class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
-
Returns the injected name of the analyzer.
- name() - Method in class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
- name() - Method in interface org.elasticsearch.index.analysis.AnalyzerProvider
- name() - Method in interface org.elasticsearch.index.analysis.CharFilterFactory
- name() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
The name of the analyzer.
- name() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
- name() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- name() - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
- name() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- name() - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- name() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- name() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- name() - Method in class org.elasticsearch.index.mapper.FieldMapper
- name() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- name() - Method in class org.elasticsearch.index.mapper.Mapper.Builder
- name() - Method in class org.elasticsearch.index.mapper.Mapper
-
Returns the canonical name which uniquely identifies the mapper against other mappers in a type.
- name() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- name() - Method in class org.elasticsearch.index.similarity.SimilarityProvider
-
Return the name of this
Similarity
. - name() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns the base file name
- name() - Method in class org.elasticsearch.index.store.StoreFileMetaData
-
Returns the name of this file
- name() - Method in exception org.elasticsearch.indices.IndexTemplateMissingException
- name() - Method in exception org.elasticsearch.indices.InvalidIndexTemplateException
- name() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- name() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
-
file name *
- name() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Return the name of this aggregator.
- name() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- name() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- name() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
- name() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- name() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- name() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- name() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- name() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
-
The name of the field highlighted.
- name() - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext.ScriptField
- name() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- name() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- name() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
Snapshot name
- name() - Method in class org.elasticsearch.threadpool.ExecutorBuilder
- name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
-
Sets the name of the repository to unregister.
- name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the name of the repository.
- name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
-
Sets the name of the repository to unregister.
- name(String) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
-
Set the index template name to delete.
- name(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the name of the index template.
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.liveness.TransportLivenessAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.flush.FlushAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.flush.SyncedFlushAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.get.GetIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.shrink.ResizeAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.shrink.ShrinkAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
- NAME - Static variable in class org.elasticsearch.action.bulk.BulkAction
- NAME - Static variable in class org.elasticsearch.action.delete.DeleteAction
- NAME - Static variable in class org.elasticsearch.action.explain.ExplainAction
- NAME - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesAction
- NAME - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- NAME - Static variable in class org.elasticsearch.action.get.GetAction
- NAME - Static variable in class org.elasticsearch.action.get.MultiGetAction
- NAME - Static variable in class org.elasticsearch.action.index.IndexAction
- NAME - Static variable in class org.elasticsearch.action.ingest.DeletePipelineAction
- NAME - Static variable in class org.elasticsearch.action.ingest.GetPipelineAction
- NAME - Static variable in class org.elasticsearch.action.ingest.PutPipelineAction
- NAME - Static variable in class org.elasticsearch.action.ingest.SimulatePipelineAction
- NAME - Static variable in class org.elasticsearch.action.main.MainAction
- NAME - Static variable in class org.elasticsearch.action.search.ClearScrollAction
- NAME - Static variable in class org.elasticsearch.action.search.MultiSearchAction
- NAME - Static variable in class org.elasticsearch.action.search.SearchAction
- NAME - Static variable in class org.elasticsearch.action.search.SearchScrollAction
- NAME - Static variable in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- NAME - Static variable in class org.elasticsearch.action.termvectors.MultiTermVectorsAction
- NAME - Static variable in class org.elasticsearch.action.termvectors.TermVectorsAction
- NAME - Static variable in class org.elasticsearch.action.update.UpdateAction
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.NodeVersionAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.RebalanceOnlyWhenActiveAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ResizeAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.RestoreInProgressAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- NAME - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.IndexFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.IndexFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.ParentFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.ParentFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SeqNoDefaults
- NAME - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.TypeFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.TypeFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.UidFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.UidFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.VersionFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.VersionFieldMapper
- NAME - Static variable in class org.elasticsearch.index.query.BoolQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.BoostingQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.DisMaxQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.ExistsQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.WeightBuilder
- NAME - Static variable in class org.elasticsearch.index.query.FuzzyQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.IdsQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchAllQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
-
The name for the match query
- NAME - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.NestedQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.PrefixQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.RegexpQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.ScriptQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Name for (de-)serialization.
- NAME - Static variable in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanNearQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanNotQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanOrQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanTermQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.TermQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.TermsQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.TermsSetQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.TypeQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.WildcardQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.WrapperQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- NAME - Static variable in class org.elasticsearch.index.reindex.DeleteByQueryAction
- NAME - Static variable in class org.elasticsearch.index.reindex.ReindexAction
- NAME - Static variable in class org.elasticsearch.index.reindex.UpdateByQueryAction
- NAME - Static variable in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- NAME - Static variable in class org.elasticsearch.persistent.CompletionPersistentTaskAction
- NAME - Static variable in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- NAME - Static variable in class org.elasticsearch.persistent.RemovePersistentTaskAction
- NAME - Static variable in class org.elasticsearch.persistent.StartPersistentTaskAction
- NAME - Static variable in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction
- NAME - Static variable in class org.elasticsearch.repositories.IndexId
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.DocValueFormat.DateTime
- NAME - Static variable in class org.elasticsearch.search.DocValueFormat.Decimal
- NAME - Static variable in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.ScoreSortBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.ScriptSortBuilder
- NAME - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- NAME - Static variable in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- NAME - Static variable in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- NAME - Static variable in class org.elasticsearch.search.suggest.phrase.Laplace
- NAME - Static variable in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- NAME - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- NAME - Static variable in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- NAME - Static variable in class org.elasticsearch.search.suggest.Suggest
- NAME - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion
- NAME - Static variable in class org.elasticsearch.tasks.RawTaskStatus
- NAME_FIELD - Static variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- NAME_FIELD - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- named(String) - Static method in class org.elasticsearch.common.inject.name.Names
-
Creates a
Named
annotation withname
as the value. - Named - Annotation Type in org.elasticsearch.common.inject.name
-
Annotates named things.
- NAMED_STOP_WORDS - Static variable in class org.elasticsearch.index.analysis.Analysis
- NamedAnalyzer - Class in org.elasticsearch.index.analysis
-
Named analyzer is an analyzer wrapper around an actual analyzer (
NamedAnalyzer.analyzer
that is associated with a name (NamedAnalyzer.name()
. - NamedAnalyzer(String, AnalyzerScope, Analyzer) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
- NamedAnalyzer(String, AnalyzerScope, Analyzer, int) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
- NamedAnalyzer(NamedAnalyzer, int) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
- NamedDiff<T extends Diffable<T>> - Interface in org.elasticsearch.cluster
-
Diff that also support NamedWriteable interface
- NamedDiffable<T> - Interface in org.elasticsearch.cluster
-
Diff that also support
VersionedNamedWriteable
interface - NamedDiffableValueSerializer<T extends NamedDiffable<T>> - Class in org.elasticsearch.cluster
-
Value Serializer for named diffables
- NamedDiffableValueSerializer(Class<T>) - Constructor for class org.elasticsearch.cluster.NamedDiffableValueSerializer
- namedFilters() - Method in class org.elasticsearch.index.query.ParsedQuery
- NamedRegistry<T> - Class in org.elasticsearch.common
-
A registry from String to some class implementation.
- NamedRegistry(String) - Constructor for class org.elasticsearch.common.NamedRegistry
- NamedWriteable - Interface in org.elasticsearch.common.io.stream
-
A
Writeable
object identified by its name. - NamedWriteableAwareStreamInput - Class in org.elasticsearch.common.io.stream
-
Wraps a
StreamInput
and associates it with aNamedWriteableRegistry
- NamedWriteableAwareStreamInput(StreamInput, NamedWriteableRegistry) - Constructor for class org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- namedWriteableRegistry - Variable in class org.elasticsearch.client.transport.TransportClient
- NamedWriteableRegistry - Class in org.elasticsearch.common.io.stream
-
A registry for
Writeable.Reader
readers ofNamedWriteable
. - NamedWriteableRegistry(List<NamedWriteableRegistry.Entry>) - Constructor for class org.elasticsearch.common.io.stream.NamedWriteableRegistry
-
Constructs a new registry from the given entries.
- NamedWriteableRegistry.Entry - Class in org.elasticsearch.common.io.stream
-
An entry in the registry, made up of a category class and name, and a reader for that category class.
- NamedXContentProvider - Interface in org.elasticsearch.plugins.spi
-
Provides named XContent parsers.
- namedXContentRegistry - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
- namedXContentRegistry - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- names() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- names() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
-
The names of the index templates.
- names() - Method in class org.elasticsearch.common.settings.Settings
- names(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- names(String...) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
-
Sets the names of the index templates.
- Names - Class in org.elasticsearch.common.inject.name
-
Utility methods for use with
@
Named
. - Names() - Constructor for class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Names
- Names() - Constructor for class org.elasticsearch.index.mapper.FieldAliasMapper.Names
- Names() - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper.Names
- Names() - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Names
-
Deprecated.
- Names() - Constructor for class org.elasticsearch.threadpool.ThreadPool.Names
- NAN - Static variable in class org.elasticsearch.common.geo.parsers.GeoWKTParser
- nativeControllerPath(Path) - Static method in class org.elasticsearch.plugins.Platforms
-
The path to the native controller for a plugin with native components.
- NAUTICALMILES - org.elasticsearch.common.unit.DistanceUnit
- NEAR - org.elasticsearch.index.query.SimpleQueryStringFlag
- needs_score() - Method in interface org.elasticsearch.script.ScoreScript.LeafFactory
-
Return
true
if the script needs_score
calculated, orfalse
otherwise. - needs_score() - Method in interface org.elasticsearch.script.SearchScript.LeafFactory
-
Return
true
if the script needs_score
calculated, orfalse
otherwise. - needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.CustomFieldsVisitor
- needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- needsReassignment(PersistentTasksCustomMetaData.Assignment, DiscoveryNodes) - Static method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Returns true if the task is not assigned or is assigned to a non-existing node
- needsRefresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Returns
true
iff the cache needs to be refreshed. - needsScores() - Method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
- needsScores() - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
- needsScores() - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
-
Indicates if document scores are needed by this function.
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- needsScores() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Most aggregators don't need scores, make sure to extend this method if your aggregator needs them.
- needsScores() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregator
- needsScores() - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
-
Whether this values source needs scores.
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.WithScript
- needsScores() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- needsScores() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- needToCheck() - Method in class org.elasticsearch.action.support.AutoCreateIndex
-
Do we really need to check if an index should be auto created?
- negativeBoost() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
Get the negative boost factor.
- negativeBoost(float) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
Set the negative boost factor.
- negativeQuery() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
Get the negative query for this boosting query.
- neighbor(String, int, int, int) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Calculate the geohash of a neighbor of a geohash
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Generates a "neighboring" model, where one of the tunable parameters has been randomly mutated within the allowed range.
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- neighbors(String) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Calculate all neighbors of a given geohash cell.
- nested - Variable in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- nested - Variable in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- nested() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- nested() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- nested(String, String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Nested
aggregation with the given name. - nested(ObjectMapper.Nested) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- Nested - Interface in org.elasticsearch.search.aggregations.bucket.nested
-
A
nested
aggregation. - Nested(BitSetProducer, Query, NestedSortBuilder, Function<IndexReaderContext, IndexSearcher>) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
- NESTED - Static variable in class org.elasticsearch.index.mapper.ObjectMapper.Defaults
- NESTED_CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.ObjectMapper
- NESTED_FIELD - Static variable in class org.elasticsearch.search.sort.NestedSortBuilder
- NESTED_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper.Defaults
- NESTED_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.UidFieldMapper.Defaults
- NESTED_FILTER_FIELD - Static variable in class org.elasticsearch.search.sort.SortBuilder
- NESTED_PATH_FIELD - Static variable in class org.elasticsearch.search.sort.SortBuilder
- NestedAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.nested
- NestedAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- NestedAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
-
Read from a stream.
- NestedAggregationBuilder(NestedAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- NestedAggregator - Class in org.elasticsearch.search.aggregations.bucket.nested
- NestedAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.nested
- NestedHelper - Class in org.elasticsearch.index.search
-
Utility class to filter parent and children clauses when building nested queries.
- NestedHelper(MapperService) - Constructor for class org.elasticsearch.index.search.NestedHelper
- NestedIdentity(String, int, SearchHit.NestedIdentity) - Constructor for class org.elasticsearch.search.SearchHit.NestedIdentity
- nestedQuery(String, QueryBuilder, ScoreMode) - Static method in class org.elasticsearch.index.query.QueryBuilders
- NestedQueryBuilder - Class in org.elasticsearch.index.query
- NestedQueryBuilder(String, QueryBuilder, ScoreMode) - Constructor for class org.elasticsearch.index.query.NestedQueryBuilder
- NestedQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.NestedQueryBuilder
-
Read from a stream.
- nestedScope() - Method in class org.elasticsearch.index.query.QueryShardContext
- NestedScope - Class in org.elasticsearch.index.query.support
-
During query parsing this keeps track of the current nested level.
- NestedScope() - Constructor for class org.elasticsearch.index.query.support.NestedScope
- NestedSortBuilder - Class in org.elasticsearch.search.sort
- NestedSortBuilder(String) - Constructor for class org.elasticsearch.search.sort.NestedSortBuilder
- NestedSortBuilder(StreamInput) - Constructor for class org.elasticsearch.search.sort.NestedSortBuilder
- nestedTypeFilter() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- nestedTypePathAsString() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- NETWORK_SERVER - Static variable in class org.elasticsearch.common.network.NetworkService
- NetworkAddress - Class in org.elasticsearch.common.network
-
Utility functions for presentation of network addresses.
- NetworkExceptionHelper - Class in org.elasticsearch.common.transport
- NetworkExceptionHelper() - Constructor for class org.elasticsearch.common.transport.NetworkExceptionHelper
- NetworkMessage - Class in org.elasticsearch.transport
-
Represents a transport message sent over the network.
- NetworkModule - Class in org.elasticsearch.common.network
-
A module to handle registering and binding all network related classes.
- NetworkModule(Settings, boolean, List<NetworkPlugin>, ThreadPool, BigArrays, PageCacheRecycler, CircuitBreakerService, NamedWriteableRegistry, NamedXContentRegistry, NetworkService, HttpServerTransport.Dispatcher) - Constructor for class org.elasticsearch.common.network.NetworkModule
-
Creates a network module that custom networking classes can be plugged into.
- NetworkPlugin - Interface in org.elasticsearch.plugins
-
Plugin for extending network and transport related classes
- networkService - Variable in class org.elasticsearch.transport.TcpTransport
- NetworkService - Class in org.elasticsearch.common.network
- NetworkService(List<NetworkService.CustomNameResolver>) - Constructor for class org.elasticsearch.common.network.NetworkService
- NetworkService.CustomNameResolver - Interface in org.elasticsearch.common.network
-
A custom name resolver can support custom lookup keys (my_net_key:ipv4) and also change the default inet address used in case no settings is provided.
- NetworkUtils - Class in org.elasticsearch.common.network
-
Utilities for network interfaces / addresses binding and publishing.
- NEW_INDEX_RESTORED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of restoring into a new index.
- NEW_PRIMARIES - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Create a new empty sub aggregation.
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- newAliasMetaData(AliasMetaData, String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
Creates a new AliasMetaData instance with same content as the given one, but with a different alias name
- newAliasMetaDataBuilder(String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData
- newAllocationId(Environment, ShardPath, Terminal) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- newAutoQueueFixed(String, int, int, int, int, int, TimeValue, ThreadFactory, ThreadContext) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Return a new executor that will automatically adjust the queue size based on queue throughput.
- newBlockingQueue() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newBuilder() - Method in class org.elasticsearch.rest.AbstractRestChannel
- newBuilder() - Method in interface org.elasticsearch.rest.RestChannel
- newBuilder(XContentType, boolean) - Method in class org.elasticsearch.rest.AbstractRestChannel
-
Creates a new
XContentBuilder
for a response to be sent using this channel. - newBuilder(XContentType, boolean) - Method in interface org.elasticsearch.rest.RestChannel
- newByteArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
ByteArray
initialized with zeros. - newByteArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
ByteArray
. - newBytesOutput() - Method in class org.elasticsearch.rest.AbstractRestChannel
- newCachedSearcher(IndexReaderContext) - Method in class org.elasticsearch.index.query.QueryShardContext
- newChangesSnapshot(String, long, long, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
Creates a new changes snapshot for reading operations whose seq_no are between
fromSeqNo
(inclusive) andtoSeqNo
(inclusive). - newChangesSnapshot(String, MapperService, long, long, boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Creates a new history snapshot from Lucene for reading operations whose seqno in the requesting seqno range (both inclusive).
- newChangesSnapshot(String, MapperService, long, long, boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- newChangesSnapshot(String, MapperService, long, long, boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- newCircleBuilder() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.create a new Circle
- newClusterInfoService(Settings, ClusterService, ThreadPool, NodeClient, Consumer<ClusterInfo>) - Method in class org.elasticsearch.node.Node
-
Constructs a ClusterInfoService which may be mocked for tests.
- newClusterStateBuilder() - Method in interface org.elasticsearch.cluster.service.ClusterApplier
-
Creates a new cluster state builder that is initialized with the cluster name and all initial cluster state customs.
- newClusterStateBuilder() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- newClusterStateBuilder() - Method in class org.elasticsearch.cluster.service.ClusterService
-
Creates a new cluster state builder that is initialized with the cluster name and all initial cluster state customs.
- newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.FloatValuesComparatorSource
- newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- newConcurrentHashSet() - Static method in class org.elasticsearch.common.util.set.Sets
- newConcurrentMap() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newConcurrentMapLong() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newConcurrentMapLongWithAggressiveConcurrency() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
-
Creates a new CHM with an aggressive concurrency level, aimed at highly updateable long living maps.
- newConcurrentMapWithAggressiveConcurrency() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
-
Creates a new CHM with an aggressive concurrency level, aimed at high concurrent update rate long living maps.
- newConcurrentMapWithAggressiveConcurrency(int) - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
-
Creates a new CHM with an aggressive concurrency level, aimed at high concurrent update rate long living maps.
- newConcurrentSet() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newCondition() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- newConfigurationException(String, String, String, Exception) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- newConfigurationException(String, String, String, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- newDefaultQuery(String) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newDeleteTombstoneDoc(String, String) - Method in interface org.elasticsearch.index.engine.EngineConfig.TombstoneDocSupplier
-
Creates a tombstone document for a delete operation.
- newDeque() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newDirectExecutorService() - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Returns an
ExecutorService
that executes submitted tasks on the current thread. - newDirectory() - Method in class org.elasticsearch.index.store.DirectoryService
- newDirectory() - Method in class org.elasticsearch.index.store.FsDirectoryService
- newDirectory(Path) - Method in class org.elasticsearch.gateway.MetaDataStateFormat
- newDirectoryService(ShardPath) - Method in class org.elasticsearch.index.store.IndexStore
-
The shard store class that should be used for each shard.
- newDispatchingListenableFuture(ThreadPool) - Static method in class org.elasticsearch.action.support.PlainListenableActionFuture
-
This method returns a listenable future.
- newDone(long, long, int, int, long, long) - Static method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- newDoubleArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
DoubleArray
of the given capacity. - newDoubleArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
DoubleArray
. - newEntry() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- newEntry() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- newEntry() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- newEntry() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- newEnvelope(Coordinate, Coordinate) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.create a new rectangle
- newErrorBuilder() - Method in class org.elasticsearch.rest.AbstractRestChannel
- newErrorBuilder() - Method in interface org.elasticsearch.rest.RestChannel
- newFactory(Map<String, Object>, Object, SearchLookup) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.MapScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.FilterScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.ScoreScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.SearchScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.TermsSetQueryScript.Factory
- newFailed(String) - Static method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- newFilter(QueryShardContext, String) - Static method in class org.elasticsearch.index.query.ExistsQueryBuilder
- newFixed(String, int, int, ThreadFactory, ThreadContext) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- newFloatArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
FloatArray
of the given capacity. - newFloatArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
FloatArray
. - newFSDirectory(Path, LockFactory) - Method in class org.elasticsearch.index.store.FsDirectoryService
- newFuture() - Static method in class org.elasticsearch.action.support.PlainActionFuture
- newFuzzyQuery(String, int) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newFuzzyQuery(Term, float, int) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- newGeometryCollection() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new GeometryCollection
- newHashSet(Iterable<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- newHashSet(Iterator<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- newHashSet(T...) - Static method in class org.elasticsearch.common.util.set.Sets
- newHeuristic(boolean, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYParser
- newIndexMapperService(NamedXContentRegistry, MapperRegistry, ScriptService) - Method in class org.elasticsearch.index.IndexModule
-
creates a new mapper service to do administrative work like mapping updates.
- newIndexService(NodeEnvironment, NamedXContentRegistry, IndexService.ShardStoreDeleter, CircuitBreakerService, BigArrays, ThreadPool, ScriptService, Client, IndicesQueryCache, MapperRegistry, IndicesFieldDataCache, NamedWriteableRegistry) - Method in class org.elasticsearch.index.IndexModule
- newInitializing() - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id for initializing allocation.
- newInitializing() - Static method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- newInitializing(String) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id for initializing allocation based on an existing id.
- newInstance() - Method in interface org.elasticsearch.script.SignificantTermsHeuristicScoreScript.Factory
- newInstance() - Method in interface org.elasticsearch.script.SimilarityScript.Factory
- newInstance() - Method in interface org.elasticsearch.script.SimilarityWeightScript.Factory
- newInstance() - Method in interface org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctionScript.Factory
- newInstance(int) - Method in class org.elasticsearch.common.recycler.AbstractRecyclerC
- newInstance(int) - Method in interface org.elasticsearch.common.recycler.Recycler.C
-
Create a new empty instance of the given size.
- newInstance(String[]) - Static method in class org.elasticsearch.common.logging.NodeNamePatternConverter
-
Called by log4j2 to initialize this converter.
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.BucketAggregationScript.Factory
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.BucketAggregationSelectorScript.Factory
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.IngestConditionalScript.Factory
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.IngestScript.Factory
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.TemplateScript.Factory
- newInstance(Map<String, Object>, Object) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript.Factory
- newInstance(Map<String, Object>, Object) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.InitScript.Factory
- newInstance(Map<String, Object>, List<Object>) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript.Factory
- newInstance(Map<String, Object>, Map<String, Object>) - Method in interface org.elasticsearch.script.UpdateScript.Factory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.FilterScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.ScoreScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.MapScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.SearchScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.TermsSetQueryScript.LeafFactory
- newInstance(SnapshotDeletionsInProgress.Entry) - Static method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns a new instance of
SnapshotDeletionsInProgress
with the givenSnapshotDeletionsInProgress.Entry
added. - newIntArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
IntArray
. - newIntArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
IntArray
. - newIntersectsQuery(String, byte[]) - Static method in class org.apache.lucene.document.BinaryRange
-
Create a query for matching indexed ip ranges that
INTERSECT
the defined range. - newLenientFieldQuery(String, RuntimeException) - Static method in class org.elasticsearch.common.lucene.search.Queries
- newLineString(List<Coordinate>) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new lineString
- newLineString(CoordinatesBuilder) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new lineString
- newLinkedList(Iterable<E>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- newListenableFuture() - Static method in class org.elasticsearch.action.support.PlainListenableActionFuture
-
This method returns a listenable future.
- newLongArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
LongArray
. - newLongArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
LongArray
. - newMap() - Static method in class org.elasticsearch.common.collect.HppcMaps
-
Returns a new map with a default initial capacity.
- newMap(int) - Static method in class org.elasticsearch.common.collect.HppcMaps
-
Returns a new map with the given number of expected elements.
- newMapBinder(Binder, Class<K>, Class<V>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound with no binding annotation. - newMapBinder(Binder, Class<K>, Class<V>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound withannotation
. - newMapBinder(Binder, Class<K>, Class<V>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound withannotationType
. - newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound with no binding annotation. - newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound withannotation
. - newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound withannotationType
. - newMapBuilder() - Static method in class org.elasticsearch.common.collect.MapBuilder
- newMapBuilder(Map<K, V>) - Static method in class org.elasticsearch.common.collect.MapBuilder
- newMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- newMatchAllDocsQuery() - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- newMatchAllQuery() - Static method in class org.elasticsearch.common.lucene.search.Queries
- newMatchNoDocsQuery(String) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
Return a query that matches no document.
- newMultiLinestring() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new Collection of lineStrings
- newMultiPoint(List<Coordinate>) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new set of points
- newMultiPolygon() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new Collection of polygons
- newMultiPolygon(ShapeBuilder.Orientation) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new Collection of polygons
- newNested(boolean, boolean) - Static method in class org.elasticsearch.index.mapper.ObjectMapper.Nested
- newNestedFilter() - Static method in class org.elasticsearch.common.lucene.search.Queries
- newNode(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- newNodeRequest(String, NodesRequest) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- newNodeRequest(String, NodesHotThreadsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- newNodeRequest(String, NodesInfoRequest) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- newNodeRequest(String, NodesReloadSecureSettingsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- newNodeRequest(String, NodesStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- newNodeRequest(String, NodesUsageRequest) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- newNodeRequest(String, TransportNodesSnapshotsStatus.Request) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- newNodeRequest(String, ClusterStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- newNodeRequest(String, TransportNodesListGatewayMetaState.Request) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- newNodeRequest(String, TransportNodesListGatewayStartedShards.Request) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- newNodeRequest(String, TransportNodesListShardStoreMetaData.Request) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
- newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- newNodeResponse() - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- newNodeResponse() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- newNodeResponse() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- newNodeResponse() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
- newNonNestedFilter(Version) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
Creates a new non-nested docs query
- newNoNullKeysMap() - Static method in class org.elasticsearch.common.collect.HppcMaps
-
Returns a map like
HppcMaps.newMap()
that does not acceptnull
keys - newNoNullKeysMap(int) - Static method in class org.elasticsearch.common.collect.HppcMaps
-
Returns a map like
HppcMaps.newMap(int)
that does not acceptnull
keys - newNoopTombstoneDoc(String) - Method in interface org.elasticsearch.index.engine.EngineConfig.TombstoneDocSupplier
-
Creates a tombstone document for a noop operation.
- newObjectArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
ObjectArray
. - newOption() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry
- newOption() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- newOption() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry
- newParameterizedType(Type, Type...) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a new parameterized type, applying
typeArguments
torawType
. - newParameterizedTypeWithOwner(Type, Type, Type...) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a new parameterized type, applying
typeArguments
torawType
and enclosed byownerType
. - newPermissionCollection() - Method in class org.elasticsearch.script.ClassPermission
- newPhraseQuery(String, int) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newPoint(double, double) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new point
- newPoint(Coordinate) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new
PointBuilder
from aCoordinate
- newPolygon(List<Coordinate>) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new PolygonBuilder
- newPolygon(CoordinatesBuilder) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.Create a new PolygonBuilder
- newPrefixQuery(String) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newPrivateBinder() - Method in interface org.elasticsearch.common.inject.Binder
-
Creates a new private child environment for bindings and other configuration.
- newQueryShardContext(int, IndexReader, LongSupplier, String) - Method in class org.elasticsearch.index.IndexService
-
Creates a new QueryShardContext.
- newQueue() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newReadWriteEngine(EngineConfig) - Method in interface org.elasticsearch.index.engine.EngineFactory
- newReadWriteEngine(EngineConfig) - Method in class org.elasticsearch.index.engine.InternalEngineFactory
- newRelocation(AllocationId) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id for a shard that moves to be relocated, populating the transient holder for relocationId.
- newReplicasProxy(long) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- newReplicasProxy(long) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- newReplicasProxy(long) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- newReplicasProxy(long) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- newRequest(StreamInput) - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.Action
-
Creates a new request builder given the client provided as argument
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.flush.FlushAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.shrink.ShrinkAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.bulk.BulkAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.delete.DeleteAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.explain.ExplainAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.get.GetAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.get.MultiGetAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.index.IndexAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.ingest.DeletePipelineAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.ingest.GetPipelineAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.ingest.PutPipelineAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.ingest.SimulatePipelineAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.main.MainAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.search.ClearScrollAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.search.MultiSearchAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.search.SearchAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.search.SearchScrollAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.termvectors.TermVectorsAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.action.update.UpdateAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.index.reindex.DeleteByQueryAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.index.reindex.ReindexAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.index.reindex.UpdateByQueryAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Add
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction
- newRequestBuilder(ElasticsearchClient) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportDeleteStoredScriptAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetStoredScriptAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportPutStoredScriptAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
- newResponse() - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.flush.FlushAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.shards.TransportIndicesShardStoresAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.shrink.ShrinkAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsAction
- newResponse() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
- newResponse() - Method in class org.elasticsearch.action.bulk.BulkAction
- newResponse() - Method in class org.elasticsearch.action.delete.DeleteAction
- newResponse() - Method in class org.elasticsearch.action.explain.ExplainAction
- newResponse() - Method in class org.elasticsearch.action.explain.TransportExplainAction
- newResponse() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesAction
- newResponse() - Method in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesIndexAction
- newResponse() - Method in class org.elasticsearch.action.GenericAction
-
Deprecated.Implement
GenericAction.getResponseReader()
instead and make this method throw anUnsupportedOperationException
- newResponse() - Method in class org.elasticsearch.action.get.GetAction
- newResponse() - Method in class org.elasticsearch.action.get.MultiGetAction
- newResponse() - Method in class org.elasticsearch.action.get.TransportGetAction
- newResponse() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- newResponse() - Method in class org.elasticsearch.action.index.IndexAction
- newResponse() - Method in class org.elasticsearch.action.ingest.DeletePipelineAction
- newResponse() - Method in class org.elasticsearch.action.ingest.DeletePipelineTransportAction
- newResponse() - Method in class org.elasticsearch.action.ingest.GetPipelineAction
- newResponse() - Method in class org.elasticsearch.action.ingest.GetPipelineTransportAction
- newResponse() - Method in class org.elasticsearch.action.ingest.PutPipelineAction
- newResponse() - Method in class org.elasticsearch.action.ingest.PutPipelineTransportAction
- newResponse() - Method in class org.elasticsearch.action.ingest.SimulatePipelineAction
- newResponse() - Method in class org.elasticsearch.action.main.MainAction
- newResponse() - Method in class org.elasticsearch.action.search.ClearScrollAction
- newResponse() - Method in class org.elasticsearch.action.search.MultiSearchAction
- newResponse() - Method in class org.elasticsearch.action.search.SearchAction
- newResponse() - Method in class org.elasticsearch.action.search.SearchScrollAction
- newResponse() - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
-
Deprecated.new implementors should override
TransportMasterNodeAction.read(StreamInput)
and use theWriteable.Reader
interface. - newResponse() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- newResponse() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- newResponse() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsAction
- newResponse() - Method in class org.elasticsearch.action.termvectors.TermVectorsAction
- newResponse() - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- newResponse() - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- newResponse() - Method in class org.elasticsearch.action.update.TransportUpdateAction
- newResponse() - Method in class org.elasticsearch.action.update.UpdateAction
- newResponse() - Method in class org.elasticsearch.index.reindex.DeleteByQueryAction
- newResponse() - Method in class org.elasticsearch.index.reindex.ReindexAction
- newResponse() - Method in class org.elasticsearch.index.reindex.UpdateByQueryAction
- newResponse() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Add
- newResponse() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove
- newResponse() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew
- newResponse() - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction
- newResponse() - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.TransportAction
- newResponse() - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction
- newResponse() - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.TransportAction
- newResponse() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction
- newResponse() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.TransportAction
- newResponse() - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction
- newResponse() - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.TransportAction
- newResponse(boolean) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- newResponse(int, int, int, List<DefaultShardOperationFailedException>) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
- newResponse(int, int, int, List<DefaultShardOperationFailedException>) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
- newResponse(int, int, int, List<DefaultShardOperationFailedException>) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- newResponse(NodesRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
Map the responses into
nodeResponseClass
responses andFailedNodeException
s. - newResponse(NodesRequest, List<NodeResponse>, List<FailedNodeException>) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
Create a new
TransportNodesAction
(multi-node response). - newResponse(NodesHotThreadsRequest, List<NodeHotThreads>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- newResponse(NodesInfoRequest, List<NodeInfo>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- newResponse(NodesReloadSecureSettingsRequest, List<NodesReloadSecureSettingsResponse.NodeResponse>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- newResponse(NodesStatsRequest, List<NodeStats>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- newResponse(CancelTasksRequest, List<TaskInfo>, List<TaskOperationFailure>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- newResponse(ListTasksRequest, List<TaskInfo>, List<TaskOperationFailure>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- newResponse(NodesUsageRequest, List<NodeUsage>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- newResponse(TransportNodesSnapshotsStatus.Request, List<TransportNodesSnapshotsStatus.NodeSnapshotStatus>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- newResponse(ClusterStatsRequest, List<ClusterStatsNodeResponse>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- newResponse(ClearIndicesCacheRequest, int, int, int, List<TransportBroadcastByNodeAction.EmptyResult>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- newResponse(ForceMergeRequest, int, int, int, List<TransportBroadcastByNodeAction.EmptyResult>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- newResponse(RecoveryRequest, int, int, int, List<RecoveryState>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- newResponse(IndicesSegmentsRequest, int, int, int, List<ShardSegments>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- newResponse(IndicesStatsRequest, int, int, int, List<ShardStats>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- newResponse(UpgradeStatusRequest, int, int, int, List<ShardUpgradeStatus>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- newResponse(UpgradeRequest, int, int, int, List<ShardUpgradeResult>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- newResponse(ValidateQueryRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- newResponse(TransportNodesListGatewayMetaState.Request, List<TransportNodesListGatewayMetaState.NodeGatewayMetaState>, List<FailedNodeException>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- newResponse(TransportNodesListGatewayStartedShards.Request, List<TransportNodesListGatewayStartedShards.NodeGatewayStartedShards>, List<FailedNodeException>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- newResponse(TransportNodesListShardStoreMetaData.Request, List<TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData>, List<FailedNodeException>) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
- newResponse(Request, int, int, int, List<ShardOperationResult>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Creates a new response to the underlying request.
- newResponse(Request, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- newResponse(TasksRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- newResponse(TasksRequest, List<TaskResponse>, List<TaskOperationFailure>, List<FailedNodeException>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- newResponseInstance() - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- newResponseInstance() - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- newResponseInstance() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- newResponseInstance() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- newResponseInstance() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
-
Deprecated.
- newResponseInstance() - Method in class org.elasticsearch.action.index.TransportIndexAction
-
Deprecated.
- newResponseInstance() - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- newResponseInstance() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- newResponseInstance() - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- newResponseInstance() - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- newResponseInstance() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- newRestorableContext(boolean) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns a supplier that gathers a
ThreadContext.newStoredContext(boolean)
and restores it once the returned supplier is invoked. - newScaling(String, int, int, long, TimeUnit, ThreadFactory, ThreadContext) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- newScorer(IndexReader, Terms, String, double, BytesRef) - Method in interface org.elasticsearch.search.suggest.phrase.WordScorer.WordScorerFactory
- newSearcher(IndexReader, IndexReader) - Method in class org.elasticsearch.index.engine.EngineSearcherFactory
- newSearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase, ResponseCollectorService) - Method in class org.elasticsearch.node.Node
-
Creates a new the SearchService.
- newSetBinder(Binder, Class<T>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound with no binding annotation. - newSetBinder(Binder, Class<T>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound withannotation
. - newSetBinder(Binder, Class<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound withannotationType
. - newSetBinder(Binder, TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound with no binding annotation. - newSetBinder(Binder, TypeLiteral<T>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound withannotation
. - newSetBinder(Binder, TypeLiteral<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound withannotationType
. - newShardRequest(int, ShardRouting, ValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- newShardRequest(int, ShardRouting, Request) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- newShardRequest(FlushRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
- newShardRequest(RefreshRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
- newShardRequest(Request, ShardId) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- newShardResponse() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
- newShardResponse() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
- newShardResponse() - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- newShardResponse() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- newShardResponse() - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- newSinglePrioritizing(String, ThreadFactory, ThreadContext, ScheduledExecutorService) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- newSingletonArrayList(E) - Static method in class org.elasticsearch.common.util.CollectionUtils
- newSnapshot() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- newSnapshot() - Method in class org.elasticsearch.index.translog.Translog
-
Snapshots the current transaction log allowing to safely iterate over the snapshot.
- newSnapshot() - Method in class org.elasticsearch.index.translog.TranslogWriter
- newSnapshotFromGen(Translog.TranslogGeneration, long) - Method in class org.elasticsearch.index.translog.Translog
- newSnapshotFromMinSeqNo(long) - Method in class org.elasticsearch.index.translog.Translog
- newSoftDeletesField() - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns a numeric docvalues which can be used to soft-delete documents.
- newStoredContext(boolean) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Just like
ThreadContext.stashContext()
but no default context is set. - newTargetRelocation(AllocationId) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id for the target initializing shard that is the result of a relocation.
- newTaskFor(Runnable, T) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- newTaskFor(Callable<T>) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- newTermExtractor(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.CustomQueryScorer
- newTermQuery(Term) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- newTermQuery(Term) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newTransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Method in class org.elasticsearch.node.Node
- newUnassigned(ShardId, boolean, RecoverySource, UnassignedInfo) - Static method in class org.elasticsearch.cluster.routing.ShardRouting
-
Creates a new unassigned shard.
- newUnmappedFieldQuery(String) - Static method in class org.elasticsearch.common.lucene.search.Queries
- newUnmappedFieldsQuery(Collection<String>) - Static method in class org.elasticsearch.common.lucene.search.Queries
- newWrapper(IndexService) - Method in interface org.elasticsearch.index.IndexModule.IndexSearcherWrapperFactory
-
Returns a new IndexSearcherWrapper.
- newWriteableReader(Supplier<T>) - Static method in interface org.elasticsearch.common.io.stream.Streamable
- newXContentBuilder(XContentType, OutputStream) - Method in class org.elasticsearch.gateway.MetaDataStateFormat
- newZenPing(Settings, ThreadPool, TransportService, UnicastHostsProvider) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- next() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- next() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
- next() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- next() - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Proxy to the original next() call, but estimates the overhead of loading the next term.
- next() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
-
Returns the next operation in the snapshot or
null
if we reached the end. - next() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks.Iter
- next() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles.Iter
- next() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks.Iter
- next() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles.Iter
- next() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket.Iter
- next(int) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Returns the next value in the series, according to the underlying smoothing model
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- next(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
-
Calculate a Holt-Linear (doubly exponential weighted) moving average
- next(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
-
Calculate a doubly exponential weighted moving average
- NEXT_DOC - org.elasticsearch.search.profile.query.QueryTimingType
- nextDoc() - Method in class org.apache.lucene.search.XFilteredDocIdSetIterator
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- nextDown(Object) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- nextKey(Number) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.HistogramFactory
-
Given a key returned by
HistogramFactory.getKey(org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket)
, compute the lowest key that is greater than it. - nextKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- nextKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- nextKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- nextLevel(ObjectMapper) - Method in class org.elasticsearch.index.query.support.NestedScope
-
Sets the new current nested level and pushes old current nested level down the stack returns that level.
- nextOrdinal() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Advances the
OrdinalsBuilder
to the next ordinal and return the current ordinal. - nextOrNull() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- nextOrNull() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
Returns the next shard, or
null
if none available. - nextPossibleMasters(ObjectContainer<DiscoveryNode>, int) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
-
Returns a list of the next possible masters.
- nextRoundingValue(long) - Method in class org.elasticsearch.common.rounding.Rounding
-
Given the rounded value (which was potentially generated by
Rounding.round(long)
, returns the next rounding value. - nextSeed() - Method in class org.elasticsearch.cluster.routing.RotationShardShuffler
- nextSeed() - Method in class org.elasticsearch.cluster.routing.ShardShuffler
-
Return a new seed.
- nextToken() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- nextUp(Object) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- nextValue() - Method in class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Return the next value associated with the current document.
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Iterates to the next value in the current document.
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Iterates to the next value in the current document.
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
- NGRAM - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
String distance algorithm based on character n-grams.
- NIOFS - org.elasticsearch.index.IndexModule.Type
- no(UnassignedInfo.AllocationStatus, List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns a NO decision with the given
UnassignedInfo.AllocationStatus
, and the individual node-level decisions that comprised the final NO decision if in explain mode. - no(UnassignedInfo.AllocationStatus, List<NodeAllocationResult>, boolean) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns a NO decision with the given
UnassignedInfo.AllocationStatus
, and the individual node-level decisions that comprised the final NO decision if in explain mode. - NO - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The shard cannot be allocated, which can happen for any number of reasons, including the allocation deciders gave a NO decision for allocating.
- NO - org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- NO - org.elasticsearch.persistent.decider.AssignmentDecision.Type
- NO - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- NO - Static variable in class org.elasticsearch.index.mapper.ObjectMapper.Nested
- NO_ATTEMPT - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
No attempt was made to allocate the shard
- NO_ATTEMPT - org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
No allocation attempt has been made yet
- NO_CONTENT - org.elasticsearch.rest.RestStatus
-
The server has fulfilled the request but does not need to return an entity-body, and might want to return updated meta information.
- NO_FOLDER_FOUND - org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
- NO_INGEST_TOOK - Static variable in class org.elasticsearch.action.bulk.BulkResponse
- NO_LOCAL_STORAGE - org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
- NO_LONGER_ASSIGNED - org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
Shard of this index were previously assigned to this node but all shards have been relocated.
- NO_MASTER_BLOCK_ALL - Static variable in class org.elasticsearch.discovery.DiscoverySettings
- NO_MASTER_BLOCK_ID - Static variable in class org.elasticsearch.discovery.DiscoverySettings
- NO_MASTER_BLOCK_SETTING - Static variable in class org.elasticsearch.discovery.DiscoverySettings
- NO_MASTER_BLOCK_WRITES - Static variable in class org.elasticsearch.discovery.DiscoverySettings
- NO_MATCH_SIZE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- NO_NODE_FOUND - Static variable in class org.elasticsearch.persistent.PersistentTasksExecutor
- NO_OP - org.elasticsearch.index.engine.Engine.Operation.TYPE
- NO_OP - org.elasticsearch.index.translog.Translog.Operation.Type
- NO_OP_COLLECTOR - Static variable in class org.elasticsearch.search.aggregations.BucketCollector
- NO_OP_COLLECTOR - Static variable in class org.elasticsearch.search.aggregations.LeafBucketCollector
- NO_OPS_PERFORMED - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
-
Represents no operations have been performed on the shard.
- NO_SCOPE - Static variable in class org.elasticsearch.common.inject.Scopes
-
No scope; the same as not applying any scope at all.
- NO_TIMEOUT - Static variable in class org.elasticsearch.search.SearchService
- NO_VALID_SHARD_COPY - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The shard was denied allocation because there were no valid shard copies found for it amongst the nodes in the cluster.
- NO_VALID_SHARD_COPY - org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
The shard was denied allocation to a node because there were no valid shard copies found for it; this can happen on node restart with gateway allocation
- NO_VALUES - Static variable in class org.elasticsearch.index.fielddata.ordinals.Ordinals
- NO_WAIT - Static variable in interface org.elasticsearch.index.IndexWarmer.TerminationHandle
- noBackoff() - Static method in class org.elasticsearch.action.bulk.BackoffPolicy
-
Creates a backoff policy that will not allow any backoff, i.e.
- NoClassSettingsException - Exception in org.elasticsearch.common.settings
-
A specific type of
SettingsException
indicating failure to load a class based on a settings value. - NoClassSettingsException(String, Throwable) - Constructor for exception org.elasticsearch.common.settings.NoClassSettingsException
- NoClassSettingsException(StreamInput) - Constructor for exception org.elasticsearch.common.settings.NoClassSettingsException
- node - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- node - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- node() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Get the id of the node
- node() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
Get the id of the node that manages the shard which allocation should be canceled
- node() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Returns the nodes
DiscoveryNode
. - node() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.NodeRemovalClusterStateTaskExecutor.Task
- node() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
the node which this ping describes
- node() - Method in exception org.elasticsearch.transport.ConnectTransportException
- node(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- Node - Class in org.elasticsearch.node
-
A node represent a node within a cluster (
cluster.name
). - Node(Settings) - Constructor for class org.elasticsearch.node.Node
-
Constructs a node with the given settings.
- Node(Environment) - Constructor for class org.elasticsearch.node.Node
- Node(Environment, Collection<Class<? extends Plugin>>, boolean) - Constructor for class org.elasticsearch.node.Node
-
Constructs a node
- NODE_ATTRIBUTES - Static variable in class org.elasticsearch.node.Node
- NODE_DATA_SETTING - Static variable in class org.elasticsearch.node.Node
- NODE_FAILURES - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- NODE_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- NODE_ID_SEED_SETTING - Static variable in class org.elasticsearch.env.NodeEnvironment
-
Seed for determining a persisted unique uuid of this node.
- NODE_INGEST_SETTING - Static variable in class org.elasticsearch.node.Node
- NODE_LEFT - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of the node hosting it leaving the cluster.
- NODE_LOCAL_STORAGE_SETTING - Static variable in class org.elasticsearch.node.Node
-
controls whether the node is allowed to persist things like metadata to disk Note that this does not control whether the node stores actual indices (see
Node.NODE_DATA_SETTING
). - NODE_LOCK_FILENAME - Static variable in class org.elasticsearch.env.NodeEnvironment
- NODE_MASTER_SETTING - Static variable in class org.elasticsearch.node.Node
- NODE_NAME_SETTING - Static variable in class org.elasticsearch.node.Node
- NODE_STORE_ALLOW_MMAP - Static variable in class org.elasticsearch.index.IndexModule
- NODE_STORE_ALLOW_MMAPFS - Static variable in class org.elasticsearch.index.IndexModule
- NodeAllocationResult - Class in org.elasticsearch.cluster.routing.allocation
-
This class represents the shard allocation decision and its explanation for a single node.
- NodeAllocationResult(DiscoveryNode, AllocationDecision, Decision, int) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- NodeAllocationResult(DiscoveryNode, Decision, int) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- NodeAllocationResult(DiscoveryNode, NodeAllocationResult.ShardStoreInfo, Decision) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- NodeAllocationResult(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- NodeAllocationResult.ShardStoreInfo - Class in org.elasticsearch.cluster.routing.allocation
-
A class that captures metadata about a shard store on a node.
- nodeBooleanValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeBooleanValue(Object, boolean) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeBooleanValue(Object, String) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeBooleanValue(Object, String, boolean) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeBooleanValue(String, String, Object, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- nodeBooleanValueLenient(String, String, Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- nodeByteValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeByteValue(Object, byte) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeClient - Class in org.elasticsearch.client.node
-
Client that executes actions on the local node.
- NodeClient(Settings, ThreadPool) - Constructor for class org.elasticsearch.client.node.NodeClient
- NodeClosedException - Exception in org.elasticsearch.node
-
An exception indicating that node is closed.
- NodeClosedException(DiscoveryNode) - Constructor for exception org.elasticsearch.node.NodeClosedException
- NodeClosedException(StreamInput) - Constructor for exception org.elasticsearch.node.NodeClosedException
- nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.ConnectionManager
-
Returns
true
if the node is connected. - nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
-
Returns
true
iff the given node is already connected. - NodeConnectionsService - Class in org.elasticsearch.cluster
-
This component is responsible for connecting to nodes once they are added to the cluster state, and disconnect when they are removed.
- NodeConnectionsService(Settings, ThreadPool, TransportService) - Constructor for class org.elasticsearch.cluster.NodeConnectionsService
- nodeDataPaths() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns an array of all of the nodes data locations.
- nodeDecisions - Variable in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- nodeDecisionsToXContent(List<NodeAllocationResult>, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Generates X-Content for the node-level decisions, creating the outer "node_decisions" object in which they are serialized.
- NodeDisconnectedException - Exception in org.elasticsearch.transport
- NodeDisconnectedException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.NodeDisconnectedException
- NodeDisconnectedException(StreamInput) - Constructor for exception org.elasticsearch.transport.NodeDisconnectedException
- nodeDoubleValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeDoubleValue(Object, double) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeEnvironment - Class in org.elasticsearch.env
-
A component that holds all data paths for a single node.
- NodeEnvironment(Settings, Environment, Consumer<String>) - Constructor for class org.elasticsearch.env.NodeEnvironment
-
Setup the environment.
- NodeEnvironment.NodeLock - Class in org.elasticsearch.env
- NodeEnvironment.NodePath - Class in org.elasticsearch.env
- NodeEnvironment.ShardLocker - Interface in org.elasticsearch.env
-
A functional interface that people can use to reference
NodeEnvironment.shardLock(ShardId, long)
- nodeExists(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Determine if a given node id exists
- nodeExists(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Determine if a given node exists
- nodeFloatValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeFloatValue(Object, float) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeGatewayMetaState(DiscoveryNode, MetaData) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeGatewayMetaState
- NodeGatewayStartedShards() - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- NodeGatewayStartedShards(DiscoveryNode, String, boolean) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- NodeGatewayStartedShards(DiscoveryNode, String, boolean, Exception) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- NodeHotThreads - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodeHotThreads(DiscoveryNode, String) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- nodeId - Variable in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- nodeId() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
- nodeId() - Method in exception org.elasticsearch.action.FailedNodeException
- nodeId() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- nodeId() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- nodeId() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Returns node id of the node where shared is getting restored
- nodeId() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Get the id of this node
- nodeId() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- nodeId() - Method in class org.elasticsearch.env.NodeEnvironment
-
returns the unique uuid describing this node.
- nodeId() - Method in class org.elasticsearch.env.NodeMetaData
- nodeId() - Method in class org.elasticsearch.repositories.VerificationFailure
- nodeId() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
Returns node id where failure occurred
- NodeIndicesStats - Class in org.elasticsearch.indices
-
Global information on indices stats running on a specific node.
- NodeIndicesStats(CommonStats, Map<Index, List<IndexShardStats>>) - Constructor for class org.elasticsearch.indices.NodeIndicesStats
- nodeInfo() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- NodeInfo - Class in org.elasticsearch.action.admin.cluster.node.info
-
Node information (static, does not change over time).
- NodeInfo() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- NodeInfo(Version, Build, DiscoveryNode, Settings, OsInfo, ProcessInfo, JvmInfo, ThreadPoolInfo, TransportInfo, HttpInfo, PluginsAndModules, IngestInfo, ByteSizeValue) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- NodeInfoRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest
- NodeInfoRequest(String, NodesInfoRequest) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest
- nodeIntegerValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeIntegerValue(Object, int) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeInterleavedShardIterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Creates an iterator over shards interleaving between nodes: The iterator returns the first shard from the first node, then the first shard of the second node, etc.
- NodeJoinController - Class in org.elasticsearch.discovery.zen
-
This class processes incoming join request (passed zia
ZenDiscovery
). - NodeJoinController(Settings, MasterService, AllocationService, ElectMasterService) - Constructor for class org.elasticsearch.discovery.zen.NodeJoinController
- NodeJoinController.ElectionCallback - Interface in org.elasticsearch.discovery.zen
- NodeJoinController.JoinTaskExecutor - Class in org.elasticsearch.discovery.zen
- NodeLock(int, Logger, Environment, CheckedFunction<Path, Boolean, IOException>) - Constructor for class org.elasticsearch.env.NodeEnvironment.NodeLock
-
Tries to acquire a node lock for a node id, throws
IOException
if it is unable to acquire it - nodeLongValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeLongValue(Object, long) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeMappingRefresh(DiscoveryNode, NodeMappingRefreshAction.NodeMappingRefreshRequest) - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
- NodeMappingRefreshAction - Class in org.elasticsearch.cluster.action.index
- NodeMappingRefreshAction(TransportService, MetaDataMappingService) - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
- NodeMappingRefreshAction.NodeMappingRefreshRequest - Class in org.elasticsearch.cluster.action.index
- NodeMappingRefreshRequest() - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- NodeMappingRefreshRequest(String, String, String) - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- nodeMapValue(Object, String) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeMetaData - Class in org.elasticsearch.env
-
Metadata associated with this node.
- NodeMetaData(String) - Constructor for class org.elasticsearch.env.NodeMetaData
- nodeName() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- NodeNamePatternConverter - Class in org.elasticsearch.common.logging
-
Converts
%node_name
in log4j patterns into the current node name. - NodeNotConnectedException - Exception in org.elasticsearch.transport
-
An exception indicating that a message is sent to a node that is not connected.
- NodeNotConnectedException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.NodeNotConnectedException
- NodeNotConnectedException(StreamInput) - Constructor for exception org.elasticsearch.transport.NodeNotConnectedException
- nodeOperation(NodeRequest) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- nodeOperation(NodeRequest, Task) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- nodeOperation(TransportNodesHotThreadsAction.NodeRequest) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- nodeOperation(TransportNodesInfoAction.NodeInfoRequest) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- nodeOperation(TransportNodesReloadSecureSettingsAction.NodeRequest) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- nodeOperation(TransportNodesStatsAction.NodeStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- nodeOperation(TransportNodesUsageAction.NodeUsageRequest) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- nodeOperation(TransportNodesSnapshotsStatus.NodeRequest) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- nodeOperation(TransportClusterStatsAction.ClusterStatsNodeRequest) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- nodeOperation(TransportNodesListGatewayMetaState.NodeRequest) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- nodeOperation(TransportNodesListGatewayStartedShards.NodeRequest) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- nodeOperation(TransportNodesListShardStoreMetaData.NodeRequest) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
- nodeOperation(AllocatedPersistentTask, Params, PersistentTaskState) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
This operation will be executed on the executor node.
- NodePath(Path) - Constructor for class org.elasticsearch.env.NodeEnvironment.NodePath
- nodePaths() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns an array of all of the
NodeEnvironment.NodePath
s. - NodePersistentTasksExecutor - Class in org.elasticsearch.persistent
-
This component is responsible for execution of persistent tasks.
- nodeQueueSize() - Method in class org.elasticsearch.search.query.QuerySearchResult
- nodeQueueSize(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
- NodeRemovalClusterStateTaskExecutor(AllocationService, ElectMasterService, Consumer<String>, Logger) - Constructor for class org.elasticsearch.discovery.zen.ZenDiscovery.NodeRemovalClusterStateTaskExecutor
- NodeRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction.NodeRequest
- NodeRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction.NodeRequest
- NodeRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeRequest
- NodeRequest() - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- NodeRequest() - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeRequest
- NodeRequest() - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- NodeRequest() - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeRequest
- NodeRequest(String, TransportNodesListGatewayStartedShards.Request) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- NodeRequest(String, Request, List<ShardRouting>) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- nodeRequiresLocalStorage(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- NodeResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- NodeResponse(DiscoveryNode, Exception) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- nodeResponseClass - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
- nodes() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- nodes() - Method in class org.elasticsearch.cluster.ClusterState.Builder
- nodes() - Method in class org.elasticsearch.cluster.ClusterState
- nodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get discovery nodes in current routing
- nodes() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
- nodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- nodes(DiscoveryNodes) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- nodes(DiscoveryNodes.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- NODES - org.elasticsearch.cluster.ClusterState.Metric
- NODES_FOLDER - Static variable in class org.elasticsearch.env.NodeEnvironment
- nodesAdded() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff nodes have been added from the cluster since the last cluster state. - nodesChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff nodes have been changed (added or removed) from the cluster since the last cluster state. - NodeScope - org.elasticsearch.common.settings.Setting.Property
-
Node scope
- nodesDelta() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns the
DiscoveryNodes.Delta
between the previous cluster state and the new cluster state. - NodeService - Class in org.elasticsearch.node
- NodesFaultDetection - Class in org.elasticsearch.discovery.zen
-
A fault detection of multiple nodes.
- NodesFaultDetection(Settings, ThreadPool, TransportService, Supplier<ClusterState>, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection
- NodesFaultDetection.Listener - Class in org.elasticsearch.discovery.zen
- NodesFaultDetection.PingRequest - Class in org.elasticsearch.discovery.zen
- NodesGatewayMetaState(ClusterName, List<TransportNodesListGatewayMetaState.NodeGatewayMetaState>, List<FailedNodeException>) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodesGatewayMetaState
- NodesGatewayStartedShards(ClusterName, List<TransportNodesListGatewayStartedShards.NodeGatewayStartedShards>, List<FailedNodeException>) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodesGatewayStartedShards
- nodeShortValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeShortValue(Object, short) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodesHotThreads(NodesHotThreadsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns top N hot-threads samples per node.
- nodesHotThreads(NodesHotThreadsRequest, ActionListener<NodesHotThreadsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns top N hot-threads samples per node.
- NodesHotThreadsAction - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodesHotThreadsRequest - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodesHotThreadsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- NodesHotThreadsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
-
Get hot threads from nodes based on the nodes ids specified.
- NodesHotThreadsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodesHotThreadsRequestBuilder(ElasticsearchClient, NodesHotThreadsAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- NodesHotThreadsResponse - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodesHotThreadsResponse(ClusterName, List<NodeHotThreads>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
- NodeShouldNotConnectException - Exception in org.elasticsearch.transport
- NodeShouldNotConnectException(DiscoveryNode, DiscoveryNode) - Constructor for exception org.elasticsearch.transport.NodeShouldNotConnectException
- NodeShouldNotConnectException(StreamInput) - Constructor for exception org.elasticsearch.transport.NodeShouldNotConnectException
- nodesIds() - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- nodesIds(String...) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- nodesInfo(NodesInfoRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes info of the cluster.
- nodesInfo(NodesInfoRequest, ActionListener<NodesInfoResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes info of the cluster.
- NodesInfoAction - Class in org.elasticsearch.action.admin.cluster.node.info
- nodesInfoRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes info request against all the nodes.
- nodesInfoRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes info request against one or more nodes.
- NodesInfoRequest - Class in org.elasticsearch.action.admin.cluster.node.info
-
A request to get node (cluster) level information.
- NodesInfoRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
- NodesInfoRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Get information from nodes based on the nodes ids specified.
- NodesInfoRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.info
- NodesInfoRequestBuilder(ElasticsearchClient, NodesInfoAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
- NodesInfoResponse - Class in org.elasticsearch.action.admin.cluster.node.info
- NodesInfoResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- NodesInfoResponse(ClusterName, List<NodeInfo>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- NodeSnapshotStatus(DiscoveryNode, Map<Snapshot, Map<ShardId, SnapshotIndexShardStatus>>) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
- NodesOperationRequestBuilder<Request extends BaseNodesRequest<Request>,Response extends BaseNodesResponse,RequestBuilder extends NodesOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.nodes
- NodesOperationRequestBuilder(ElasticsearchClient, Action<Request, Response, RequestBuilder>, Request) - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
- nodesPerAttributesCounts(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- NodesReloadSecureSettingsAction - Class in org.elasticsearch.action.admin.cluster.node.reload
- NodesReloadSecureSettingsRequest - Class in org.elasticsearch.action.admin.cluster.node.reload
-
Request for a reload secure settings action.
- NodesReloadSecureSettingsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
- NodesReloadSecureSettingsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
-
Reload secure settings only on certain nodes, based on the nodes IDs specified.
- NodesReloadSecureSettingsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.reload
-
Builder for the reload secure settings nodes request
- NodesReloadSecureSettingsRequestBuilder(ElasticsearchClient, NodesReloadSecureSettingsAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequestBuilder
- NodesReloadSecureSettingsResponse - Class in org.elasticsearch.action.admin.cluster.node.reload
-
The response for the reload secure settings action
- NodesReloadSecureSettingsResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- NodesReloadSecureSettingsResponse(ClusterName, List<NodesReloadSecureSettingsResponse.NodeResponse>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- NodesReloadSecureSettingsResponse.NodeResponse - Class in org.elasticsearch.action.admin.cluster.node.reload
- nodesRemoved() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff nodes have been removed from the cluster since the last cluster state. - nodesResponse(XContentBuilder, ToXContent.Params, NodesResponse) - Static method in class org.elasticsearch.rest.action.RestActions
- NodesResponseRestListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestActions.NodesResponseRestListener
- NodesSnapshotStatus(ClusterName, List<TransportNodesSnapshotsStatus.NodeSnapshotStatus>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
- nodesStats(NodesStatsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes stats of the cluster.
- nodesStats(NodesStatsRequest, ActionListener<NodesStatsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes stats of the cluster.
- NodesStatsAction - Class in org.elasticsearch.action.admin.cluster.node.stats
- nodesStatsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes stats request against one or more nodes.
- NodesStatsRequest - Class in org.elasticsearch.action.admin.cluster.node.stats
-
A request to get node (cluster) level stats.
- NodesStatsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- NodesStatsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Get stats from nodes based on the nodes ids specified.
- NodesStatsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.stats
- NodesStatsRequestBuilder(ElasticsearchClient, NodesStatsAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
- NodesStatsResponse - Class in org.elasticsearch.action.admin.cluster.node.stats
- NodesStatsResponse(ClusterName, List<NodeStats>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- NodesStoreFilesMetaData(ClusterName, List<TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData>, List<FailedNodeException>) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
- nodeStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- NodeStats - Class in org.elasticsearch.action.admin.cluster.node.stats
-
Node statistics (dynamic, changes depending on when created).
- NodeStats(DiscoveryNode, long, NodeIndicesStats, OsStats, ProcessStats, JvmStats, ThreadPoolStats, FsInfo, TransportStats, HttpStats, AllCircuitBreakerStats, ScriptStats, DiscoveryStats, IngestStats, AdaptiveSelectionStats) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- NodeStatsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction.NodeStatsRequest
- NodeStoreFilesMetaData(DiscoveryNode, TransportNodesListShardStoreMetaData.StoreFilesMetaData) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
- nodeStringArrayValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
Returns an array of string value from a node value.
- nodeStringValue(Object, String) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodesUsage(NodesUsageRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns top N hot-threads samples per node.
- nodesUsage(NodesUsageRequest, ActionListener<NodesUsageResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes usage of the cluster.
- NodesUsageAction - Class in org.elasticsearch.action.admin.cluster.node.usage
- NodesUsageAction() - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageAction
- nodesUsageRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes usage request against one or more nodes.
- NodesUsageRequest - Class in org.elasticsearch.action.admin.cluster.node.usage
- NodesUsageRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
- NodesUsageRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Get usage from nodes based on the nodes ids specified.
- NodesUsageRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.usage
- NodesUsageRequestBuilder(ElasticsearchClient, Action<NodesUsageRequest, NodesUsageResponse, NodesUsageRequestBuilder>) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequestBuilder
- NodesUsageResponse - Class in org.elasticsearch.action.admin.cluster.node.usage
-
The response for the nodes usage api which contains the individual usage statistics for all nodes queried.
- NodesUsageResponse(ClusterName, List<NodeUsage>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- nodeTimeValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeTimeValue(Object, TimeValue) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeUsage - Class in org.elasticsearch.action.admin.cluster.node.usage
- NodeUsage(DiscoveryNode, long, long, Map<String, Long>) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- NodeUsageRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction.NodeUsageRequest
- NodeValidationException - Exception in org.elasticsearch.node
-
An exception thrown during node validation.
- NodeValidationException(String) - Constructor for exception org.elasticsearch.node.NodeValidationException
-
Creates a node validation exception with the specified validation message to be displayed to the user.
- NodeVersionAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that prevents relocation or allocation from nodes that might not be version compatible.
- NodeVersionAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.NodeVersionAllocationDecider
- NodeView(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- NodeView(String, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- NodeView(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- NoisyChannelSpellChecker - Class in org.elasticsearch.search.suggest.phrase
- NoisyChannelSpellChecker() - Constructor for class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
- NoisyChannelSpellChecker(double) - Constructor for class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
- NoisyChannelSpellChecker(double, boolean, int) - Constructor for class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
- NoisyChannelSpellChecker.Result - Class in org.elasticsearch.search.suggest.phrase
- NoLongerPrimaryShardException(StreamInput) - Constructor for exception org.elasticsearch.cluster.action.shard.ShardStateAction.NoLongerPrimaryShardException
- NoLongerPrimaryShardException(ShardId, String) - Constructor for exception org.elasticsearch.cluster.action.shard.ShardStateAction.NoLongerPrimaryShardException
- noMatchSize - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- noMatchSize() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- noMatchSize() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- noMatchSize(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Sets the size of the fragment to return from the beginning of the field if there are no matches to highlight and the field doesn't also define noMatchSize.
- NON_AUTHORITATIVE_INFORMATION - org.elasticsearch.rest.RestStatus
-
The returned meta information in the entity-header is not the definitive set as available from the origin server, but is gathered from a local or a third-party copy.
- NON_RECYCLING_INSTANCE - Static variable in class org.elasticsearch.common.util.BigArrays
- NON_RECYCLING_INSTANCE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- nonAggregatableIndices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The list of indices where this field is not aggregatable, or null if the field is aggregatable in all indices.
- NonCollectingAggregator - Class in org.elasticsearch.search.aggregations
-
An aggregator that is not collected, this can typically be used when running an aggregation over a field that doesn't have a mapping.
- NonCollectingAggregator(String, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.NonCollectingAggregator
- NonCollectingAggregator(String, SearchContext, Aggregator, AggregatorFactories, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.NonCollectingAggregator
- NonDiffableValueSerializer() - Constructor for class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- none(Recycler.C<T>) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Return a
Recycler
that never recycles entries. - None() - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- NONE - org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Don't refresh after this request.
- NONE - org.elasticsearch.action.ThreadingModel
- NONE - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- NONE - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- NONE - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- NONE - org.elasticsearch.common.util.PageCacheRecycler.Type
- NONE - org.elasticsearch.index.query.RegexpFlag
-
Disables all available option flags
- NONE - org.elasticsearch.index.query.SimpleQueryStringFlag
- NONE - org.elasticsearch.index.search.MatchQuery.ZeroTermsQuery
- NONE - org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- NONE - org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- NONE - Static variable in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- NONE - Static variable in class org.elasticsearch.action.OriginalIndices
- NONE - Static variable in class org.elasticsearch.action.support.ActiveShardCount
- NONE - Static variable in enum org.elasticsearch.action.support.IndicesOptions.Option
- NONE - Static variable in enum org.elasticsearch.action.support.IndicesOptions.WildcardStates
- NoneCircuitBreakerService - Class in org.elasticsearch.indices.breaker
-
Class that returns a breaker that never breaks
- NoneCircuitBreakerService() - Constructor for class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
- NoneRecycler<T> - Class in org.elasticsearch.common.recycler
- NoneRecycler(Recycler.C<T>) - Constructor for class org.elasticsearch.common.recycler.NoneRecycler
- NoneRecycler.NV<T> - Class in org.elasticsearch.common.recycler
- NoNodeAvailableException - Exception in org.elasticsearch.client.transport
-
An exception indicating no node is available to perform the operation.
- NoNodeAvailableException(String) - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
- NoNodeAvailableException(String, Throwable) - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
- NoNodeAvailableException(StreamInput) - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
- nonRootDocuments() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- nonRootDocuments() - Method in class org.elasticsearch.index.mapper.ParseContext
-
Returns an Iterable over all non-root documents.
- nonSearchableIndices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The list of indices where this field is not searchable, or null if the field is searchable in all indices.
- noOp(Engine.NoOp) - Method in class org.elasticsearch.index.engine.Engine
- noOp(Engine.NoOp) - Method in class org.elasticsearch.index.engine.InternalEngine
- noOp(Engine.NoOp) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- NoOp(long, long, String) - Constructor for class org.elasticsearch.index.translog.Translog.NoOp
- NoOp(long, long, Engine.Operation.Origin, long, String) - Constructor for class org.elasticsearch.index.engine.Engine.NoOp
- NOOP - org.elasticsearch.action.bulk.TransportShardBulkAction.ReplicaItemExecutionMode
-
When primary execution failed before sequence no was generated or primary execution was a noop (only possible when request is originating from pre-6.0 nodes)
- NOOP - org.elasticsearch.action.DocWriteResponse.Result
- NOOP - org.elasticsearch.common.breaker.CircuitBreaker.Type
- NOOP_FIELD_FILTER - Static variable in interface org.elasticsearch.plugins.MapperPlugin
-
The default field filter applied, which doesn't filter anything.
- NOOP_FIELD_PREDICATE - Static variable in interface org.elasticsearch.plugins.MapperPlugin
-
The default field predicate applied, which doesn't filter anything.
- NOOP_PIPELINE_NAME - Static variable in class org.elasticsearch.ingest.IngestService
- NOOP_TRANSPORT_INTERCEPTOR - Static variable in class org.elasticsearch.transport.TransportService
- NoopCircuitBreaker - Class in org.elasticsearch.common.breaker
-
A CircuitBreaker that doesn't increment or adjust, and all operations are basically noops
- NoopCircuitBreaker(String) - Constructor for class org.elasticsearch.common.breaker.NoopCircuitBreaker
- NoOpLock() - Constructor for class org.elasticsearch.index.engine.Engine.NoOpLock
- NOOPS_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- noopUpdate(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Should be called for each no-op update operation to increment relevant statistics.
- NORMAL - org.elasticsearch.action.bulk.TransportShardBulkAction.ReplicaItemExecutionMode
-
When primary execution succeeded
- NORMAL - org.elasticsearch.common.Priority
- normalize(String, TokenStream) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- normalizedValue() - Method in interface org.elasticsearch.search.aggregations.pipeline.derivative.Derivative
-
Returns the normalized value.
- normalizedValue() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
- normalizedValue() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.ParsedDerivative
- normalizeLat(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Normalize latitude to lie within the -90 to 90 (both inclusive) range.
- normalizeLon(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Normalize longitude to lie within the -180 (exclusive) to 180 (inclusive) range.
- normalizePoint(double[]) - Static method in class org.elasticsearch.common.geo.GeoUtils
- normalizePoint(double[], boolean, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
- normalizePoint(GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Normalize the geo
Point
for its coordinates to lie within their respective normalized ranges. - normalizePoint(GeoPoint, boolean, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Normalize the geo
Point
for the given coordinates to lie within their respective normalized ranges. - normalizePrefix(String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Checks that all settings in the builder start with the specified prefix.
- normalizer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- normalizer() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- normalizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- normalizer(IndexAnalyzers, String) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- NORMALIZER - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- NoShardAvailableActionException - Exception in org.elasticsearch.action
- NoShardAvailableActionException(StreamInput) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
- NoShardAvailableActionException(ShardId) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
- NoShardAvailableActionException(ShardId, String) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
- NoShardAvailableActionException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
- NoSuchNodeException - Exception in org.elasticsearch.action
- NoSuchNodeException(String) - Constructor for exception org.elasticsearch.action.NoSuchNodeException
- NoSuchNodeException(StreamInput) - Constructor for exception org.elasticsearch.action.NoSuchNodeException
- NoSuchRemoteClusterException - Exception in org.elasticsearch.transport
-
An exception that remote cluster is missing or connectivity to the remote connection is failing
- NoSuchRemoteClusterException(StreamInput) - Constructor for exception org.elasticsearch.transport.NoSuchRemoteClusterException
- not(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
Return a query that matches all documents but those that match the given query.
- not(Matcher<? super T>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Inverts the given matcher.
- NOT - org.elasticsearch.index.query.SimpleQueryStringFlag
- NOT_ACCEPTABLE - org.elasticsearch.rest.RestStatus
-
The resource identified by the request is only capable of generating response entities which have content characteristics not acceptable according to the accept headers sent in the request.
- NOT_EXISTS - Static variable in class org.elasticsearch.index.engine.Engine.GetResult
- NOT_FOUND - org.elasticsearch.action.DocWriteResponse.Result
- NOT_FOUND - org.elasticsearch.rest.RestStatus
-
The server has not found anything matching the Request-URI.
- NOT_FOUND - Static variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- NOT_FOUND - Static variable in class org.elasticsearch.common.lucene.uid.Versions
-
indicates that the current document was not found in lucene and in the version map
- NOT_IMPLEMENTED - org.elasticsearch.rest.RestStatus
-
The server does not support the functionality required to fulfill the request.
- NOT_MODIFIED - org.elasticsearch.rest.RestStatus
-
If the client has performed a conditional GET request and access is allowed, but the document has not been modified, the server SHOULD respond with this status code.
- NOT_TAKEN - Static variable in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
a constant representing a shard decision where no decision was taken
- NOT_TAKEN - Static variable in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
a constant representing no decision taken
- NOT_TAKEN - Static variable in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- notASubtype(Class<?>, Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- NotCompressedException - Exception in org.elasticsearch.common.compress
-
Exception indicating that we were expecting something compressed, which was not compressed or corrupted so that the compression format could not be detected.
- NotCompressedException() - Constructor for exception org.elasticsearch.common.compress.NotCompressedException
- NotCopyableOnResize - org.elasticsearch.common.settings.Setting.Property
-
Mark this setting as not copyable during an index resize (shrink or split).
- notifyListener(RecoveryFailedException, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- notifyNow() - Method in class org.elasticsearch.watcher.ResourceWatcherService
- notifyNow(ResourceWatcherService.Frequency) - Method in class org.elasticsearch.watcher.ResourceWatcherService
- notifyOnce(ActionListener<Response>) - Static method in interface org.elasticsearch.action.ActionListener
-
Wraps a given listener and returns a new listener which makes sure
ActionListener.onResponse(Object)
andActionListener.onFailure(Exception)
of the provided listener will be called at most once. - NotifyOnceListener<Response> - Class in org.elasticsearch.action
-
A listener that ensures that only one of onResponse or onFailure is called.
- NotifyOnceListener() - Constructor for class org.elasticsearch.action.NotifyOnceListener
- NotMasterException - Exception in org.elasticsearch.cluster
-
Thrown when a node join request or a master ping reaches a node which is not currently acting as a master or when a cluster state update task is to be executed on a node that is no longer master.
- NotMasterException(String) - Constructor for exception org.elasticsearch.cluster.NotMasterException
- NotMasterException(StreamInput) - Constructor for exception org.elasticsearch.cluster.NotMasterException
- NotSerializableExceptionWrapper - Exception in org.elasticsearch.common.io.stream
-
This exception can be used to wrap a given, not serializable exception to serialize via
StreamOutput.writeException(Throwable)
. - NotSerializableExceptionWrapper(Throwable) - Constructor for exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- NotSerializableExceptionWrapper(StreamInput) - Constructor for exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- NotSerializableTransportException - Exception in org.elasticsearch.transport
- NotSerializableTransportException(Throwable) - Constructor for exception org.elasticsearch.transport.NotSerializableTransportException
- NotSerializableTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.NotSerializableTransportException
- NotXContentException - Exception in org.elasticsearch.common.compress
-
Exception indicating that we were expecting some
XContent
but could not detect its type. - NotXContentException(String) - Constructor for exception org.elasticsearch.common.compress.NotXContentException
- now() - Method in class org.elasticsearch.common.cache.Cache
-
The relative time used to track time-based evictions.
- NOW - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- nowInMillis - Variable in class org.elasticsearch.index.query.QueryRewriteContext
- nowInMillis() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- nowInMillis() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Returns the time in milliseconds that is shared across all resources involved.
- nowInMillis() - Method in class org.elasticsearch.index.query.QueryShardContext
- nowInMillis() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- nowInMillis() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- nowInMillis() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- NULL - org.elasticsearch.index.search.MatchQuery.ZeroTermsQuery
- NULL - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
- NULL_KEY - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- NULL_SEPARATOR - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils
- NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Names
- NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper.Defaults
- Nullability - Class in org.elasticsearch.common.inject.internal
-
Whether a member supports null values injected.
- nullValue - Variable in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- nullValue() - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- nullValue() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the value that should be added when JSON null is found, or null if no value should be added
- nullValue(Object) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- nullValue(Object) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- nullValueAsString() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the null value stringified, so it can be used for e.g.
- nullValueQuery() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- nullValueQuery() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- nullValueQuery() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- NUM_BUCKETS_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- NUM_PARTITIONS_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- NUMBER - org.elasticsearch.search.aggregations.support.ValueType
- NUMBER - org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
-
script sort for a numeric value
- NUMBER_OF_FRAGMENTS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- NUMBER_OF_SEGMENTS - Static variable in class org.elasticsearch.common.cache.Cache
- NUMBER_SIGNIFICANT_DIGITS_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- NumberFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for numeric types: byte, short, int, long, float and double. - NumberFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- NumberFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- NumberFieldMapper.NumberFieldType - Class in org.elasticsearch.index.mapper
- NumberFieldMapper.NumberType - Enum in org.elasticsearch.index.mapper
- NumberFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- NumberFieldType(NumberFieldMapper.NumberType) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- numberOfActions() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
The number of actions in the bulk request.
- numberOfActions() - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
The number of actions currently in the bulk.
- numberOfFiles() - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- numberOfFragments() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- numberOfNodesShardsAreAllocatedOn(String...) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Calculates the number of nodes that hold one or more shards of this index
IndexRoutingTable
excluding the nodes with the node ids give as theexcludedNodes
parameter. - numberOfOwningShards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
The number of shards on this node that will not be eventually relocated.
- numberOfParts() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns number of parts
- numberOfPendingTasks() - Method in class org.elasticsearch.cluster.service.MasterService
-
Returns the number of currently pending tasks.
- numberOfProcessors(Settings) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Returns the number of available processors.
- numberOfReplicas() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
Returns the number of replicas.
- numberOfReplicas(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- numberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
Returns the number of shards.
- numberOfShards() - Method in class org.elasticsearch.index.IndexService
- numberOfShards() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- numberOfShards() - Method in class org.elasticsearch.search.internal.SearchContext
- numberOfShards() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- numberOfShards() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- numberOfShards() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- numberOfShards(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- numberOfShardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Determine the number of shards with a specific state
- numberOfSignificantValueDigits - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- numberOfSignificantValueDigits() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
-
Expert: get the number of significant digits in the values.
- numberOfSignificantValueDigits() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Expert: get the number of significant digits in the values.
- numberOfSignificantValueDigits(int) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
-
Expert: set the number of significant digits in the values.
- numberOfSignificantValueDigits(int) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Expert: set the number of significant digits in the values.
- Numbers - Class in org.elasticsearch.common
-
A set of utilities for numbers.
- numCollectedDocs - Variable in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
- numCollectedDocs - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
- numCollectedDocs - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
- numCollectedDocs - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregator
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.LineStringBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.MultiPointBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- numDimensions() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
tracks number of dimensions for this shape
- numDimensions() - Method in class org.elasticsearch.common.geo.parsers.CoordinateNode
- numDocs - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- Numeric() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
- NUMERIC - org.elasticsearch.search.aggregations.support.ValuesSourceType
- NUMERIC - org.elasticsearch.search.aggregations.support.ValueType
- NUMERIC_DETECTION - Static variable in class org.elasticsearch.index.mapper.RootObjectMapper.Defaults
- numericDetection - Variable in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- numericDetection() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- NumericDoubleValues - Class in org.elasticsearch.index.fielddata
-
A per-document numeric value.
- NumericDoubleValues() - Constructor for class org.elasticsearch.index.fielddata.NumericDoubleValues
-
Sole constructor.
- NumericMetricsAggregation - Interface in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregation.MultiValue - Interface in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregation.SingleValue - Interface in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregator - Class in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregator.MultiValue - Class in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregator.SingleValue - Class in org.elasticsearch.search.aggregations.metrics
- NumericMultiValuesSource(Map<String, ValuesSourceConfig<ValuesSource.Numeric>>, QueryShardContext) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSource.NumericMultiValuesSource
- numericType(IndexNumericFieldData.NumericType) - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData.Builder
- numericValue() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- numOfFragments - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- numOfFragments() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- numOfFragments(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set the number of fragments, defaults to
HighlightBuilder.DEFAULT_NUMBER_OF_FRAGMENTS
- numPriorUsesInASequence - Variable in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- numReducePhases - Variable in class org.elasticsearch.action.search.SearchResponseSections
- numShapes() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- NXYBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
- NXYParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYParser
- NXYSignificanceHeuristic - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- NXYSignificanceHeuristic(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- NXYSignificanceHeuristic(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
-
Read from a stream.
- NXYSignificanceHeuristic.Frequencies - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- NXYSignificanceHeuristic.NXYBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- NXYSignificanceHeuristic.NXYParser - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
O
- Object() - Constructor for class org.elasticsearch.common.collect.HppcMaps.Object
- OBJECT - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- OBJECT_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- ObjectArray<T> - Interface in org.elasticsearch.common.util
-
Abstraction of an array of object values.
- ObjectMapper - Class in org.elasticsearch.index.mapper
- ObjectMapper.Builder<T extends ObjectMapper.Builder,Y extends ObjectMapper> - Class in org.elasticsearch.index.mapper
- ObjectMapper.Defaults - Class in org.elasticsearch.index.mapper
- ObjectMapper.Dynamic - Enum in org.elasticsearch.index.mapper
- ObjectMapper.Nested - Class in org.elasticsearch.index.mapper
- ObjectMapper.TypeParser - Class in org.elasticsearch.index.mapper
- objectMappers() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- objectPage() - Method in class org.elasticsearch.common.util.PageCacheRecycler
- ObjectParserHelper<Value,Context> - Class in org.elasticsearch.common.xcontent
-
This class provides helpers for
ObjectParser
that allow dealing with classes outside of the xcontent dependencies. - ObjectParserHelper() - Constructor for class org.elasticsearch.common.xcontent.ObjectParserHelper
- obtain() - Method in interface org.elasticsearch.common.recycler.Recycler
- obtain(int) - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- obtain(int) - Method in class org.elasticsearch.common.recycler.DequeRecycler
- obtain(int) - Method in class org.elasticsearch.common.recycler.NoneRecycler
- obtain(int) - Method in interface org.elasticsearch.common.recycler.Recycler
- occur - Variable in class org.elasticsearch.index.search.MatchQuery
- of() - Static method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- of() - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
- of(T) - Static method in class org.elasticsearch.common.inject.util.Providers
-
Returns a provider which always provides
instance
. - OFF - org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
debug mode is off
- offer(E) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- offer(E, long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- offer(T) - Method in class org.elasticsearch.common.collect.EvictingQueue
- offMaster() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
- offMaster() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
-
Called when the local node used to be the master, a new master was elected and it's no longer the local node.
- offset - Variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- offset - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- offset() - Method in class org.elasticsearch.common.bytes.BytesArray
- offset() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Get the offset to use when rounding, which is a number of milliseconds.
- offset() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Get the current offset that is set on this builder.
- offset(double) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set the offset on this builder, and return the builder so that calls can be chained.
- offset(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set the offset on this builder, which is a number of milliseconds, and return the builder so that calls can be chained.
- offset(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set the offset on this builder, as a time value, and return the builder so that calls can be chained.
- OFFSET - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- OFFSET_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- OFFSET_TIME_FORMATTER - Static variable in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- offsetAttr - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- offsets() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- offsets(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the start and stop offsets for each term if they were stored or skip offsets.
- Offsets - org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- OK - org.elasticsearch.rest.RestStatus
-
The request has succeeded.
- OLD - Static variable in class org.elasticsearch.monitor.jvm.GcNames
- OLD_PORT - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_SETTING_HTTP_TCP_NO_DELAY - Static variable in class org.elasticsearch.http.HttpTransportSettings
- OLD_TCP_KEEP_ALIVE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_NO_DELAY - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_NO_DELAY_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_RECEIVE_BUFFER_SIZE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_REUSE_ADDRESS_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_SEND_BUFFER_SIZE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TRANSPORT_COMPRESS - Static variable in class org.elasticsearch.transport.TransportSettings
- omitNorms(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- omitNormsSet - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- ON - org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
debug mode is on
- ON_FAILURE_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- ON_FAILURE_MESSAGE_FIELD - Static variable in class org.elasticsearch.ingest.CompoundProcessor
- ON_FAILURE_PROCESSOR_TAG_FIELD - Static variable in class org.elasticsearch.ingest.CompoundProcessor
- ON_FAILURE_PROCESSOR_TYPE_FIELD - Static variable in class org.elasticsearch.ingest.CompoundProcessor
- onAckTimeout() - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Called once the acknowledgement timeout defined by
AckedClusterStateUpdateTask.ackTimeout()
has expired - onAckTimeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Called once the acknowledgement timeout defined by
AckedClusterStateUpdateTask.ackTimeout()
has expired - onAfter() - Method in class org.elasticsearch.common.util.concurrent.AbstractLifecycleRunnable
-
This method is called in a finally block after successful execution or on a rejection.
- onAfter() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
This method is called in a finally block after successful execution or on a rejection.
- onAfter() - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- onAfterInLifecycle() - Method in class org.elasticsearch.common.util.concurrent.AbstractLifecycleRunnable
-
This method is invoked in the finally block of the run method, but it is only executed if the
AbstractLifecycleRunnable.lifecycle
is not stopped or closed. - onAllNodesAcked(Exception) - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Called once all the nodes have acknowledged the cluster state update request.
- onAllNodesAcked(Exception) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Called once all the nodes have acknowledged the cluster state update request.
- onCache(ShardId, String, Accountable) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache.Listener
-
Called after the fielddata is loaded during the cache phase
- onCache(ShardId, String, Accountable) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
- onCache(ShardId, Accountable) - Method in interface org.elasticsearch.index.cache.bitset.BitsetFilterCache.Listener
-
Called for each cached bitset on the cache event.
- onCached(long) - Method in class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
- onCached(Accountable, BytesReference) - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- onCacheEviction() - Method in class org.elasticsearch.script.ScriptMetrics
- onCancel(String, Exception) - Method in interface org.elasticsearch.common.util.CancellableThreads.OnCancel
-
Called when some running operations are cancelled or
CancellableThreads.checkForCancel()
is explicitly called. - onCancelled() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
- onCancelled() - Method in class org.elasticsearch.tasks.CancellableTask
-
Called after the task is cancelled so that it can take any actions that it has to take.
- onClose() - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
- onClose(IndexReader.CacheKey) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- onClose(ShardId) - Method in class org.elasticsearch.indices.IndicesQueryCache
- onClusterServiceClose() - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
-
called when the cluster service is closed
- onClusterStateCommitted(String, ActionListener<Void>) - Method in interface org.elasticsearch.discovery.zen.PublishClusterStateAction.IncomingClusterStateListener
-
called when a cluster state has been committed and is ready to be processed
- onClusterStateCommitted(String, ActionListener<Void>) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- onCommit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.engine.CombinedDeletionPolicy
- onCommit(TimeValue) - Method in interface org.elasticsearch.discovery.Discovery.AckListener
-
Should be called when the discovery layer has committed the clusters state (i.e.
- onCompilation() - Method in class org.elasticsearch.script.ScriptMetrics
- onCompletion() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- onConnectionClosed(Transport.Connection) - Method in interface org.elasticsearch.transport.TransportConnectionListener
-
Called once a connection ws closed.
- onConnectionClosed(Transport.Connection) - Method in class org.elasticsearch.transport.TransportService
- onConnectionOpened(Transport.Connection) - Method in interface org.elasticsearch.transport.TransportConnectionListener
-
Called once a connection was opened
- onDirectoryCreated(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every new subdirectory found in the watched directory
- onDirectoryDeleted(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every file that disappeared in the watched directory
- onDirectoryInit(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every subdirectory found in the watched directory during initialization
- ONE - org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
- ONE - Static variable in class org.elasticsearch.action.support.ActiveShardCount
- ONE - Static variable in class org.elasticsearch.common.unit.Fuzziness
- onElectedAsMaster(ClusterState) - Method in interface org.elasticsearch.discovery.zen.NodeJoinController.ElectionCallback
-
called when the local node is successfully elected as master Guaranteed to be called on the cluster state update thread
- OneMergeHelper - Class in org.apache.lucene.index
-
Allows pkg private access
- onError() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- onException(TcpChannel, Exception) - Method in class org.elasticsearch.transport.TcpTransport
- onFailedEngine(String, Exception) - Method in interface org.elasticsearch.index.engine.Engine.EventListener
-
Called when a fatal exception occurred
- onFailedFetchPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFailedFetchPhase(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFailedFetchPhase(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed if a fetch phased failed.
- onFailedQueryPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFailedQueryPhase(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFailedQueryPhase(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed if a query phased failed.
- onFailure(Exception) - Method in interface org.elasticsearch.action.ActionListener
-
A failure caused by an exception at some phase of the task.
- onFailure(Exception) - Method in class org.elasticsearch.action.ActionRunnable
-
Calls the action listeners
ActionListener.onFailure(Exception)
method with the given exception. - onFailure(Exception) - Method in class org.elasticsearch.action.LatchedActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.NotifyOnceListener
- onFailure(Exception) - Method in class org.elasticsearch.action.search.SearchExecutionStatsCollector
- onFailure(Exception) - Method in class org.elasticsearch.action.StepListener
- onFailure(Exception) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- onFailure(Exception) - Method in class org.elasticsearch.action.support.ChannelActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.support.ContextPreservingActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.support.GroupedActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- onFailure(Exception) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
- onFailure(Exception) - Method in class org.elasticsearch.action.support.ThreadedActionListener
- onFailure(Exception) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutListener
- onFailure(Exception) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveListener
- onFailure(Exception) - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
This method is invoked for all exception thrown by
AbstractRunnable.doRun()
- onFailure(Exception) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
- onFailure(Exception) - Method in interface org.elasticsearch.discovery.zen.MembershipAction.JoinCallback
- onFailure(Exception) - Method in class org.elasticsearch.rest.action.RestActionListener
- onFailure(Exception) - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- onFailure(Iterable<ActionListener<Response>>, Exception) - Static method in interface org.elasticsearch.action.ActionListener
-
Notifies every given listener with the failure passed to
ActionListener.onFailure(Exception)
. - onFailure(String) - Method in interface org.elasticsearch.gateway.Gateway.GatewayStateRecoveredListener
- onFailure(String, Exception) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- onFailure(String, Exception) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardStartedClusterStateTaskExecutor
- onFailure(String, Exception) - Method in interface org.elasticsearch.cluster.ClusterStateTaskListener
-
A callback called when execute fails.
- onFailure(String, Exception) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
A callback called when execute fails.
- onFailure(String, Exception) - Method in interface org.elasticsearch.cluster.service.ClusterApplier.ClusterApplyListener
-
Called on failure during cluster state application
- onFailure(String, Exception) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.NodeRemovalClusterStateTaskExecutor
- onFailure(Throwable) - Method in interface org.elasticsearch.discovery.zen.NodeJoinController.ElectionCallback
-
called when the local node failed to be elected as master Guaranteed to be called on the cluster state update thread
- onFailure(Throwable) - Method in interface org.elasticsearch.gateway.LocalAllocateDangledIndices.Listener
- onFailure(DiscoveryNode, Exception) - Method in class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
- onFailure(DiscoveryNode, Exception) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Called for each failure obtained from non master nodes
- onFailure(Task, Throwable) - Method in class org.elasticsearch.tasks.LoggingTaskListener
- onFailure(Task, Throwable) - Method in interface org.elasticsearch.tasks.TaskListener
-
A failure caused by an exception at some phase of the task.
- onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.SearchSlowLog
- onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFetchPhase(SearchContext, long) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed after the fetch phase successfully finished.
- onFileChanged(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every file that was changed in the watched directory
- onFileCreated(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every new file found in the watched directory
- onFileDeleted(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every file that disappeared in the watched directory
- onFileInit(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every file found in the watched directory during initialization
- onFreeContext(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFreeContext(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFreeContext(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed when a previously created search context is freed.
- onFreeScrollContext(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFreeScrollContext(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFreeScrollContext(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed when a scroll search
SearchContext
is freed. - OnGoingMerge - Class in org.elasticsearch.index.merge
-
Represents a single on going merge within an index.
- OnGoingMerge(MergePolicy.OneMerge) - Constructor for class org.elasticsearch.index.merge.OnGoingMerge
- onHit() - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- onIncomingClusterState(ClusterState) - Method in interface org.elasticsearch.discovery.zen.PublishClusterStateAction.IncomingClusterStateListener
-
called when a new incoming cluster state has been received.
- onIncomingClusterState(ClusterState) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- onIndexModule(IndexModule) - Method in class org.elasticsearch.plugins.Plugin
-
Called before a new index is created on a node.
- onIndexModule(IndexModule) - Method in class org.elasticsearch.plugins.PluginsService
- onInit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.engine.CombinedDeletionPolicy
- onJoin(DiscoveryNode, MembershipAction.JoinCallback) - Method in interface org.elasticsearch.discovery.zen.MembershipAction.MembershipListener
- onLeave(DiscoveryNode) - Method in interface org.elasticsearch.discovery.zen.MembershipAction.MembershipListener
- only(Object) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches objects equal to the given object.
- ONLY_EXPUNGE_DELETES - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest.Defaults
- ONLY_LOCAL - org.elasticsearch.cluster.routing.Preference
-
Route to the local shard only
- ONLY_NODES - org.elasticsearch.cluster.routing.Preference
-
Route to only node with attribute
- onlyExpungeDeletes() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Should the merge only expunge deletes from the index, without full merging.
- onlyExpungeDeletes(boolean) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Should the merge only expunge deletes from the index, without full merge.
- onlyNodeActiveInitializingShardsIt(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- onlyNodeSelectorActiveInitializingShardsIt(String[], DiscoveryNodes) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns shards based on nodeAttributes given such as node name , node attribute, node IP Supports node specifications in cluster API
- onlyNodeSelectorActiveInitializingShardsIt(String, DiscoveryNodes) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- onMaster() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
- onMaster() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
-
Called when local node is elected to be the master
- onMasterFailure(DiscoveryNode, Throwable, String) - Method in interface org.elasticsearch.discovery.zen.MasterFaultDetection.Listener
-
called when pinging the master failed, like a timeout, transport disconnects etc
- onMiss() - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- onModule(ActionModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.implement
ActionPlugin
instead - onModule(ClusterModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.implement
ClusterPlugin
instead - onModule(NetworkModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.implement
NetworkPlugin
instead - onModule(SettingsModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.use #getSettings and #getSettingsFilter instead
- onModule(DiscoveryModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.implement
DiscoveryPlugin
instead - onModule(IndexModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.use #onIndexModule instead
- onModule(AnalysisModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.implement
AnalysisPlugin
instead - onModule(RepositoriesModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.implement
RepositoryPlugin
instead - onModule(ScriptModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.implement
ScriptPlugin
instead - onModule(SearchModule) - Method in class org.elasticsearch.plugins.Plugin
-
Deprecated.implement
SearchPlugin
instead - onNewClusterState(String, Supplier<ClusterState>, ClusterApplier.ClusterApplyListener) - Method in interface org.elasticsearch.cluster.service.ClusterApplier
-
Method to invoke when a new cluster state is available to be applied
- onNewClusterState(String, Supplier<ClusterState>, ClusterApplier.ClusterApplyListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- onNewClusterState(ClusterState) - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
-
called when a new state is observed
- onNewContext(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onNewContext(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onNewContext(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed when a new search context was created
- onNewEngine(Engine) - Method in class org.elasticsearch.index.shard.IndexShard
- onNewInfo(ClusterInfo) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdMonitor
- onNewScrollContext(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onNewScrollContext(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onNewScrollContext(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed when a new scroll search
SearchContext
was created - onNodeAck(DiscoveryNode, Exception) - Method in interface org.elasticsearch.discovery.Discovery.AckListener
-
Should be called whenever the discovery layer receives confirmation from a node that it has successfully applied the cluster state.
- onNodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportConnectionListener
-
Called once a node connection is opened and registered.
- onNodeDisconnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportConnectionListener
-
Called once a node connection is closed and unregistered.
- onNodeDisconnected(DiscoveryNode, Exception) - Method in interface org.elasticsearch.client.transport.TransportClient.HostFailureListener
-
Called once a node disconnect is detected.
- onNodeFailure(DiscoveryNode, int, Throwable) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- onNodeFailure(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.Listener
- onNodeResponse(DiscoveryNode, int, TransportBroadcastByNodeAction.NodeResponse) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- onNodeStarted() - Method in interface org.elasticsearch.plugins.ClusterPlugin
-
Called when the node is started
- onNoLongerMaster() - Method in class org.elasticsearch.cluster.service.MasterService.TaskInputs
- onNoLongerMaster(String) - Method in interface org.elasticsearch.cluster.ClusterStateTaskListener
-
called when the task was rejected because the local node is no longer master.
- onNoLongerMaster(String) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.NodeRemovalClusterStateTaskExecutor
- onNonChannelException(Exception) - Method in class org.elasticsearch.transport.TcpTransport
-
Exception handler for exceptions that are not associated with a specific channel.
- onOperation(ShardRouting, int, ShardResponse) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- onOrAfter(Version) - Method in class org.elasticsearch.Version
- onOrBefore(Version) - Method in class org.elasticsearch.Version
- onOutOfMemoryError() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- onPause(long) - Method in interface org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream.Listener
- onPingReceived(NodesFaultDetection.PingRequest) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.Listener
- onPortNumber(int) - Method in interface org.elasticsearch.common.transport.PortsRange.PortCallback
- onPostWarm(long) - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
- onPreFetchPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onPreFetchPhase(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onPreFetchPhase(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed before the fetch phase is executed
- onPreQueryPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onPreQueryPhase(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onPreQueryPhase(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed before the query phase is executed
- onPreWarm() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
- onQueryPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onQueryPhase(SearchContext, long) - Method in class org.elasticsearch.index.SearchSlowLog
- onQueryPhase(SearchContext, long) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onQueryPhase(SearchContext, long) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed after the query phase successfully finished.
- onRecoveryDone(RecoveryState) - Method in interface org.elasticsearch.indices.recovery.PeerRecoveryTargetService.RecoveryListener
- onRecoveryFailure(RecoveryState, RecoveryFailedException, boolean) - Method in interface org.elasticsearch.indices.recovery.PeerRecoveryTargetService.RecoveryListener
- onRejection(Exception) - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
This should be executed if the thread-pool executing this action rejected the execution.
- onRejection(Exception) - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- onRemoval(long) - Method in class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
- onRemoval(Accountable, BytesReference, boolean) - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- onRemoval(RemovalNotification<K, V>) - Method in interface org.elasticsearch.common.cache.RemovalListener
- onRemoval(RemovalNotification<IndexReader.CacheKey, Cache<Query, BitsetFilterCache.Value>>) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- onRemoval(RemovalNotification<IndicesFieldDataCache.Key, Accountable>) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- onRemoval(RemovalNotification<IndicesRequestCache.Key, BytesReference>) - Method in class org.elasticsearch.indices.IndicesRequestCache
- onRemoval(ShardId, String, boolean, long) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache.Listener
-
Called after the fielddata is unloaded
- onRemoval(ShardId, String, boolean, long) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
- onRemoval(ShardId, Accountable) - Method in interface org.elasticsearch.index.cache.bitset.BitsetFilterCache.Listener
-
Called for each cached bitset on the removal event.
- onRequestReceived(long, String) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called once a request is received
- onRequestReceived(long, String) - Method in class org.elasticsearch.transport.TransportService
-
called by the
Transport
implementation when an incoming request arrives but before any parsing of it has happened (with the exception of the requestId and action) - onRequestSent(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called for every request sent to a server after the request has been passed to the underlying network implementation
- onRequestSent(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.transport.TransportService
-
called by the
Transport
implementation once a request has been sent - onResponse(Iterable<ActionListener<Response>>, Response) - Static method in interface org.elasticsearch.action.ActionListener
-
Notifies every given listener with the response passed to
ActionListener.onResponse(Object)
. - onResponse(L) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- onResponse(MetaDataIndexTemplateService.PutResponse) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutListener
- onResponse(MetaDataIndexTemplateService.RemoveResponse) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveListener
- onResponse(DiscoveryNode) - Method in class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
- onResponse(DiscoveryNode) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Called for each response obtained from non master nodes
- onResponse(LocalAllocateDangledIndices.AllocateDangledResponse) - Method in interface org.elasticsearch.gateway.LocalAllocateDangledIndices.Listener
- onResponse(SearchPhaseResult) - Method in class org.elasticsearch.action.search.SearchExecutionStatsCollector
- onResponse(Task, Response) - Method in class org.elasticsearch.tasks.LoggingTaskListener
- onResponse(Task, Response) - Method in interface org.elasticsearch.tasks.TaskListener
-
Handle task response.
- onResponse(R) - Method in class org.elasticsearch.action.support.ContextPreservingActionListener
- onResponse(Response) - Method in interface org.elasticsearch.action.ActionListener
-
Handle action response.
- onResponse(Response) - Method in class org.elasticsearch.action.NotifyOnceListener
- onResponse(Response) - Method in class org.elasticsearch.action.StepListener
- onResponse(Response) - Method in class org.elasticsearch.action.support.ChannelActionListener
- onResponse(Response) - Method in class org.elasticsearch.action.support.ThreadedActionListener
- onResponse(Response) - Method in class org.elasticsearch.rest.action.RestActionListener
- onResponse(T) - Method in class org.elasticsearch.action.LatchedActionListener
- onResponse(T) - Method in class org.elasticsearch.action.support.GroupedActionListener
- onResponse(V) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
- onResponseReceived(long, Transport.ResponseContext) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called for every response received
- onResponseReceived(long, Transport.ResponseContext) - Method in class org.elasticsearch.transport.TransportService
- onResponseReceived(long, TransportMessageListener) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
called by the
Transport
implementation when a response or an exception has been received for a previously sent request (before any processing or deserialization was done). - onResponseSent(long, String, Exception) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called for every failed action response after the response has been passed to the underlying network implementation.
- onResponseSent(long, String, Exception) - Method in class org.elasticsearch.transport.TransportService
-
called by the
Transport
implementation after an exception was sent as a response to an incoming request - onResponseSent(long, String, TransportResponse) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called for every action response sent after the response has been passed to the underlying network implementation.
- onResponseSent(long, String, TransportResponse) - Method in class org.elasticsearch.transport.TransportService
-
called by the
Transport
implementation once a response was sent to calling node - onRetry() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- onRetry() - Method in class org.elasticsearch.action.index.IndexRequest
- onRetry() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
This method is called before this replication request is retried the first time.
- onServerException(TcpServerChannel, Exception) - Method in class org.elasticsearch.transport.TcpTransport
- onSettingsChanged() - Method in class org.elasticsearch.index.engine.Engine
- onSettingsChanged() - Method in class org.elasticsearch.index.engine.InternalEngine
- onSettingsChanged() - Method in class org.elasticsearch.index.shard.IndexShard
- onShardInactive(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called when a shard is marked as inactive
- onShardInactive(IndexShard) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
- onSliceFailure(ActionListener<BulkByScrollResponse>, int, Exception) - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Record a failure from a slice and respond to the listener if the request is finished.
- onSliceResponse(ActionListener<BulkByScrollResponse>, int, BulkByScrollResponse) - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Record a response from a slice and respond to the listener if the request is finished.
- onStoreClosed(ShardId) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called when the given shards store is closed.
- onSuccess() - Method in interface org.elasticsearch.discovery.zen.MembershipAction.JoinCallback
- onSuccess(boolean) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- onSuccess(boolean) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
- onSuccess(String) - Method in interface org.elasticsearch.cluster.service.ClusterApplier.ClusterApplyListener
-
Called on successful cluster state application
- onSuccess(ClusterState) - Method in interface org.elasticsearch.gateway.Gateway.GatewayStateRecoveredListener
- onTerminated() - Method in interface org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor.ShutdownListener
- onTimeout(List<? extends TaskBatcher.BatchedTask>, TimeValue) - Method in class org.elasticsearch.cluster.service.TaskBatcher
-
Action to be implemented by the specific batching implementation.
- onTimeout(TimeValue) - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
- onTimeout(TimeValue) - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
- onTimeout(TimeValue) - Method in interface org.elasticsearch.persistent.PersistentTasksService.WaitForPersistentTaskListener
- OP - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- open(FileChannel, Path, Checkpoint, String) - Static method in class org.elasticsearch.index.translog.TranslogReader
-
Given a file channel, opens a
TranslogReader
, taking care of checking and validating the file header. - open(Path) - Method in interface org.elasticsearch.index.translog.ChannelFactory
- open(Path, OpenOption...) - Method in interface org.elasticsearch.index.translog.ChannelFactory
- open(IndexCommit) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- open(OpenIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Open an index based on the index name.
- open(OpenIndexRequest, ActionListener<OpenIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Open an index based on the index name.
- OPEN - org.elasticsearch.action.support.IndicesOptions.WildcardStates
- OPEN - org.elasticsearch.cluster.metadata.IndexMetaData.State
- openAndPutIndexOutput(String, StoreFileMetaData, Store) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
-
Creates an
IndexOutput
for the given file name. - openConnection(DiscoveryNode, ConnectionProfile) - Method in class org.elasticsearch.transport.ConnectionManager
- openConnection(DiscoveryNode, ConnectionProfile) - Method in class org.elasticsearch.transport.TransportService
-
Establishes and returns a new connection to the given node.
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.transport.TcpTransport
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in interface org.elasticsearch.transport.Transport
-
Opens a new connection to the given node.
- openEngineAndRecoverFromTranslog() - Method in class org.elasticsearch.index.shard.IndexShard
-
opens the engine on top of the existing lucene engine and translog.
- openEngineAndSkipTranslogRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
-
Opens the engine on top of the existing lucene engine and translog.
- openFileURLStream(URL) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Returns an InputStream the given url if the url has a protocol of 'file' or 'jar', no host, and no port.
- openIndex(OpenIndexClusterStateUpdateRequest, ActionListener<OpenIndexClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexStateService
- OpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
- OpenIndexClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.open
-
Cluster state update request that allows to open one or more indices
- OpenIndexClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexClusterStateUpdateRequest
- OpenIndexClusterStateUpdateResponse - Class in org.elasticsearch.cluster.ack
-
A cluster state update response with specific fields for index opening.
- OpenIndexClusterStateUpdateResponse(boolean, boolean) - Constructor for class org.elasticsearch.cluster.ack.OpenIndexClusterStateUpdateResponse
- openIndexRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates an open index request.
- OpenIndexRequest - Class in org.elasticsearch.action.admin.indices.open
-
A request to open an index.
- OpenIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- OpenIndexRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Constructs a new open index request for the specified index.
- OpenIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.open
-
Builder for for open index request
- OpenIndexRequestBuilder(ElasticsearchClient, OpenIndexAction) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
- OpenIndexRequestBuilder(ElasticsearchClient, OpenIndexAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
- OpenIndexResponse - Class in org.elasticsearch.action.admin.indices.open
-
A response for a open index action.
- OpenIndexResponse() - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
- OpenIndexResponse(boolean, boolean) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
- openSlice(long) - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
Called for each logical slice given a zero based slice ordinal.
- openVerifyingInput(String, IOContext, StoreFileMetaData) - Method in class org.elasticsearch.index.store.Store
- Operation(Term, long, long, long, VersionType, Engine.Operation.Origin, long) - Constructor for class org.elasticsearch.index.engine.Engine.Operation
- OPERATION - org.elasticsearch.action.ThreadingModel
- OPERATION_LISTENER - org.elasticsearch.action.ThreadingModel
- operationRouting() - Method in class org.elasticsearch.cluster.service.ClusterService
- OperationRouting - Class in org.elasticsearch.cluster.routing
- OperationRouting(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.OperationRouting
- operations() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- operations() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- OperationTransportHandler() - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.OperationTransportHandler
- operationType() - Method in class org.elasticsearch.index.engine.Engine.Delete
- operationType() - Method in class org.elasticsearch.index.engine.Engine.Index
- operationType() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- operationType() - Method in class org.elasticsearch.index.engine.Engine.Operation
- operator() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Returns the operator to use in a boolean query.
- operator() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- operator(Operator) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets the operator to use when using a boolean query.
- operator(Operator) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the operator to use when using a boolean query.
- Operator - Enum in org.elasticsearch.index.query
- OPERATOR_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- optimizedAppendOnly(long, long) - Static method in class org.elasticsearch.index.engine.InternalEngine.IndexingStrategy
- Option() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- Option() - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- Option() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- Option(int, Text, float, Map<String, Set<String>>) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- Option(Text, float) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- Option(Text, int, float) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- Option(Text, Text, float) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- Option(Text, Text, float, Boolean) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- optional() - Method in annotation type org.elasticsearch.common.inject.Inject
-
If true, and the appropriate binding is not found, the Injector will skip injection of this method or field rather than produce an error.
- optionalConstructor(Constructor) - Method in class org.elasticsearch.common.inject.internal.Errors
- options - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- options - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- options() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- options() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- options(Map<String, Object>) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Allows to set custom options for custom highlighters.
- OPTIONS - org.elasticsearch.rest.RestRequest.Method
- OPTIONS - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- OPTIONS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- OPTIONS_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for options on the inner level. - OPTIONS_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for options on the inner level. - opType() - Method in class org.elasticsearch.action.delete.DeleteRequest
- opType() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the requested document operation type of the request
- opType() - Method in class org.elasticsearch.action.index.IndexRequest
- opType() - Method in class org.elasticsearch.action.update.UpdateRequest
- opType() - Method in class org.elasticsearch.index.translog.Translog.Delete
- opType() - Method in class org.elasticsearch.index.translog.Translog.Index
- opType() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- opType() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- opType(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets a string representation of the
IndexRequest.opType(OpType)
. - opType(DocWriteRequest.OpType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the type of operation to perform.
- or(Matcher<? super T>) - Method in class org.elasticsearch.common.inject.matcher.AbstractMatcher
- or(Matcher<? super T>) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
-
Returns a new matcher which returns
true
if either this or the given matcher returntrue
. - OR - org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
- OR - org.elasticsearch.index.query.Operator
- OR - org.elasticsearch.index.query.SimpleQueryStringFlag
- ord() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- order - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- order - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- order - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- order - Variable in class org.elasticsearch.search.sort.SortBuilder
- order() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- order() - Method in interface org.elasticsearch.action.support.ActionFilter
-
The position of the filter in the chain.
- order() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- order() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the
SortOrder
to use to sort values produced this source - order() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return the order to use to sort buckets of this histogram.
- order() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Return the order to use to sort buckets of this histogram.
- order() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Gets the order in which the buckets will be returned.
- order() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- order() - Method in class org.elasticsearch.search.sort.SortBuilder
-
Return the
SortOrder
used for thisSortBuilder
. - order(int) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- order(int) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- order(int) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- order(String) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the
SortOrder
to use to sort values produced this source - order(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
The order of fragments per field.
- order(List<BucketOrder>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Sets the order in which the buckets will be returned.
- order(List<BucketOrder>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Sets the order in which the buckets will be returned.
- order(List<BucketOrder>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Sets the order in which the buckets will be returned.
- order(BucketOrder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set a new order on this builder and return the builder so that calls can be chained.
- order(BucketOrder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set a new order on this builder and return the builder so that calls can be chained.
- order(BucketOrder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set a new order on this builder and return the builder so that calls can be chained.
- order(HighlightBuilder.Order) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
By default, fragments of a field are ordered by the order in the highlighted text.
- order(SortOrder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the
SortOrder
to use to sort values produced this source - order(SortOrder) - Method in class org.elasticsearch.search.sort.SortBuilder
-
Set the order of sorting.
- ORDER_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- ORDER_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- ORDER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- ORDER_FIELD - Static variable in class org.elasticsearch.search.sort.SortBuilder
- orderElements() - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- ORDINAL_DATE - org.elasticsearch.common.time.FormatNames
- ORDINAL_DATE_TIME - org.elasticsearch.common.time.FormatNames
- ORDINAL_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- ordinalDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date, using a four digit year and three digit dayOfYear (yyyy-DDD).
- ordinalDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time, using a four digit year and three digit dayOfYear (yyyy-DDD'T'HH:mm:ss.SSSZZ).
- ordinalDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time without millis, using a four digit year and three digit dayOfYear (yyyy-DDD'T'HH:mm:ssZZ).
- ordinals - Variable in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
- ordinals() - Method in class org.elasticsearch.index.fielddata.ordinals.Ordinals
- ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
- ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.Ordinals
- ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.SinglePackedOrdinals
- Ordinals - Class in org.elasticsearch.index.fielddata.ordinals
-
A thread safe ordinals abstraction.
- Ordinals() - Constructor for class org.elasticsearch.index.fielddata.ordinals.Ordinals
- Ordinals.ValuesHolder - Interface in org.elasticsearch.index.fielddata.ordinals
- OrdinalsBuilder - Class in org.elasticsearch.index.fielddata.ordinals
-
Simple class to build document ID <-> ordinal mapping.
- OrdinalsBuilder(int) - Constructor for class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
- OrdinalsBuilder(int, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
- OrdinalsFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.OrdinalsFilter
- ordinalsValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- ordinalsValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
- org.apache.lucene.analysis.miscellaneous - package org.apache.lucene.analysis.miscellaneous
- org.apache.lucene.document - package org.apache.lucene.document
- org.apache.lucene.index - package org.apache.lucene.index
- org.apache.lucene.queries - package org.apache.lucene.queries
- org.apache.lucene.queryparser.classic - package org.apache.lucene.queryparser.classic
- org.apache.lucene.search - package org.apache.lucene.search
- org.apache.lucene.search.grouping - package org.apache.lucene.search.grouping
- org.apache.lucene.search.suggest.analyzing - package org.apache.lucene.search.suggest.analyzing
- org.apache.lucene.search.uhighlight - package org.apache.lucene.search.uhighlight
- org.apache.lucene.search.vectorhighlight - package org.apache.lucene.search.vectorhighlight
- org.elasticsearch - package org.elasticsearch
-
A distributed RESTful search engine.
- org.elasticsearch.action - package org.elasticsearch.action
-
Actions that Elasticsearch can take either on the data stored on disk or on other nodes.
- org.elasticsearch.action.admin.cluster.allocation - package org.elasticsearch.action.admin.cluster.allocation
- org.elasticsearch.action.admin.cluster.health - package org.elasticsearch.action.admin.cluster.health
- org.elasticsearch.action.admin.cluster.node.hotthreads - package org.elasticsearch.action.admin.cluster.node.hotthreads
- org.elasticsearch.action.admin.cluster.node.info - package org.elasticsearch.action.admin.cluster.node.info
- org.elasticsearch.action.admin.cluster.node.liveness - package org.elasticsearch.action.admin.cluster.node.liveness
- org.elasticsearch.action.admin.cluster.node.reload - package org.elasticsearch.action.admin.cluster.node.reload
- org.elasticsearch.action.admin.cluster.node.stats - package org.elasticsearch.action.admin.cluster.node.stats
- org.elasticsearch.action.admin.cluster.node.tasks.cancel - package org.elasticsearch.action.admin.cluster.node.tasks.cancel
- org.elasticsearch.action.admin.cluster.node.tasks.get - package org.elasticsearch.action.admin.cluster.node.tasks.get
- org.elasticsearch.action.admin.cluster.node.tasks.list - package org.elasticsearch.action.admin.cluster.node.tasks.list
- org.elasticsearch.action.admin.cluster.node.usage - package org.elasticsearch.action.admin.cluster.node.usage
- org.elasticsearch.action.admin.cluster.remote - package org.elasticsearch.action.admin.cluster.remote
- org.elasticsearch.action.admin.cluster.repositories.delete - package org.elasticsearch.action.admin.cluster.repositories.delete
- org.elasticsearch.action.admin.cluster.repositories.get - package org.elasticsearch.action.admin.cluster.repositories.get
- org.elasticsearch.action.admin.cluster.repositories.put - package org.elasticsearch.action.admin.cluster.repositories.put
- org.elasticsearch.action.admin.cluster.repositories.verify - package org.elasticsearch.action.admin.cluster.repositories.verify
- org.elasticsearch.action.admin.cluster.reroute - package org.elasticsearch.action.admin.cluster.reroute
- org.elasticsearch.action.admin.cluster.settings - package org.elasticsearch.action.admin.cluster.settings
- org.elasticsearch.action.admin.cluster.shards - package org.elasticsearch.action.admin.cluster.shards
- org.elasticsearch.action.admin.cluster.snapshots.create - package org.elasticsearch.action.admin.cluster.snapshots.create
- org.elasticsearch.action.admin.cluster.snapshots.delete - package org.elasticsearch.action.admin.cluster.snapshots.delete
- org.elasticsearch.action.admin.cluster.snapshots.get - package org.elasticsearch.action.admin.cluster.snapshots.get
- org.elasticsearch.action.admin.cluster.snapshots.restore - package org.elasticsearch.action.admin.cluster.snapshots.restore
- org.elasticsearch.action.admin.cluster.snapshots.status - package org.elasticsearch.action.admin.cluster.snapshots.status
- org.elasticsearch.action.admin.cluster.state - package org.elasticsearch.action.admin.cluster.state
- org.elasticsearch.action.admin.cluster.stats - package org.elasticsearch.action.admin.cluster.stats
- org.elasticsearch.action.admin.cluster.storedscripts - package org.elasticsearch.action.admin.cluster.storedscripts
- org.elasticsearch.action.admin.cluster.tasks - package org.elasticsearch.action.admin.cluster.tasks
- org.elasticsearch.action.admin.indices.alias - package org.elasticsearch.action.admin.indices.alias
- org.elasticsearch.action.admin.indices.alias.exists - package org.elasticsearch.action.admin.indices.alias.exists
- org.elasticsearch.action.admin.indices.alias.get - package org.elasticsearch.action.admin.indices.alias.get
- org.elasticsearch.action.admin.indices.analyze - package org.elasticsearch.action.admin.indices.analyze
- org.elasticsearch.action.admin.indices.cache.clear - package org.elasticsearch.action.admin.indices.cache.clear
- org.elasticsearch.action.admin.indices.close - package org.elasticsearch.action.admin.indices.close
- org.elasticsearch.action.admin.indices.create - package org.elasticsearch.action.admin.indices.create
-
Create index action.
- org.elasticsearch.action.admin.indices.delete - package org.elasticsearch.action.admin.indices.delete
-
Delete index action.
- org.elasticsearch.action.admin.indices.exists.indices - package org.elasticsearch.action.admin.indices.exists.indices
- org.elasticsearch.action.admin.indices.exists.types - package org.elasticsearch.action.admin.indices.exists.types
- org.elasticsearch.action.admin.indices.flush - package org.elasticsearch.action.admin.indices.flush
-
Flush index/indices action.
- org.elasticsearch.action.admin.indices.forcemerge - package org.elasticsearch.action.admin.indices.forcemerge
-
Force merge index/indices action.
- org.elasticsearch.action.admin.indices.get - package org.elasticsearch.action.admin.indices.get
- org.elasticsearch.action.admin.indices.mapping.get - package org.elasticsearch.action.admin.indices.mapping.get
- org.elasticsearch.action.admin.indices.mapping.put - package org.elasticsearch.action.admin.indices.mapping.put
-
Put Mapping Action.
- org.elasticsearch.action.admin.indices.open - package org.elasticsearch.action.admin.indices.open
- org.elasticsearch.action.admin.indices.recovery - package org.elasticsearch.action.admin.indices.recovery
- org.elasticsearch.action.admin.indices.refresh - package org.elasticsearch.action.admin.indices.refresh
-
Refresh index/indices action.
- org.elasticsearch.action.admin.indices.rollover - package org.elasticsearch.action.admin.indices.rollover
- org.elasticsearch.action.admin.indices.segments - package org.elasticsearch.action.admin.indices.segments
- org.elasticsearch.action.admin.indices.settings.get - package org.elasticsearch.action.admin.indices.settings.get
- org.elasticsearch.action.admin.indices.settings.put - package org.elasticsearch.action.admin.indices.settings.put
- org.elasticsearch.action.admin.indices.shards - package org.elasticsearch.action.admin.indices.shards
- org.elasticsearch.action.admin.indices.shrink - package org.elasticsearch.action.admin.indices.shrink
- org.elasticsearch.action.admin.indices.stats - package org.elasticsearch.action.admin.indices.stats
- org.elasticsearch.action.admin.indices.template.delete - package org.elasticsearch.action.admin.indices.template.delete
- org.elasticsearch.action.admin.indices.template.get - package org.elasticsearch.action.admin.indices.template.get
- org.elasticsearch.action.admin.indices.template.put - package org.elasticsearch.action.admin.indices.template.put
- org.elasticsearch.action.admin.indices.upgrade.get - package org.elasticsearch.action.admin.indices.upgrade.get
- org.elasticsearch.action.admin.indices.upgrade.post - package org.elasticsearch.action.admin.indices.upgrade.post
- org.elasticsearch.action.admin.indices.validate.query - package org.elasticsearch.action.admin.indices.validate.query
-
Validate action.
- org.elasticsearch.action.bulk - package org.elasticsearch.action.bulk
- org.elasticsearch.action.delete - package org.elasticsearch.action.delete
-
Delete action.
- org.elasticsearch.action.explain - package org.elasticsearch.action.explain
-
Explain action.
- org.elasticsearch.action.fieldcaps - package org.elasticsearch.action.fieldcaps
- org.elasticsearch.action.get - package org.elasticsearch.action.get
-
Get action.
- org.elasticsearch.action.index - package org.elasticsearch.action.index
-
Index action.
- org.elasticsearch.action.ingest - package org.elasticsearch.action.ingest
- org.elasticsearch.action.main - package org.elasticsearch.action.main
- org.elasticsearch.action.resync - package org.elasticsearch.action.resync
- org.elasticsearch.action.search - package org.elasticsearch.action.search
-
Search action.
- org.elasticsearch.action.support - package org.elasticsearch.action.support
- org.elasticsearch.action.support.broadcast - package org.elasticsearch.action.support.broadcast
- org.elasticsearch.action.support.broadcast.node - package org.elasticsearch.action.support.broadcast.node
- org.elasticsearch.action.support.master - package org.elasticsearch.action.support.master
- org.elasticsearch.action.support.master.info - package org.elasticsearch.action.support.master.info
- org.elasticsearch.action.support.nodes - package org.elasticsearch.action.support.nodes
- org.elasticsearch.action.support.replication - package org.elasticsearch.action.support.replication
- org.elasticsearch.action.support.single.instance - package org.elasticsearch.action.support.single.instance
- org.elasticsearch.action.support.single.shard - package org.elasticsearch.action.support.single.shard
- org.elasticsearch.action.support.tasks - package org.elasticsearch.action.support.tasks
- org.elasticsearch.action.termvectors - package org.elasticsearch.action.termvectors
-
Get the term vector for a specific document.
- org.elasticsearch.action.update - package org.elasticsearch.action.update
- org.elasticsearch.bootstrap - package org.elasticsearch.bootstrap
- org.elasticsearch.cli - package org.elasticsearch.cli
- org.elasticsearch.client - package org.elasticsearch.client
-
The client module allowing to easily perform actions/operations.
- org.elasticsearch.client.node - package org.elasticsearch.client.node
- org.elasticsearch.client.support - package org.elasticsearch.client.support
- org.elasticsearch.client.transport - package org.elasticsearch.client.transport
- org.elasticsearch.cluster - package org.elasticsearch.cluster
- org.elasticsearch.cluster.ack - package org.elasticsearch.cluster.ack
- org.elasticsearch.cluster.action.index - package org.elasticsearch.cluster.action.index
- org.elasticsearch.cluster.action.shard - package org.elasticsearch.cluster.action.shard
- org.elasticsearch.cluster.block - package org.elasticsearch.cluster.block
- org.elasticsearch.cluster.health - package org.elasticsearch.cluster.health
- org.elasticsearch.cluster.metadata - package org.elasticsearch.cluster.metadata
- org.elasticsearch.cluster.node - package org.elasticsearch.cluster.node
- org.elasticsearch.cluster.routing - package org.elasticsearch.cluster.routing
- org.elasticsearch.cluster.routing.allocation - package org.elasticsearch.cluster.routing.allocation
- org.elasticsearch.cluster.routing.allocation.allocator - package org.elasticsearch.cluster.routing.allocation.allocator
- org.elasticsearch.cluster.routing.allocation.command - package org.elasticsearch.cluster.routing.allocation.command
- org.elasticsearch.cluster.routing.allocation.decider - package org.elasticsearch.cluster.routing.allocation.decider
- org.elasticsearch.cluster.service - package org.elasticsearch.cluster.service
- org.elasticsearch.common - package org.elasticsearch.common
- org.elasticsearch.common.blobstore - package org.elasticsearch.common.blobstore
- org.elasticsearch.common.blobstore.fs - package org.elasticsearch.common.blobstore.fs
- org.elasticsearch.common.blobstore.support - package org.elasticsearch.common.blobstore.support
- org.elasticsearch.common.breaker - package org.elasticsearch.common.breaker
- org.elasticsearch.common.bytes - package org.elasticsearch.common.bytes
- org.elasticsearch.common.cache - package org.elasticsearch.common.cache
- org.elasticsearch.common.collect - package org.elasticsearch.common.collect
- org.elasticsearch.common.component - package org.elasticsearch.common.component
- org.elasticsearch.common.compress - package org.elasticsearch.common.compress
- org.elasticsearch.common.document - package org.elasticsearch.common.document
- org.elasticsearch.common.geo - package org.elasticsearch.common.geo
- org.elasticsearch.common.geo.builders - package org.elasticsearch.common.geo.builders
- org.elasticsearch.common.geo.parsers - package org.elasticsearch.common.geo.parsers
- org.elasticsearch.common.hash - package org.elasticsearch.common.hash
- org.elasticsearch.common.inject - package org.elasticsearch.common.inject
-
Google Guice (pronounced "juice") is an ultra-lightweight dependency injection framework.
- org.elasticsearch.common.inject.assistedinject - package org.elasticsearch.common.inject.assistedinject
-
Extension for combining factory interfaces with injection; this extension requires
guice-jndi-2.0.jar
. - org.elasticsearch.common.inject.binder - package org.elasticsearch.common.inject.binder
-
Interfaces which make up
Binder
's expression language. - org.elasticsearch.common.inject.internal - package org.elasticsearch.common.inject.internal
-
Guice (sounds like like "juice")
- org.elasticsearch.common.inject.matcher - package org.elasticsearch.common.inject.matcher
-
Used for matching things.
- org.elasticsearch.common.inject.multibindings - package org.elasticsearch.common.inject.multibindings
-
Extension for binding multiple instances in a collection; this extension requires
guice-multibindings-2.0.jar
. - org.elasticsearch.common.inject.name - package org.elasticsearch.common.inject.name
-
Support for binding to string-based names.
- org.elasticsearch.common.inject.spi - package org.elasticsearch.common.inject.spi
-
Guice service provider interface
- org.elasticsearch.common.inject.util - package org.elasticsearch.common.inject.util
-
Helper methods for working with Guice.
- org.elasticsearch.common.io - package org.elasticsearch.common.io
- org.elasticsearch.common.io.stream - package org.elasticsearch.common.io.stream
-
Classes for streaming objects from one Elasticsearch node to another over its binary internode protocol.
- org.elasticsearch.common.joda - package org.elasticsearch.common.joda
- org.elasticsearch.common.lease - package org.elasticsearch.common.lease
- org.elasticsearch.common.logging - package org.elasticsearch.common.logging
- org.elasticsearch.common.lucene - package org.elasticsearch.common.lucene
- org.elasticsearch.common.lucene.all - package org.elasticsearch.common.lucene.all
- org.elasticsearch.common.lucene.index - package org.elasticsearch.common.lucene.index
- org.elasticsearch.common.lucene.search - package org.elasticsearch.common.lucene.search
- org.elasticsearch.common.lucene.search.function - package org.elasticsearch.common.lucene.search.function
- org.elasticsearch.common.lucene.store - package org.elasticsearch.common.lucene.store
- org.elasticsearch.common.lucene.uid - package org.elasticsearch.common.lucene.uid
- org.elasticsearch.common.metrics - package org.elasticsearch.common.metrics
- org.elasticsearch.common.network - package org.elasticsearch.common.network
- org.elasticsearch.common.path - package org.elasticsearch.common.path
- org.elasticsearch.common.recycler - package org.elasticsearch.common.recycler
- org.elasticsearch.common.regex - package org.elasticsearch.common.regex
- org.elasticsearch.common.rounding - package org.elasticsearch.common.rounding
- org.elasticsearch.common.settings - package org.elasticsearch.common.settings
-
Settings based utility.
- org.elasticsearch.common.text - package org.elasticsearch.common.text
- org.elasticsearch.common.time - package org.elasticsearch.common.time
- org.elasticsearch.common.transport - package org.elasticsearch.common.transport
- org.elasticsearch.common.unit - package org.elasticsearch.common.unit
- org.elasticsearch.common.util - package org.elasticsearch.common.util
- org.elasticsearch.common.util.concurrent - package org.elasticsearch.common.util.concurrent
- org.elasticsearch.common.util.iterable - package org.elasticsearch.common.util.iterable
- org.elasticsearch.common.util.set - package org.elasticsearch.common.util.set
- org.elasticsearch.common.xcontent - package org.elasticsearch.common.xcontent
- org.elasticsearch.common.xcontent.support - package org.elasticsearch.common.xcontent.support
- org.elasticsearch.discovery - package org.elasticsearch.discovery
- org.elasticsearch.discovery.single - package org.elasticsearch.discovery.single
- org.elasticsearch.discovery.zen - package org.elasticsearch.discovery.zen
- org.elasticsearch.env - package org.elasticsearch.env
- org.elasticsearch.gateway - package org.elasticsearch.gateway
- org.elasticsearch.http - package org.elasticsearch.http
- org.elasticsearch.index - package org.elasticsearch.index
- org.elasticsearch.index.analysis - package org.elasticsearch.index.analysis
- org.elasticsearch.index.cache - package org.elasticsearch.index.cache
- org.elasticsearch.index.cache.bitset - package org.elasticsearch.index.cache.bitset
- org.elasticsearch.index.cache.query - package org.elasticsearch.index.cache.query
- org.elasticsearch.index.cache.request - package org.elasticsearch.index.cache.request
- org.elasticsearch.index.codec - package org.elasticsearch.index.codec
- org.elasticsearch.index.engine - package org.elasticsearch.index.engine
- org.elasticsearch.index.fielddata - package org.elasticsearch.index.fielddata
- org.elasticsearch.index.fielddata.fieldcomparator - package org.elasticsearch.index.fielddata.fieldcomparator
- org.elasticsearch.index.fielddata.ordinals - package org.elasticsearch.index.fielddata.ordinals
- org.elasticsearch.index.fielddata.plain - package org.elasticsearch.index.fielddata.plain
- org.elasticsearch.index.fieldvisitor - package org.elasticsearch.index.fieldvisitor
- org.elasticsearch.index.flush - package org.elasticsearch.index.flush
- org.elasticsearch.index.get - package org.elasticsearch.index.get
- org.elasticsearch.index.mapper - package org.elasticsearch.index.mapper
- org.elasticsearch.index.merge - package org.elasticsearch.index.merge
- org.elasticsearch.index.query - package org.elasticsearch.index.query
- org.elasticsearch.index.query.functionscore - package org.elasticsearch.index.query.functionscore
- org.elasticsearch.index.query.support - package org.elasticsearch.index.query.support
- org.elasticsearch.index.recovery - package org.elasticsearch.index.recovery
- org.elasticsearch.index.refresh - package org.elasticsearch.index.refresh
- org.elasticsearch.index.reindex - package org.elasticsearch.index.reindex
- org.elasticsearch.index.search - package org.elasticsearch.index.search
- org.elasticsearch.index.search.stats - package org.elasticsearch.index.search.stats
- org.elasticsearch.index.seqno - package org.elasticsearch.index.seqno
- org.elasticsearch.index.shard - package org.elasticsearch.index.shard
- org.elasticsearch.index.similarity - package org.elasticsearch.index.similarity
- org.elasticsearch.index.snapshots - package org.elasticsearch.index.snapshots
- org.elasticsearch.index.snapshots.blobstore - package org.elasticsearch.index.snapshots.blobstore
- org.elasticsearch.index.store - package org.elasticsearch.index.store
- org.elasticsearch.index.termvectors - package org.elasticsearch.index.termvectors
- org.elasticsearch.index.translog - package org.elasticsearch.index.translog
- org.elasticsearch.index.warmer - package org.elasticsearch.index.warmer
- org.elasticsearch.indices - package org.elasticsearch.indices
- org.elasticsearch.indices.analysis - package org.elasticsearch.indices.analysis
- org.elasticsearch.indices.breaker - package org.elasticsearch.indices.breaker
- org.elasticsearch.indices.cluster - package org.elasticsearch.indices.cluster
- org.elasticsearch.indices.fielddata.cache - package org.elasticsearch.indices.fielddata.cache
- org.elasticsearch.indices.flush - package org.elasticsearch.indices.flush
- org.elasticsearch.indices.mapper - package org.elasticsearch.indices.mapper
- org.elasticsearch.indices.recovery - package org.elasticsearch.indices.recovery
- org.elasticsearch.indices.store - package org.elasticsearch.indices.store
- org.elasticsearch.ingest - package org.elasticsearch.ingest
- org.elasticsearch.monitor - package org.elasticsearch.monitor
-
Monitors the Elasticsearch process and the system on which it is running so that metrics can be exposed via an HTTP or transport APIs to be logged and graphed.
- org.elasticsearch.monitor.fs - package org.elasticsearch.monitor.fs
- org.elasticsearch.monitor.jvm - package org.elasticsearch.monitor.jvm
- org.elasticsearch.monitor.os - package org.elasticsearch.monitor.os
- org.elasticsearch.monitor.process - package org.elasticsearch.monitor.process
- org.elasticsearch.node - package org.elasticsearch.node
-
Allow to build a
Node
which is a node within the cluster. - org.elasticsearch.persistent - package org.elasticsearch.persistent
-
The Persistent Tasks Executors are responsible for executing restartable tasks that can survive disappearance of a coordinating and executor nodes.
- org.elasticsearch.persistent.decider - package org.elasticsearch.persistent.decider
- org.elasticsearch.plugins - package org.elasticsearch.plugins
-
Support for extending Elasticsearch by providing java code that is loaded by a child classloader.
- org.elasticsearch.plugins.spi - package org.elasticsearch.plugins.spi
-
This package contains interfaces for services provided by Elasticsearch plugins to external applications like the Java High Level Rest Client.
- org.elasticsearch.repositories - package org.elasticsearch.repositories
-
Repositories of snapshot/restore information.
- org.elasticsearch.repositories.blobstore - package org.elasticsearch.repositories.blobstore
- org.elasticsearch.repositories.fs - package org.elasticsearch.repositories.fs
- org.elasticsearch.rest - package org.elasticsearch.rest
-
Exposes Elasticsearch functionality over RESTful HTTP.
- org.elasticsearch.rest.action - package org.elasticsearch.rest.action
-
RestHandler
s that translate requests from REST into internal requests and start them then wait for them to complete and then translate them back into REST. - org.elasticsearch.rest.action.admin.cluster - package org.elasticsearch.rest.action.admin.cluster
-
RestHandler
s for administrative actions that can be taken on the cluster as a whole like getting the listing tasks, adding repositories, and getting stats. - org.elasticsearch.rest.action.admin.indices - package org.elasticsearch.rest.action.admin.indices
-
RestHandler
s for administrative actions that can be taken on indexes like creation, deletion, setting up aliases, and changing mapping. - org.elasticsearch.rest.action.cat - package org.elasticsearch.rest.action.cat
-
RestHandler
s for actions that spit out tables of results. - org.elasticsearch.rest.action.document - package org.elasticsearch.rest.action.document
-
RestHandler
s for actions that can be taken on documents like index, update, get, and delete. - org.elasticsearch.rest.action.ingest - package org.elasticsearch.rest.action.ingest
-
RestHandler
s that manage ingest pipelines. - org.elasticsearch.rest.action.search - package org.elasticsearch.rest.action.search
-
RestHandler
s for search actions like search, scroll, and suggest. - org.elasticsearch.script - package org.elasticsearch.script
-
Support for running user provided scripts (in the request, in cluster state, etc) in portions of various requests (
FunctionScoreQuery
,Aggregation
,UpdateAction
, etc). - org.elasticsearch.search - package org.elasticsearch.search
- org.elasticsearch.search.aggregations - package org.elasticsearch.search.aggregations
-
Builds analytic information over all hits in a search request.
- org.elasticsearch.search.aggregations.bucket - package org.elasticsearch.search.aggregations.bucket
- org.elasticsearch.search.aggregations.bucket.adjacency - package org.elasticsearch.search.aggregations.bucket.adjacency
- org.elasticsearch.search.aggregations.bucket.composite - package org.elasticsearch.search.aggregations.bucket.composite
- org.elasticsearch.search.aggregations.bucket.filter - package org.elasticsearch.search.aggregations.bucket.filter
- org.elasticsearch.search.aggregations.bucket.geogrid - package org.elasticsearch.search.aggregations.bucket.geogrid
- org.elasticsearch.search.aggregations.bucket.global - package org.elasticsearch.search.aggregations.bucket.global
- org.elasticsearch.search.aggregations.bucket.histogram - package org.elasticsearch.search.aggregations.bucket.histogram
-
Histogram module for different bucket specifications used in aggregation.
- org.elasticsearch.search.aggregations.bucket.missing - package org.elasticsearch.search.aggregations.bucket.missing
- org.elasticsearch.search.aggregations.bucket.nested - package org.elasticsearch.search.aggregations.bucket.nested
- org.elasticsearch.search.aggregations.bucket.range - package org.elasticsearch.search.aggregations.bucket.range
- org.elasticsearch.search.aggregations.bucket.sampler - package org.elasticsearch.search.aggregations.bucket.sampler
- org.elasticsearch.search.aggregations.bucket.significant - package org.elasticsearch.search.aggregations.bucket.significant
- org.elasticsearch.search.aggregations.bucket.significant.heuristics - package org.elasticsearch.search.aggregations.bucket.significant.heuristics
- org.elasticsearch.search.aggregations.bucket.terms - package org.elasticsearch.search.aggregations.bucket.terms
- org.elasticsearch.search.aggregations.metrics - package org.elasticsearch.search.aggregations.metrics
-
Aggregations module
- org.elasticsearch.search.aggregations.metrics.avg - package org.elasticsearch.search.aggregations.metrics.avg
- org.elasticsearch.search.aggregations.metrics.cardinality - package org.elasticsearch.search.aggregations.metrics.cardinality
- org.elasticsearch.search.aggregations.metrics.geobounds - package org.elasticsearch.search.aggregations.metrics.geobounds
- org.elasticsearch.search.aggregations.metrics.geocentroid - package org.elasticsearch.search.aggregations.metrics.geocentroid
- org.elasticsearch.search.aggregations.metrics.mad - package org.elasticsearch.search.aggregations.metrics.mad
- org.elasticsearch.search.aggregations.metrics.max - package org.elasticsearch.search.aggregations.metrics.max
- org.elasticsearch.search.aggregations.metrics.min - package org.elasticsearch.search.aggregations.metrics.min
- org.elasticsearch.search.aggregations.metrics.percentiles - package org.elasticsearch.search.aggregations.metrics.percentiles
- org.elasticsearch.search.aggregations.metrics.percentiles.hdr - package org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- org.elasticsearch.search.aggregations.metrics.percentiles.tdigest - package org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- org.elasticsearch.search.aggregations.metrics.scripted - package org.elasticsearch.search.aggregations.metrics.scripted
- org.elasticsearch.search.aggregations.metrics.stats - package org.elasticsearch.search.aggregations.metrics.stats
- org.elasticsearch.search.aggregations.metrics.stats.extended - package org.elasticsearch.search.aggregations.metrics.stats.extended
- org.elasticsearch.search.aggregations.metrics.sum - package org.elasticsearch.search.aggregations.metrics.sum
- org.elasticsearch.search.aggregations.metrics.tophits - package org.elasticsearch.search.aggregations.metrics.tophits
- org.elasticsearch.search.aggregations.metrics.valuecount - package org.elasticsearch.search.aggregations.metrics.valuecount
- org.elasticsearch.search.aggregations.metrics.weighted_avg - package org.elasticsearch.search.aggregations.metrics.weighted_avg
- org.elasticsearch.search.aggregations.pipeline - package org.elasticsearch.search.aggregations.pipeline
- org.elasticsearch.search.aggregations.pipeline.bucketmetrics - package org.elasticsearch.search.aggregations.pipeline.bucketmetrics
- org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg - package org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg
- org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max - package org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max
- org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min - package org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min
- org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile - package org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
- org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats - package org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
- org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended - package org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended
- org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum - package org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum
- org.elasticsearch.search.aggregations.pipeline.bucketscript - package org.elasticsearch.search.aggregations.pipeline.bucketscript
- org.elasticsearch.search.aggregations.pipeline.bucketselector - package org.elasticsearch.search.aggregations.pipeline.bucketselector
- org.elasticsearch.search.aggregations.pipeline.bucketsort - package org.elasticsearch.search.aggregations.pipeline.bucketsort
- org.elasticsearch.search.aggregations.pipeline.cumulativesum - package org.elasticsearch.search.aggregations.pipeline.cumulativesum
- org.elasticsearch.search.aggregations.pipeline.derivative - package org.elasticsearch.search.aggregations.pipeline.derivative
- org.elasticsearch.search.aggregations.pipeline.movavg - package org.elasticsearch.search.aggregations.pipeline.movavg
- org.elasticsearch.search.aggregations.pipeline.movavg.models - package org.elasticsearch.search.aggregations.pipeline.movavg.models
- org.elasticsearch.search.aggregations.pipeline.movfn - package org.elasticsearch.search.aggregations.pipeline.movfn
- org.elasticsearch.search.aggregations.pipeline.serialdiff - package org.elasticsearch.search.aggregations.pipeline.serialdiff
- org.elasticsearch.search.aggregations.support - package org.elasticsearch.search.aggregations.support
- org.elasticsearch.search.aggregations.support.values - package org.elasticsearch.search.aggregations.support.values
- org.elasticsearch.search.builder - package org.elasticsearch.search.builder
- org.elasticsearch.search.collapse - package org.elasticsearch.search.collapse
- org.elasticsearch.search.dfs - package org.elasticsearch.search.dfs
- org.elasticsearch.search.fetch - package org.elasticsearch.search.fetch
-
Search phase that fetches the top hits from the shards after the results of the query phase have been merged.
- org.elasticsearch.search.fetch.subphase - package org.elasticsearch.search.fetch.subphase
-
Built in
FetchSubPhase
s like matched queries and fetching_source
. - org.elasticsearch.search.fetch.subphase.highlight - package org.elasticsearch.search.fetch.subphase.highlight
-
Fetch sub phase that extracts significant portions of string fields, marking the matches.
- org.elasticsearch.search.internal - package org.elasticsearch.search.internal
- org.elasticsearch.search.lookup - package org.elasticsearch.search.lookup
- org.elasticsearch.search.profile - package org.elasticsearch.search.profile
-
Profiling for portions of the search request.
- org.elasticsearch.search.profile.aggregation - package org.elasticsearch.search.profile.aggregation
-
Profiles the aggregation portion of a search request.
- org.elasticsearch.search.profile.query - package org.elasticsearch.search.profile.query
-
Profiles the query portion of a search request.
- org.elasticsearch.search.query - package org.elasticsearch.search.query
- org.elasticsearch.search.rescore - package org.elasticsearch.search.rescore
- org.elasticsearch.search.searchafter - package org.elasticsearch.search.searchafter
- org.elasticsearch.search.slice - package org.elasticsearch.search.slice
- org.elasticsearch.search.sort - package org.elasticsearch.search.sort
- org.elasticsearch.search.suggest - package org.elasticsearch.search.suggest
-
Support for suggesting alternate queries.
- org.elasticsearch.search.suggest.completion - package org.elasticsearch.search.suggest.completion
-
Suggests alternate queries by fancy prefix matching.
- org.elasticsearch.search.suggest.completion.context - package org.elasticsearch.search.suggest.completion.context
-
Support for limiting the completion suggesters results to within a "context" like a geographic location or a category.
- org.elasticsearch.search.suggest.phrase - package org.elasticsearch.search.suggest.phrase
-
Suggests alternate queries by breaking the query into terms and suggesting terms that are frequently found together.
- org.elasticsearch.search.suggest.term - package org.elasticsearch.search.suggest.term
-
Suggests alternate queries by breaking the query into terms and suggesting more popular terms.
- org.elasticsearch.snapshots - package org.elasticsearch.snapshots
- org.elasticsearch.tasks - package org.elasticsearch.tasks
-
Support for viewing and modifying in flight actions (
Task
s) and saving their results to an index. - org.elasticsearch.threadpool - package org.elasticsearch.threadpool
- org.elasticsearch.transport - package org.elasticsearch.transport
- org.elasticsearch.usage - package org.elasticsearch.usage
- org.elasticsearch.watcher - package org.elasticsearch.watcher
- org.joda.time.format - package org.joda.time.format
- orientation - Variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- orientation - Variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- orientation() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- orientation() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- orientation() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- orientation() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- orientation() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- orientation(ShapeBuilder.Orientation) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- ORIENTATION - Static variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Defaults
- ORIENTATION - Static variable in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Names
- origin() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- origin() - Method in class org.elasticsearch.index.engine.Engine.Operation
- origin() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Return the
GeoPoint
that is used for distance computations. - origin(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- ORIGIN - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- originalIndices - Variable in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- OriginalIndices - Class in org.elasticsearch.action
-
Used to keep track of original indices within internal (e.g.
- OriginalIndices(String[], IndicesOptions) - Constructor for class org.elasticsearch.action.OriginalIndices
- OriginalIndices(IndicesRequest) - Constructor for class org.elasticsearch.action.OriginalIndices
- originalMessage() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- originalTerm - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- OriginSettingClient - Class in org.elasticsearch.client
-
A Client that sends requests with the
origin
set to a particular value and calls its ActionListener in its originalThreadContext
. - OriginSettingClient(Client, String) - Constructor for class org.elasticsearch.client.OriginSettingClient
- os() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node OS be returned.
- os() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node OS be returned.
- os(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node OS be returned.
- os(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node OS be returned.
- OsInfo - Class in org.elasticsearch.monitor.os
- OsInfo(long, int, int, String, String, String, String) - Constructor for class org.elasticsearch.monitor.os.OsInfo
- OsInfo(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsInfo
- OsProbe - Class in org.elasticsearch.monitor.os
-
The
OsProbe
class retrieves information about the physical and swap size of the machine memory, as well as the system load average and cpu load. - OSS - org.elasticsearch.Build.Flavor
- osService() - Method in class org.elasticsearch.monitor.MonitorService
- OsService - Class in org.elasticsearch.monitor.os
- OsService(Settings) - Constructor for class org.elasticsearch.monitor.os.OsService
- osStats() - Method in class org.elasticsearch.monitor.os.OsProbe
- OsStats - Class in org.elasticsearch.monitor.os
- OsStats(long, OsStats.Cpu, OsStats.Mem, OsStats.Swap, OsStats.Cgroup) - Constructor for class org.elasticsearch.monitor.os.OsStats
- OsStats(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsStats
- OsStats.Cgroup - Class in org.elasticsearch.monitor.os
-
Encapsulates basic cgroup statistics.
- OsStats.Cgroup.CpuStat - Class in org.elasticsearch.monitor.os
-
Encapsulates CPU time statistics.
- OsStats.Cpu - Class in org.elasticsearch.monitor.os
- OsStats.Mem - Class in org.elasticsearch.monitor.os
- OsStats.Swap - Class in org.elasticsearch.monitor.os
- OTHER_BUCKET_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- OTHER_BUCKET_KEY_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- otherBucket() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Get whether to include a bucket for documents not matching any filter
- otherBucket(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Set whether to include a bucket for documents not matching any filter
- otherBucketKey() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Get the key to use for the bucket for documents not matching any filter.
- otherBucketKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Set the key to use for the bucket for documents not matching any filter.
- otherDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- otherStatsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- otherStatsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- otherStatsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- otherStatsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- out - Variable in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- OutOfScopeException - Exception in org.elasticsearch.common.inject
-
Thrown from
Provider.get()
when an attempt is made to access a scoped object while the scope in question is not currently active. - OutOfScopeException(String) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
- OutOfScopeException(String, Throwable) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
- OutOfScopeException(Throwable) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
- OutputStreamStreamOutput - Class in org.elasticsearch.common.io.stream
- OutputStreamStreamOutput(OutputStream) - Constructor for class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- overallState(RestoreInProgress.State, ImmutableOpenMap<ShardId, RestoreInProgress.ShardRestoreStatus>) - Static method in class org.elasticsearch.snapshots.RestoreService
- overriddenOperations() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
-
The number of operations have been overridden (eg.
- override(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.util.Modules
-
Returns a builder that creates a module that overlays override modules over the given modules.
- override(Module...) - Static method in class org.elasticsearch.common.inject.util.Modules
-
Returns a builder that creates a module that overlays override modules over the given modules.
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- overridePath(ContentPath) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that will have the provided path.
- overSize(long) - Static method in class org.elasticsearch.common.util.BigArrays
-
Returns the next size to grow when working with parallel arrays that may have different page sizes or number of bytes per element.
- overSize(long, int, int) - Static method in class org.elasticsearch.common.util.BigArrays
-
Return the next size to grow to that is >=
minTargetSize
.
P
- pad(boolean) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
- pad(Table.Cell, int, RestRequest, UTF8StreamWriter) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- pad(Table.Cell, int, RestRequest, UTF8StreamWriter, boolean) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- padStart(String, int, char) - Static method in class org.elasticsearch.common.Strings
- PAGE_SIZE_IN_BYTES - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
-
Page size in bytes: 16KB
- pageCacheRecycler - Variable in class org.elasticsearch.transport.TcpTransport
- PageCacheRecycler - Class in org.elasticsearch.common.util
-
A recycler of fixed-size pages.
- PageCacheRecycler(Settings) - Constructor for class org.elasticsearch.common.util.PageCacheRecycler
- PageCacheRecycler.Type - Enum in org.elasticsearch.common.util
- PagedBytesAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
- PagedBytesAtomicFieldData(PagedBytes.Reader, PackedLongValues, Ordinals) - Constructor for class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
- PagedBytesIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- PagedBytesIndexFieldData(IndexSettings, String, IndexFieldDataCache, CircuitBreakerService, double, double, int) - Constructor for class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData
- PagedBytesIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- PagedBytesIndexFieldData.PagedBytesEstimator - Class in org.elasticsearch.index.fielddata.plain
-
Estimator that wraps string field data by either using BlockTreeTermsReader, or wrapping the data in a RamAccountingTermsEnum if the BlockTreeTermsReader cannot be used.
- PagedBytesReference - Class in org.elasticsearch.common.bytes
-
A page based bytes reference, internally holding the bytes in a paged data structure.
- PagedBytesReference(ByteArray, int) - Constructor for class org.elasticsearch.common.bytes.PagedBytesReference
- PARAGRAPH_SEPARATOR - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils
- param(String) - Method in class org.elasticsearch.rest.RestRequest
- param(String, String) - Method in class org.elasticsearch.rest.RestRequest
- paramAsBoolean(String, boolean) - Method in class org.elasticsearch.rest.RestRequest
- paramAsBoolean(String, Boolean) - Method in class org.elasticsearch.rest.RestRequest
- paramAsFloat(String, float) - Method in class org.elasticsearch.rest.RestRequest
- paramAsInt(String, int) - Method in class org.elasticsearch.rest.RestRequest
- paramAsLong(String, long) - Method in class org.elasticsearch.rest.RestRequest
- paramAsSize(String, ByteSizeValue) - Method in class org.elasticsearch.rest.RestRequest
- paramAsStringArray(String, String[]) - Method in class org.elasticsearch.rest.RestRequest
- paramAsStringArrayOrEmptyIfAll(String) - Method in class org.elasticsearch.rest.RestRequest
- paramAsTime(String, TimeValue) - Method in class org.elasticsearch.rest.RestRequest
- ParameterizedTypeImpl(Type, Type, Type...) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- Parameters(Environment, ScriptService, AnalysisRegistry, ThreadContext, LongSupplier, BiFunction<Long, Runnable, ScheduledFuture<?>>, IngestService) - Constructor for class org.elasticsearch.ingest.Processor.Parameters
- PARAMETERS - Static variable in class org.elasticsearch.script.BucketAggregationScript
- PARAMETERS - Static variable in class org.elasticsearch.script.BucketAggregationSelectorScript
- PARAMETERS - Static variable in class org.elasticsearch.script.FilterScript
- PARAMETERS - Static variable in class org.elasticsearch.script.IngestConditionalScript
- PARAMETERS - Static variable in class org.elasticsearch.script.IngestScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScoreScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- PARAMETERS - Static variable in class org.elasticsearch.script.SignificantTermsHeuristicScoreScript
- PARAMETERS - Static variable in class org.elasticsearch.script.SimilarityScript
- PARAMETERS - Static variable in class org.elasticsearch.script.SimilarityWeightScript
- PARAMETERS - Static variable in class org.elasticsearch.script.TemplateScript
- PARAMETERS - Static variable in class org.elasticsearch.script.TermsSetQueryScript
- PARAMETERS - Static variable in class org.elasticsearch.script.UpdateScript
- PARAMETERS - Static variable in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctionScript
- params() - Method in class org.elasticsearch.rest.RestRequest
- params() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Get parameters that will be available in the
init
,map
andcombine
phases. - params(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Set parameters that will be available in the
init
,map
andcombine
phases. - PARAMS_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for params on the inner level. - parent - Variable in class org.elasticsearch.index.translog.Translog.Source
- parent - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- parent - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
- parent() - Method in class org.elasticsearch.action.delete.DeleteRequest
- parent() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the parent for this request
- parent() - Method in class org.elasticsearch.action.get.GetRequest
- parent() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- parent() - Method in class org.elasticsearch.action.index.IndexRequest
- parent() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- parent() - Method in class org.elasticsearch.action.update.UpdateRequest
- parent() - Method in class org.elasticsearch.index.engine.Engine.Index
- parent() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- parent() - Method in class org.elasticsearch.index.mapper.SourceToParse
- parent() - Method in class org.elasticsearch.index.translog.Translog.Index
- parent() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Return the parent aggregator.
- parent() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- parent() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- parent() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- parent() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- parent(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Sets the parent id of this document.
- parent(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
-
Simple sets the routing.
- parent(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the parent id of this document.
- parent(String) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- parent(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the parent id of this document.
- parent(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets the parent id of this document.
- parent(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
The parent id is used for the upsert request.
- parent(String) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- parent(String) - Method in class org.elasticsearch.index.mapper.SourceToParse
- PARENT - org.elasticsearch.common.breaker.CircuitBreaker.Type
- PARENT - org.elasticsearch.ingest.IngestDocument.MetaData
- PARENT - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- PARENT - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The parent breaker is a sum of all the following breakers combined.
- parentFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- ParentFieldMapper - Class in org.elasticsearch.index.mapper
- ParentFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- ParentFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- ParentFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- ParentFieldSubFetchPhase - Class in org.elasticsearch.search.fetch.subphase
- ParentFieldSubFetchPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.ParentFieldSubFetchPhase
- parentObjectMapperAreNested(MapperService) - Method in class org.elasticsearch.index.mapper.ObjectMapper
-
Returns whether all parent objects fields are nested too.
- parentSearchContext() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- ParentTaskAssigningClient - Class in org.elasticsearch.client
-
A Client that sets the parent task on all requests that it makes.
- ParentTaskAssigningClient(Client, DiscoveryNode, Task) - Constructor for class org.elasticsearch.client.ParentTaskAssigningClient
-
Convenience constructor for building the TaskId out of what is usually at hand.
- ParentTaskAssigningClient(Client, TaskId) - Constructor for class org.elasticsearch.client.ParentTaskAssigningClient
-
Standard constructor.
- parse(Object, boolean) - Method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- parse(Object, boolean) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- parse(String) - Static method in enum org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Parse the string representation of a refresh policy, usually from a request parameter.
- parse(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- parse(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- parse(String) - Static method in enum org.elasticsearch.cluster.routing.Preference
-
Parses the Preference Type given a string
- parse(String) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
-
Try to parse input to a java time TemporalAccessor using joda-time library.
- parse(String) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Try to parse input to a java time TemporalAccessor
- parse(String) - Static method in class org.elasticsearch.common.util.LocaleUtils
-
Parse the given locale as
language
,language-country
orlanguage-country-variant
. - parse(String) - Static method in enum org.elasticsearch.common.util.PageCacheRecycler.Type
- parse(String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- parse(String) - Static method in enum org.elasticsearch.index.SlowLogLevel
- parse(String) - Static method in enum org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.SeasonalityType
-
Parse a string SeasonalityType into the byte enum
- parse(String) - Static method in class org.elasticsearch.search.aggregations.support.AggregationPath
- parse(String, String, Object, LegacyGeoShapeFieldMapper.DeprecatedParameters) - Static method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- parse(String, LongSupplier) - Method in interface org.elasticsearch.common.time.DateMathParser
-
Parse a date math expression without timzeone info and rounding down.
- parse(String, LongSupplier, boolean, ZoneId) - Method in class org.elasticsearch.common.joda.JodaDateMathParser
- parse(String, LongSupplier, boolean, ZoneId) - Method in interface org.elasticsearch.common.time.DateMathParser
-
Parse text, that potentially contains date math into the milliseconds since the epoch Examples are
2014-11-18||-2y
subtracts two years from the input datenow/m
rounds the current time to minute granularity Supported rounding units are y year M month w week (beginning on a monday) d day h/H hour m minute s second - parse(String, LongSupplier, boolean, ZoneId) - Method in class org.elasticsearch.common.time.JavaDateMathParser
- parse(String, LongSupplier, boolean, DateTimeZone) - Method in interface org.elasticsearch.common.time.DateMathParser
-
Deprecated.
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.AllFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.IdFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in interface org.elasticsearch.index.mapper.Mapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in interface org.elasticsearch.index.mapper.MetadataFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.UidFieldMapper.TypeParser
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper.TypeParser
- parse(String, Map<String, Object>, Version) - Static method in class org.elasticsearch.index.mapper.DynamicTemplate
- parse(String, CompressedXContent) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
- parse(String, CompressedXContent, boolean) - Method in class org.elasticsearch.index.mapper.MapperService
- parse(String, CompressedXContent, String) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
- parse(String, DistanceUnit) - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Parses a given distance and converts it to this unit.
- parse(String, DistanceUnit, DistanceUnit) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
-
Parses a given distance and converts it to the specified unit.
- parse(String, DeprecationHandler) - Static method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- parse(String, DeprecationHandler) - Static method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- parse(String, XContentLocation) - Static method in enum org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Parse a string GapPolicy into the byte enum
- parse(String, XContentParser) - Method in interface org.elasticsearch.search.aggregations.Aggregator.Parser
-
Returns the aggregator factory with which this parser is associated, may return
null
indicating the aggregation should be skipped (e.g. - parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- parse(String, XContentParser) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsParser
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
- parse(String, XContentParser) - Method in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
-
Returns the pipeline aggregator factory with which this parser is associated.
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- parse(Map<String, Object>, String, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel.AbstractModelParser
-
Parse a settings hash that is specific to this model
- parse(BytesReference, XContentType) - Static method in class org.elasticsearch.script.StoredScriptSource
-
This will parse XContent into a
StoredScriptSource
. - parse(Settings) - Static method in class org.elasticsearch.script.Script
-
Parse the script configured in the given settings.
- parse(ParseFieldRegistry<MovAvgModel.AbstractModelParser>, String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- parse(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- parse(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- parse(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand.Builder
- parse(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand.Builder
- parse(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand.Builder
- parse(XContentParser) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
Deprecated.this method will be removed in a future version; use ShapeParser.parse instead
- parse(XContentParser) - Static method in interface org.elasticsearch.common.geo.parsers.ShapeParser
-
Create a new
ShapeBuilder
fromXContent
- parse(XContentParser) - Static method in class org.elasticsearch.common.unit.Fuzziness
- parse(XContentParser) - Static method in class org.elasticsearch.script.Script
-
Convenience method to call
Script.parse(XContentParser, String)
using the default scripting language. - parse(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
- parse(XContentParser) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYParser
- parse(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- parse(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- parse(XContentParser) - Method in interface org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicParser
- parse(XContentParser, boolean) - Method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- parse(XContentParser, String) - Static method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- parse(XContentParser, String) - Static method in class org.elasticsearch.script.Script
-
This will parse XContent into a
Script
. - parse(XContentParser, BaseGeoShapeFieldMapper) - Static method in class org.elasticsearch.common.geo.parsers.GeoWKTParser
- parse(XContentParser, BaseGeoShapeFieldMapper) - Static method in interface org.elasticsearch.common.geo.parsers.ShapeParser
-
Create a new
ShapeBuilder
fromXContent
- parse(XContentParser, MoreLikeThisQueryBuilder.Item) - Static method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Parses and returns the given item.
- parse(FieldMapper, ParseContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.AllFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
-
Parses and indexes inputs Parsing: Acceptable format: "STRING" - interpreted as field value (input) "ARRAY" - each element can be one of "OBJECT" (see below) "OBJECT" - { "input": STRING|ARRAY, "weight": STRING|INT, "contexts": ARRAY|OBJECT } Indexing: if context mappings are defined, delegates to
ContextMappings.addField(ParseContext.Document, String, String, int, Map)
else adds inputs as aSuggestField
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Parse the field value using the provided
ParseContext
. - parse(ParseContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
-
parsing logic for
LatLonShape
indexing - parse(ParseContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper
-
Deprecated.
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.UidFieldMapper
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- parse(ParseContext, GeoPoint) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- parse(SourceToParse) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- parse(MultiMatchQueryBuilder.Type, Map<String, Float>, Object, String) - Method in class org.elasticsearch.index.search.MultiMatchQuery
- parse(MatchQuery.Type, String, Object) - Method in class org.elasticsearch.index.search.MatchQuery
- parse5x(String) - Static method in class org.elasticsearch.common.util.LocaleUtils
-
Deprecated.
- parseAggregators(XContentParser) - Static method in class org.elasticsearch.search.aggregations.AggregatorFactories
-
Parses the aggregation request recursively generating aggregator factories in turn.
- parseAliasFilter(CheckedFunction<byte[], QueryBuilder, IOException>, IndexMetaData, String...) - Static method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the filter associated with listed filtering aliases.
- parseAnalysisVersion(Settings, Settings, Logger) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseArticles(Environment, Version, Settings) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseBoolParam(Map<String, Object>, String, boolean) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel.AbstractModelParser
-
Extracts a boolean from the settings map, otherwise throws an exception
- parseBoundingBox(XContentParser) - Static method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Parses the bounding box and returns bottom, top, left, right coordinates
- parseByteSize(String, ByteSizeValue, ByteSizeValue, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseBytesRef(String) - Method in interface org.elasticsearch.search.DocValueFormat
-
Parse a value that was formatted with
DocValueFormat.format(BytesRef)
back to the original BytesRef. - parseBytesSizeValue(String, String) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- parseBytesSizeValue(String, ByteSizeValue, String) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- parseBytesSizeValueOrHeapRatio(String, String) - Static method in enum org.elasticsearch.common.unit.MemorySizeValue
-
Parse the provided string as a memory size.
- parseCidr(String) - Static method in class org.elasticsearch.common.network.InetAddresses
-
Parse an IP address and its prefix length using the CIDR notation.
- parseCommonWords(Environment, Settings, CharArraySet, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseContentType(List<String>) - Static method in class org.elasticsearch.rest.RestRequest
-
Parses the given content type string for the media type.
- parseContext(ParseContext.Document) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
- parseContext(ParseContext.Document) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Retrieves a set of context from a
document
at index-time. - parseContext(ParseContext.Document) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- parseContext(ParseContext, XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
-
Parse a set of
CharSequence
contexts at index-time. - parseContext(ParseContext, XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Parses a set of index-time contexts.
- parseContext(ParseContext, XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
-
Parse a set of
CharSequence
contexts at index-time. - ParseContext - Class in org.elasticsearch.index.mapper
- ParseContext() - Constructor for class org.elasticsearch.index.mapper.ParseContext
- ParseContext.Document - Class in org.elasticsearch.index.mapper
-
Fork of
Document
with additional functionality. - ParseContext.InternalParseContext - Class in org.elasticsearch.index.mapper
- parseCopyFields(Object, FieldMapper.Builder) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.AllFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Parse the field value and populate
fields
. - parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.IdFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.UidFieldMapper
- parseCreateField(ParseContext, List<IndexableField>) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- ParsedAdjacencyMatrix - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- ParsedAdjacencyMatrix() - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix
- ParsedAdjacencyMatrix.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- ParsedAggregation - Class in org.elasticsearch.search.aggregations
-
An implementation of
Aggregation
that is parsed from a REST response. - ParsedAggregation() - Constructor for class org.elasticsearch.search.aggregations.ParsedAggregation
- parseDateTimeFormatter(Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- ParsedAutoDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedAutoDateHistogram() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- ParsedAutoDateHistogram.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedAvg - Class in org.elasticsearch.search.aggregations.metrics.avg
- ParsedAvg() - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.ParsedAvg
- ParsedBinaryRange - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedBinaryRange() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange
- ParsedBinaryRange.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedGeoDistance.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantLongTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantStringTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- ParsedBucketMetricValue - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics
- ParsedBucketMetricValue() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.ParsedBucketMetricValue
- ParsedCardinality - Class in org.elasticsearch.search.aggregations.metrics.cardinality
- ParsedCardinality() - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.ParsedCardinality
- ParsedComposite - Class in org.elasticsearch.search.aggregations.bucket.composite
- ParsedComposite() - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- ParsedComposite.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.composite
- ParsedDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedDateHistogram() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram
- ParsedDateHistogram.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedDateRange - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedDateRange() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange
- ParsedDateRange.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedDerivative - Class in org.elasticsearch.search.aggregations.pipeline.derivative
- ParsedDerivative() - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.ParsedDerivative
- parsedDoc() - Method in class org.elasticsearch.index.engine.Engine.Index
- ParsedDocument - Class in org.elasticsearch.index.mapper
-
The result of parsing a document.
- ParsedDocument(Field, SeqNoFieldMapper.SequenceIDFields, String, String, String, List<ParseContext.Document>, BytesReference, XContentType, Mapping) - Constructor for class org.elasticsearch.index.mapper.ParsedDocument
- ParsedDoubleTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedDoubleTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms
- ParsedDoubleTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedExtendedStats - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
- ParsedExtendedStats() - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- ParsedExtendedStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended
- ParsedExtendedStatsBucket() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ParsedExtendedStatsBucket
- ParsedFilter - Class in org.elasticsearch.search.aggregations.bucket.filter
- ParsedFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilter
- ParsedFilters - Class in org.elasticsearch.search.aggregations.bucket.filter
- ParsedFilters() - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters
- ParsedFilters.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.filter
- ParsedGeoBounds - Class in org.elasticsearch.search.aggregations.metrics.geobounds
- ParsedGeoBounds() - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.ParsedGeoBounds
- ParsedGeoCentroid - Class in org.elasticsearch.search.aggregations.metrics.geocentroid
-
Serialization and merge logic for
GeoCentroidAggregator
. - ParsedGeoCentroid() - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.ParsedGeoCentroid
- ParsedGeoDistance - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedGeoDistance() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedGeoDistance
- ParsedGeoDistance.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedGeoHashGrid - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- ParsedGeoHashGrid() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid
- ParsedGeoHashGrid.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- ParsedGlobal - Class in org.elasticsearch.search.aggregations.bucket.global
- ParsedGlobal() - Constructor for class org.elasticsearch.search.aggregations.bucket.global.ParsedGlobal
- ParsedHDRPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- ParsedHDRPercentileRanks() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentileRanks
- ParsedHDRPercentiles - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
- ParsedHDRPercentiles() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentiles
- ParsedHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedHistogram() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedHistogram
- parseDistance(String) - Static method in class org.elasticsearch.common.unit.DistanceUnit.Distance
-
Parse a
DistanceUnit.Distance
from a given String. - ParsedLongTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedLongTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms
- ParsedLongTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- parsedMatchAllQuery() - Static method in class org.elasticsearch.index.query.ParsedQuery
- ParsedMax - Class in org.elasticsearch.search.aggregations.metrics.max
- ParsedMax() - Constructor for class org.elasticsearch.search.aggregations.metrics.max.ParsedMax
- ParsedMedianAbsoluteDeviation - Class in org.elasticsearch.search.aggregations.metrics.mad
- ParsedMedianAbsoluteDeviation() - Constructor for class org.elasticsearch.search.aggregations.metrics.mad.ParsedMedianAbsoluteDeviation
- ParsedMin - Class in org.elasticsearch.search.aggregations.metrics.min
- ParsedMin() - Constructor for class org.elasticsearch.search.aggregations.metrics.min.ParsedMin
- ParsedMissing - Class in org.elasticsearch.search.aggregations.bucket.missing
- ParsedMissing() - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.ParsedMissing
- ParsedMultiBucketAggregation<B extends MultiBucketsAggregation.Bucket> - Class in org.elasticsearch.search.aggregations
- ParsedMultiBucketAggregation() - Constructor for class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- ParsedMultiBucketAggregation.ParsedBucket - Class in org.elasticsearch.search.aggregations
- ParsedNested - Class in org.elasticsearch.search.aggregations.bucket.nested
- ParsedNested() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ParsedNested
- parseDouble(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- parseDouble(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- parseDouble(String, boolean, LongSupplier) - Method in interface org.elasticsearch.search.DocValueFormat
-
Parse a value that was formatted with
DocValueFormat.format(double)
back to the original double value. - parseDouble(XContentParser, double) - Static method in class org.elasticsearch.search.aggregations.ParsedAggregation
-
Parse a token of type XContentParser.Token.VALUE_NUMBER or XContentParser.Token.STRING to a double.
- parseDoubleParam(Map<String, Object>, String, double) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel.AbstractModelParser
-
Extracts a 0-1 inclusive double from the settings map, otherwise throws an exception
- ParsedPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics.percentiles
- ParsedPercentileRanks() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentileRanks
- ParsedPercentiles - Class in org.elasticsearch.search.aggregations.metrics.percentiles
- ParsedPercentiles() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentiles
- ParsedPercentilesBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
- ParsedPercentilesBucket() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.ParsedPercentilesBucket
- parsedPostFilter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- parsedPostFilter() - Method in class org.elasticsearch.search.internal.SearchContext
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.SearchContext
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.SubSearchContext
- parsedQuery() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- parsedQuery() - Method in class org.elasticsearch.search.internal.SearchContext
- parsedQuery() - Method in class org.elasticsearch.search.internal.SubSearchContext
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.SearchContext
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.SubSearchContext
- ParsedQuery - Class in org.elasticsearch.index.query
-
The result of parsing a query.
- ParsedQuery(Query) - Constructor for class org.elasticsearch.index.query.ParsedQuery
- ParsedQuery(Query, Map<String, Query>) - Constructor for class org.elasticsearch.index.query.ParsedQuery
-
Store the query and filters.
- ParsedQuery(Query, ParsedQuery) - Constructor for class org.elasticsearch.index.query.ParsedQuery
- ParsedRange - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedRange() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedRange
- ParsedRange.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedReverseNested - Class in org.elasticsearch.search.aggregations.bucket.nested
- ParsedReverseNested() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ParsedReverseNested
- ParsedSampler - Class in org.elasticsearch.search.aggregations.bucket.sampler
- ParsedSampler() - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.ParsedSampler
- ParsedScriptedMetric - Class in org.elasticsearch.search.aggregations.metrics.scripted
- ParsedScriptedMetric() - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ParsedScriptedMetric
- ParsedSignificantLongTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
- ParsedSignificantLongTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantLongTerms
- ParsedSignificantLongTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.significant
- ParsedSignificantStringTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
- ParsedSignificantStringTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantStringTerms
- ParsedSignificantStringTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.significant
- ParsedSignificantTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
- ParsedSignificantTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- ParsedSignificantTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.significant
- ParsedSimpleValue - Class in org.elasticsearch.search.aggregations.pipeline
- ParsedSimpleValue() - Constructor for class org.elasticsearch.search.aggregations.pipeline.ParsedSimpleValue
- ParsedSingleBucketAggregation - Class in org.elasticsearch.search.aggregations.bucket
-
A base class for all the single bucket aggregations.
- ParsedSingleBucketAggregation() - Constructor for class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- ParsedSingleValueNumericMetricsAggregation - Class in org.elasticsearch.search.aggregations.metrics
- ParsedSingleValueNumericMetricsAggregation() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- ParsedStats - Class in org.elasticsearch.search.aggregations.metrics.stats
- ParsedStats() - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- ParsedStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
- ParsedStatsBucket() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.ParsedStatsBucket
- ParsedStringTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedStringTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms
- ParsedStringTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedSum - Class in org.elasticsearch.search.aggregations.metrics.sum
- ParsedSum() - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.ParsedSum
- ParsedTDigestPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- ParsedTDigestPercentileRanks() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentileRanks
- ParsedTDigestPercentiles - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- ParsedTDigestPercentiles() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentiles
- ParsedTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- ParsedTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedTopHits - Class in org.elasticsearch.search.aggregations.metrics.tophits
- ParsedTopHits() - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.ParsedTopHits
- ParsedValueCount - Class in org.elasticsearch.search.aggregations.metrics.valuecount
- ParsedValueCount() - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ParsedValueCount
- ParsedWeightedAvg - Class in org.elasticsearch.search.aggregations.metrics.weighted_avg
- ParsedWeightedAvg() - Constructor for class org.elasticsearch.search.aggregations.metrics.weighted_avg.ParsedWeightedAvg
- parseEntries(XContentParser, Suggest.Suggestion<E>, CheckedFunction<XContentParser, E, IOException>) - Static method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- parseExclude(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- parseExpectedType(XContentParser, GeoShapeType) - Static method in class org.elasticsearch.common.geo.parsers.GeoWKTParser
- parseExpectedType(XContentParser, GeoShapeType, BaseGeoShapeFieldMapper) - Static method in class org.elasticsearch.common.geo.parsers.GeoWKTParser
-
throws an exception if the parsed geometry type does not match the expected shape type
- parseExternalValue(Class<T>) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Try to parse an externalValue if any
- parseField() - Method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- parseField() - Method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- parseField(FieldMapper.Builder, String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.TypeParsers
-
Parse common field attributes such as
doc_values
orstore
. - ParseFieldRegistry<T> - Class in org.elasticsearch.common.xcontent
-
Registry for looking things up using ParseField semantics.
- ParseFieldRegistry(String) - Constructor for class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Build the registry.
- parseFields(XContentParser) - Static method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- parseFieldsAndWeights(List<String>) - Static method in class org.elasticsearch.index.search.QueryParserHelper
-
Convert a list of field names encoded with optional boosts to a map that associates the field name and its boost.
- parseFieldsValue(XContentParser) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
-
Parse the current token depending on its token type.
- parseFrom(RangeFieldMapper.RangeFieldType, XContentParser, boolean, boolean) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
-
parses from value.
- parseFromLatLon(String) - Static method in class org.elasticsearch.common.geo.GeoPoint
- parseFromRestRequest(RestRequest) - Static method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- parseFromXContent(XContentParser) - Static method in class org.elasticsearch.search.rescore.RescorerBuilder
- parseGeoPoint(Object, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parses the value as a geopoint.
- parseGeoPoint(XContentParser) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parse a
GeoPoint
with aXContentParser
: - parseGeoPoint(XContentParser, GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
- parseGeoPoint(XContentParser, GeoPoint, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parse a
GeoPoint
with aXContentParser
. - parseHostPort(String) - Static method in class org.elasticsearch.transport.RemoteClusterAware
- parseIdFromFileName(Path) - Static method in class org.elasticsearch.index.translog.Translog
-
Extracts the translog generation from a file name.
- parseIds(XContentParser, List<MultiGetRequest.Item>) - Static method in class org.elasticsearch.action.get.MultiGetRequest
- parseIds(XContentParser, List<MultiGetRequest.Item>, String, String, String[], FetchSourceContext, String) - Static method in class org.elasticsearch.action.get.MultiGetRequest
- parseInclude(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- parseInnerQueryBuilder(XContentParser) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Parses a query excluding the query element that wraps it
- parseInnerQueryBuilder(XContentParser) - Method in class org.elasticsearch.index.query.QueryShardContext
- parseInnerToXContent(XContentParser, DocWriteResponse.Builder) - Static method in class org.elasticsearch.action.DocWriteResponse
-
Parse the output of the
DocWriteResponse.innerToXContent(XContentBuilder, Params)
method. - parseInt(String, int, int, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseInt(String, int, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseIntegerParam(Map<String, Object>, String, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel.AbstractModelParser
-
Extracts an integer from the settings map, otherwise throws an exception
- parseInternal(MatchQuery.Type, String, MatchQuery.MatchQueryBuilder, Object) - Method in class org.elasticsearch.index.search.MatchQuery
- parseInto(DateTimeParserBucket, String, int) - Method in class org.elasticsearch.common.joda.Joda.EpochTimeParser
- parseJoda(String) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- parseJoda(String) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Parse the given input into a Joda
DateTime
. - parseLong(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- parseLong(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- parseLong(String, boolean, LongSupplier) - Method in interface org.elasticsearch.search.DocValueFormat
-
Parse a value that was formatted with
DocValueFormat.format(long)
back to the original long value. - parseLong(String, long, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseMapping(NamedXContentRegistry, String) - Static method in class org.elasticsearch.index.mapper.MapperService
-
Parses the mappings (formatted as JSON) into a map
- parseMillis(String) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- parseMillis(String) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Parse the given input into millis-since-epoch.
- parseMultiField(FieldMapper.Builder, String, Mapper.TypeParser.ParserContext, String, Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- parseMultiLineRequest(RestRequest, IndicesOptions, boolean, CheckedBiConsumer<SearchRequest, XContentParser, IOException>) - Static method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
-
Parses a multi-line
RestRequest
body, instantiating aSearchRequest
for each line and applying the given consumer. - parseNested(String, Map<String, Object>, ObjectMapper.Builder, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- parseNestedFilter(XContentParser) - Static method in class org.elasticsearch.search.sort.SortBuilder
- parseNorms(FieldMapper.Builder, String, String, Object, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- parseObjectOrDocumentTypeProperties(String, Object, Mapper.TypeParser.ParserContext, ObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- parseOrderParam(XContentParser) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Parser
-
Parse a
BucketOrder
fromXContent
. - parseParameter(Object, EnumSet<IndicesOptions.WildcardStates>) - Static method in enum org.elasticsearch.action.support.IndicesOptions.WildcardStates
- parsePoint(byte[]) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- parsePoint(byte[]) - Method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- parsePrecision(XContentParser) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parse a precision that can be expressed as an integer or a distance measure like "1km", "10m".
- parseProperties(ObjectMapper.Builder, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- parseQueryContext(XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Parses query contexts for this mapper
- parser() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- parser() - Method in class org.elasticsearch.index.mapper.ParseContext
- parser() - Static method in class org.elasticsearch.tasks.TaskId
- Parser() - Constructor for class org.elasticsearch.search.aggregations.InternalOrder.Parser
- PARSER - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- PARSER - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Parser for any one
AliasAction
. - PARSER - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- PARSER - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- PARSER - Static variable in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- PARSER - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- PARSER - Static variable in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- PARSER - Static variable in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- PARSER - Static variable in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- PARSER - Static variable in class org.elasticsearch.action.ingest.SimulateProcessorResult
- PARSER - Static variable in class org.elasticsearch.action.support.DefaultShardOperationFailedException
- PARSER - Static variable in class org.elasticsearch.cluster.health.ClusterShardHealth
- PARSER - Static variable in class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- PARSER - Static variable in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- PARSER - Static variable in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- PARSER - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- PARSER - Static variable in class org.elasticsearch.tasks.TaskInfo
- PARSER - Static variable in class org.elasticsearch.tasks.TaskResult
- PARSER_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- parseRangeBucketXContent(XContentParser, Supplier<B>, boolean) - Static method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- parseRatioValue(String) - Static method in class org.elasticsearch.common.unit.RatioValue
-
Parses the provided string as a
RatioValue
, the string can either be in percentage format (eg. - parserContext(String) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
- ParserContext(String, IndexAnalyzers, Function<String, SimilarityProvider>, MapperService, Function<String, Mapper.TypeParser>, Version, Supplier<QueryShardContext>) - Constructor for class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- parseRequest(TermVectorsRequest, XContentParser) - Static method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
populates a request object (pre-populated with defaults) based on a parser.
- parseRequest(RestRequest, boolean) - Static method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
-
Parses a
RestRequest
body and returns aMultiSearchRequest
- parseRewriteMethod(String, MultiTermQuery.RewriteMethod, DeprecationHandler) - Static method in class org.elasticsearch.index.query.support.QueryParsers
- parseRewriteMethod(String, DeprecationHandler) - Static method in class org.elasticsearch.index.query.support.QueryParsers
- parseScoreMode(String) - Static method in class org.elasticsearch.index.query.NestedQueryBuilder
- parseSearchRequest(SearchRequest, RestRequest, XContentParser, IntConsumer) - Static method in class org.elasticsearch.rest.action.search.RestSearchAction
-
Parses the rest request on top of the SearchRequest, preserving values that are not overridden by the rest request.
- parseSizeValue(String) - Static method in class org.elasticsearch.common.unit.SizeValue
- parseSizeValue(String, SizeValue) - Static method in class org.elasticsearch.common.unit.SizeValue
- parseStemExclusion(Settings, CharArraySet) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseStopWords(Environment, Settings, CharArraySet, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseStopWords(Environment, Version, Settings, CharArraySet) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseString(String) - Static method in class org.elasticsearch.action.support.ActiveShardCount
-
Parses the active shard count from the given string.
- parseString(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
- parseString(String, boolean) - Static method in enum org.elasticsearch.cluster.ClusterState.Metric
- parseTermsLookup(XContentParser) - Static method in class org.elasticsearch.indices.TermsLookup
- parseTermVector(String, String, FieldMapper.Builder) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- parseTextField(FieldMapper.Builder, String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.TypeParsers
-
Parse text field attributes.
- parseTimeValue(String, TimeValue, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseTo(RangeFieldMapper.RangeFieldType, XContentParser, boolean, boolean) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
-
parses to value.
- parseToMilliseconds(Object, boolean, DateTimeZone, DateMathParser, QueryRewriteContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- parseTypedKeysObject(XContentParser, String, Class<T>, Consumer<T>) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
-
This method expects that the current field name is the concatenation of a type, a delimiter and a name (ex: terms#foo where "terms" refers to the type of a registered
NamedXContentRegistry.Entry
, "#" is the delimiter and "foo" the name of the object to parse). - parseUnit(String, DistanceUnit) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
-
Parses the suffix of a given distance string and return the corresponding
DistanceUnit
- parseValue(String) - Static method in enum org.elasticsearch.common.breaker.CircuitBreaker.Type
- parseVersion(String, Version, Logger) - Static method in class org.elasticsearch.common.lucene.Lucene
- parseVersion(RestRequest) - Static method in class org.elasticsearch.rest.action.RestActions
- parseVersion(RestRequest, long) - Static method in class org.elasticsearch.rest.action.RestActions
- parseVersionLenient(String, Version) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Parses the version string lenient and returns the default value if the given string is null or empty
- parseWords(Environment, Settings, String, CharArraySet, Map<String, Set<?>>, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseXContent(XContentParser) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- parseXContent(XContentParser, boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Parse some xContent into this SearchSourceBuilder, overwriting any values specified in the xContent.
- parseXContent(XContentParser, boolean, Supplier<B>, CheckedBiConsumer<XContentParser, B, IOException>) - Static method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- parseXContent(XContentParser, T, String) - Static method in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- parseXContentFields(XContentParser, DeleteResponse.Builder) - Static method in class org.elasticsearch.action.delete.DeleteResponse
-
Parse the current token and update the parsing context appropriately.
- parseXContentFields(XContentParser, IndexResponse.Builder) - Static method in class org.elasticsearch.action.index.IndexResponse
-
Parse the current token and update the parsing context appropriately.
- parseXContentFields(XContentParser, UpdateResponse.Builder) - Static method in class org.elasticsearch.action.update.UpdateResponse
-
Parse the current token and update the parsing context appropriately.
- ParsingException - Exception in org.elasticsearch.common
-
Exception that can be used when parsing queries with a given
XContentParser
. - ParsingException(int, int, String, Throwable) - Constructor for exception org.elasticsearch.common.ParsingException
-
This constructor is provided for use in unit tests where a
XContentParser
may not be available - ParsingException(StreamInput) - Constructor for exception org.elasticsearch.common.ParsingException
- ParsingException(XContentLocation, String, Object...) - Constructor for exception org.elasticsearch.common.ParsingException
- ParsingException(XContentLocation, String, Throwable, Object...) - Constructor for exception org.elasticsearch.common.ParsingException
- partBytes(int) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns the size (in bytes) of a given part
- partial() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns true if indices with unavailable shards should be be partially snapshotted.
- partial() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns true if indices with failed to snapshot shards should be partially restored.
- partial() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- partial(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Set to true to allow indices with unavailable shards to be partially snapshotted.
- partial(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Set to true to allow indices with failed to snapshot shards should be partially restored.
- PARTIAL - org.elasticsearch.snapshots.SnapshotState
-
Snapshot was partial successful
- PARTIAL_CONTENT - org.elasticsearch.rest.RestStatus
-
The server has fulfilled the partial GET request for the resource.
- PARTITION_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- PartitionedLongFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.PartitionedLongFilter
- partName(long) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns part name if file is stored as multiple parts
- partSize() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns part size
- PATCH - org.elasticsearch.rest.RestRequest.Method
- path - Variable in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- path - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
- path - Variable in class org.elasticsearch.index.translog.BaseTranslogReader
- path() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Gets the
BlobPath
that defines the implementation specific paths to where the blobs are contained. - path() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- path() - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
- path() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- path() - Method in class org.elasticsearch.index.mapper.Mapper.BuilderContext
- path() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- path() - Method in class org.elasticsearch.index.mapper.ParseContext
- path() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- path() - Method in class org.elasticsearch.indices.TermsLookup
- path() - Method in class org.elasticsearch.rest.RestRequest
-
The path part of the URI (without the query string), decoded.
- path() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
-
Get the path to use for this nested aggregation.
- path() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
-
Get the path to use for this nested aggregation.
- path() - Method in class org.elasticsearch.search.aggregations.InternalOrder.Aggregation
- path(String) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- path(String) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
-
Set the path to use for this nested aggregation.
- Path() - Constructor for class org.elasticsearch.monitor.fs.FsInfo.Path
- Path(String, String, long, long, long) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.Path
- Path(StreamInput) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.Path
-
Read from a stream.
- PATH - Static variable in class org.elasticsearch.index.mapper.FieldAliasMapper.Names
- PATH_DATA_SETTING - Static variable in class org.elasticsearch.env.Environment
- PATH_FIELD - Static variable in class org.elasticsearch.search.sort.NestedSortBuilder
- PATH_HOME_SETTING - Static variable in class org.elasticsearch.env.Environment
- PATH_LOGS_SETTING - Static variable in class org.elasticsearch.env.Environment
- PATH_REPO_SETTING - Static variable in class org.elasticsearch.env.Environment
- PATH_SHARED_DATA_SETTING - Static variable in class org.elasticsearch.env.Environment
- pathAsText(String) - Method in class org.elasticsearch.index.mapper.ContentPath
- PathElement(String, String, String) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- PathTrie<T> - Class in org.elasticsearch.common.path
- PathTrie(PathTrie.Decoder) - Constructor for class org.elasticsearch.common.path.PathTrie
- PathTrie.Decoder - Interface in org.elasticsearch.common.path
- PathTrie.TrieNode - Class in org.elasticsearch.common.path
- pattern() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- pattern() - Method in interface org.elasticsearch.common.time.DateFormatter
-
A name based format for this formatter.
- patterns() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- patterns() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- patterns(List<String>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- patterns(List<String>) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- patterns(List<String>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- PAYLOAD_SEP - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- payloads() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
The list of optional payloads associated with requests in the same order as the requests.
- payloads() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- payloads(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the payloads for each term or skip.
- Payloads - org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- PAYMENT_REQUIRED - org.elasticsearch.rest.RestStatus
-
This code is reserved for future use.
- PB - org.elasticsearch.common.unit.ByteSizeUnit
- peek() - Method in class org.elasticsearch.common.collect.EvictingQueue
- peek() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- PEER - org.elasticsearch.cluster.routing.RecoverySource.Type
- PEER_RECOVERY - org.elasticsearch.index.engine.Engine.Operation.Origin
- PeerRecoverySourceService - Class in org.elasticsearch.indices.recovery
-
The source recovery accepts recovery requests from other peer shards and start the recovery process from this source shard to the target shard.
- PeerRecoverySourceService(TransportService, IndicesService, RecoverySettings) - Constructor for class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- PeerRecoverySourceService.Actions - Class in org.elasticsearch.indices.recovery
- PeerRecoveryTargetService - Class in org.elasticsearch.indices.recovery
-
The recovery target handles recoveries of peer shards of the shard+node to recover to.
- PeerRecoveryTargetService(ThreadPool, TransportService, RecoverySettings, ClusterService) - Constructor for class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- PeerRecoveryTargetService.Actions - Class in org.elasticsearch.indices.recovery
- PeerRecoveryTargetService.RecoveryListener - Interface in org.elasticsearch.indices.recovery
- Pending(Object, Priority, long, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- PENDING_CANCEL - org.elasticsearch.persistent.AllocatedPersistentTask.State
- PENDING_OPERATIONS - org.elasticsearch.index.engine.Engine.SyncedFlushResult
- pendingClusterStates() - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
returns all pending states, committed or not
- pendingClusterStates() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- PendingClusterStatesQueue - Class in org.elasticsearch.discovery.zen
-
A queue that holds all "in-flight" incoming cluster states from the master.
- PendingClusterStatesQueue(Logger, int) - Constructor for class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
- PendingClusterStateStats - Class in org.elasticsearch.discovery.zen
-
Class encapsulating stats about the PendingClusterStatsQueue
- PendingClusterStateStats(int, int, int) - Constructor for class org.elasticsearch.discovery.zen.PendingClusterStateStats
- PendingClusterStateStats(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.PendingClusterStateStats
- PendingClusterTask - Class in org.elasticsearch.cluster.service
- PendingClusterTask() - Constructor for class org.elasticsearch.cluster.service.PendingClusterTask
- PendingClusterTask(long, Priority, Text, long, boolean) - Constructor for class org.elasticsearch.cluster.service.PendingClusterTask
- pendingClusterTasks(PendingClusterTasksRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a list of the pending cluster tasks, that are scheduled to be executed.
- pendingClusterTasks(PendingClusterTasksRequest, ActionListener<PendingClusterTasksResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a list of the pending cluster tasks, that are scheduled to be executed.
- PendingClusterTasksAction - Class in org.elasticsearch.action.admin.cluster.tasks
- PendingClusterTasksRequest - Class in org.elasticsearch.action.admin.cluster.tasks
- PendingClusterTasksRequest() - Constructor for class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequest
- PendingClusterTasksRequestBuilder - Class in org.elasticsearch.action.admin.cluster.tasks
- PendingClusterTasksRequestBuilder(ElasticsearchClient, PendingClusterTasksAction) - Constructor for class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequestBuilder
- PendingClusterTasksResponse - Class in org.elasticsearch.action.admin.cluster.tasks
- pendingCount() - Method in class org.elasticsearch.index.shard.RefreshListeners
-
The number of pending listeners.
- pendingInSync() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Whether the are shards blocking global checkpoint advancement.
- pendingInSync() - Method in class org.elasticsearch.index.shard.IndexShard
-
Check if there are any recoveries pending in-sync.
- pendingNodes() - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
returns a list of nodes which didn't respond yet
- pendingTasks() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- pendingTasks() - Method in class org.elasticsearch.cluster.service.MasterService
-
Returns the tasks that are pending.
- percent(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
- percent(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentileRanks
- percent(double) - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanks
-
Return the percentile for the given value.
- percent(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
- PercentageScore - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- PercentageScore() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- PercentageScore(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- PercentageScore.PercentageScoreBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- PercentageScoreBuilder() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore.PercentageScoreBuilder
- percentAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
- percentAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentileRanks
- percentAsString(double) - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanks
-
Return the percentile for the given value as a String.
- percentAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
- percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
- percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentiles
- percentile(double) - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.Percentiles
-
Return the value associated with the provided percentile.
- percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
- percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentiles
- percentile(double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- percentile(double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.ParsedPercentilesBucket
- Percentile - Class in org.elasticsearch.search.aggregations.metrics.percentiles
- Percentile(double, double) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.Percentile
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.ParsedHDRPercentiles
- percentileAsString(double) - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.Percentiles
-
Return the value associated with the provided percentile as a String.
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.ParsedTDigestPercentiles
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.ParsedPercentilesBucket
- percentileRanks(String, double[]) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
PercentileRanks
aggregation with the given name. - PercentileRanks - Interface in org.elasticsearch.search.aggregations.metrics.percentiles
-
An aggregation that computes approximate percentiles given values.
- PercentileRanksAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.percentiles
- PercentileRanksAggregationBuilder(String, double[]) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- PercentileRanksAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
-
Read from a stream.
- PercentileRanksAggregationBuilder(PercentileRanksAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- percentiles - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentiles
- percentiles() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Get the values to compute percentiles from.
- percentiles(double...) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Set the values to compute percentiles from.
- percentiles(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Percentiles
aggregation with the given name. - Percentiles - Interface in org.elasticsearch.search.aggregations.metrics.percentiles
-
An aggregation that computes approximate percentiles.
- PercentilesAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.percentiles
- PercentilesAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- PercentilesAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
-
Read from a stream.
- PercentilesAggregationBuilder(PercentilesAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- percentilesAsString - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.ParsedPercentiles
- percentilesBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- PercentilesBucket - Interface in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
- PercentilesBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
- PercentilesBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- PercentilesBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
-
Read from a stream.
- PercentilesBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
- PercentilesBucketPipelineAggregator(String, double[], String[], BucketHelpers.GapPolicy, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
- PercentilesBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
-
Read from a stream.
- PercentilesMethod - Enum in org.elasticsearch.search.aggregations.metrics.percentiles
-
An enum representing the methods for calculating percentiles
- percents() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
-
Get the percentages to calculate percentiles for in this aggregation
- percents(double[]) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
-
Set the percentages to calculate percentiles for in this aggregation
- PERCENTS_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- PERCENTS_FIELD - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregationBuilder
- PERCENTS_FIELD - Variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
- perFieldAnalyzer() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the overridden analyzers at each field.
- perFieldAnalyzer() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- perFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Override the analyzer used at each field when generating term vectors.
- perFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Sets the analyzer(s) to use at any given field.
- PerFieldMappingPostingFormatCodec - Class in org.elasticsearch.index.codec
-
This postings format
is the defaultPostingsFormat
for Elasticsearch. - PerFieldMappingPostingFormatCodec(Lucene50StoredFieldsFormat.Mode, MapperService, Logger) - Constructor for class org.elasticsearch.index.codec.PerFieldMappingPostingFormatCodec
- perform(RequestT) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Performs the given request on this primary.
- performOn(ShardRouting, ReplicaRequest, long, long, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicasProxy
- performOn(ShardRouting, RequestT, long, long, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Replicas
-
Performs the specified request on the specified replica.
- performOnPrimary(BulkShardRequest, IndexShard, UpdateHelper, boolean, LongSupplier, MappingUpdatePerformer, CheckedRunnable<Exception>) - Static method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- performOnPrimary(ResyncReplicationRequest, IndexShard) - Static method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- performOnReplica(BulkShardRequest, IndexShard) - Static method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- performOnReplica(ResyncReplicationRequest, IndexShard) - Static method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- performOperation(ShardIterator, ShardRouting, int) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- performRecoveryRestart() - Method in class org.elasticsearch.index.shard.IndexShard
-
called if recovery has to be restarted after network error / delay **
- performStateRecovery(Gateway.GatewayStateRecoveredListener) - Method in class org.elasticsearch.gateway.Gateway
- period(int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
- persistentSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- persistentSettings() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- persistentSettings() - Method in class org.elasticsearch.cluster.metadata.MetaData
- persistentSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the source containing the persistent settings to be updated.
- persistentSettings(Map) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the persistent settings to be updated.
- persistentSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the persistent settings to be updated.
- persistentSettings(Settings) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- persistentSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the persistent settings to be updated.
- PersistentTask(String, String, P, long, PersistentTasksCustomMetaData.Assignment) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- PersistentTask(StreamInput) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- PersistentTask(PersistentTasksCustomMetaData.PersistentTask<P>, long, PersistentTasksCustomMetaData.Assignment) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- PersistentTask(PersistentTasksCustomMetaData.PersistentTask<P>, PersistentTaskState) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- PersistentTaskParams - Interface in org.elasticsearch.persistent
-
Parameters used to start persistent task
- PersistentTaskPlugin - Interface in org.elasticsearch.plugins
-
Plugin for registering persistent tasks executors.
- PersistentTaskResponse - Class in org.elasticsearch.persistent
-
Response upon a successful start or an persistent task
- PersistentTaskResponse() - Constructor for class org.elasticsearch.persistent.PersistentTaskResponse
- PersistentTaskResponse(PersistentTasksCustomMetaData.PersistentTask<?>) - Constructor for class org.elasticsearch.persistent.PersistentTaskResponse
- PersistentTasksClusterService - Class in org.elasticsearch.persistent
-
Component that runs only on the master node and is responsible for assigning running tasks to nodes
- PersistentTasksClusterService(Settings, PersistentTasksExecutorRegistry, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.persistent.PersistentTasksClusterService
- PersistentTasksCustomMetaData - Class in org.elasticsearch.persistent
-
A cluster state record that contains a list of all running persistent tasks
- PersistentTasksCustomMetaData(long, Map<String, PersistentTasksCustomMetaData.PersistentTask<?>>) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- PersistentTasksCustomMetaData(StreamInput) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- PersistentTasksCustomMetaData.Assignment - Class in org.elasticsearch.persistent
- PersistentTasksCustomMetaData.Builder - Class in org.elasticsearch.persistent
- PersistentTasksCustomMetaData.PersistentTask<P extends PersistentTaskParams> - Class in org.elasticsearch.persistent
-
A record that represents a single running persistent task
- PersistentTasksExecutor<Params extends PersistentTaskParams> - Class in org.elasticsearch.persistent
-
An executor of tasks that can survive restart of requesting or executing node.
- PersistentTasksExecutor(String, String) - Constructor for class org.elasticsearch.persistent.PersistentTasksExecutor
- PersistentTasksExecutorRegistry - Class in org.elasticsearch.persistent
-
Components that registers all persistent task executors
- PersistentTasksExecutorRegistry(Collection<PersistentTasksExecutor<?>>) - Constructor for class org.elasticsearch.persistent.PersistentTasksExecutorRegistry
- PersistentTasksNodeService - Class in org.elasticsearch.persistent
-
This component is responsible for coordination of execution of persistent tasks on individual nodes.
- PersistentTasksNodeService(PersistentTasksService, PersistentTasksExecutorRegistry, TaskManager, NodePersistentTasksExecutor) - Constructor for class org.elasticsearch.persistent.PersistentTasksNodeService
- PersistentTasksNodeService.Status - Class in org.elasticsearch.persistent
- PersistentTasksService - Class in org.elasticsearch.persistent
-
This service is used by persistent tasks and allocated persistent tasks to communicate changes to the master node so that the master can update the cluster state and can track of the states of the persistent tasks.
- PersistentTasksService(ClusterService, ThreadPool, Client) - Constructor for class org.elasticsearch.persistent.PersistentTasksService
- PersistentTasksService.WaitForPersistentTaskListener<P extends PersistentTaskParams> - Interface in org.elasticsearch.persistent
- PersistentTaskState - Interface in org.elasticsearch.persistent
-
PersistentTaskState
represents the state of the persistent tasks, as it is persisted in the cluster state. - persistRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Persists the current retention leases to their dedicated state file.
- persistRetentionLeases(Path) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Persists the current retention leases to their dedicated state file.
- peta() - Method in class org.elasticsearch.common.unit.SizeValue
- PETA - org.elasticsearch.common.unit.SizeUnit
- petaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- phase() - Method in exception org.elasticsearch.index.engine.RecoveryEngineException
- PHASE - org.elasticsearch.search.internal.SearchContext.Lifetime
-
This life time is for objects that need to live until the end of the current search phase.
- phase1(IndexCommit, Supplier<Integer>) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
Perform phase1 of the recovery operations.
- PHRASE - org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the best matching phrase field as main score and uses a tie-breaker to adjust the score based on remaining field matches
- PHRASE - org.elasticsearch.index.query.SimpleQueryStringFlag
- PHRASE - org.elasticsearch.index.search.MatchQuery.Type
-
The text is analyzed and used as a phrase query.
- PHRASE_LIMIT_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- PHRASE_PREFIX - org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the best matching phrase-prefix field as main score and uses a tie-breaker to adjust the score based on remaining field matches
- PHRASE_PREFIX - org.elasticsearch.index.search.MatchQuery.Type
-
The text is analyzed and used in a phrase query, with the last term acting as a prefix.
- phraseLimit - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- phraseLimit() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- phraseLimit() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- phraseLimit(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Sets the maximum number of phrases the fvh will consider if the field doesn't also define phraseLimit.
- phrasePrefixQuery(TokenStream, int, int) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- phrasePrefixQuery(TokenStream, int, int) - Method in class org.elasticsearch.index.mapper.StringFieldType
- phrasePrefixQuery(TokenStream, int, int) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- phraseQuery(TokenStream, int, boolean) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- phraseQuery(TokenStream, int, boolean) - Method in class org.elasticsearch.index.mapper.StringFieldType
- phraseQuery(TokenStream, int, boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- phraseSlop - Variable in class org.elasticsearch.index.search.MatchQuery
- phraseSlop() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- phraseSlop(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Sets the default slop for phrases.
- PhraseSuggester - Class in org.elasticsearch.search.suggest.phrase
- phraseSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a phrase suggestion lookup query with the provided
field
- PhraseSuggestion - Class in org.elasticsearch.search.suggest.phrase
-
Suggestion entry returned from the
PhraseSuggester
. - PhraseSuggestion() - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- PhraseSuggestion(String, int) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- PhraseSuggestion.Entry - Class in org.elasticsearch.search.suggest.phrase
- PhraseSuggestionBuilder - Class in org.elasticsearch.search.suggest.phrase
-
Defines the actual suggest command for phrase suggestions (
phrase
). - PhraseSuggestionBuilder(String) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- PhraseSuggestionBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Read from a stream.
- PhraseSuggestionBuilder.CandidateGenerator - Interface in org.elasticsearch.search.suggest.phrase
-
PhraseSuggestionBuilder.CandidateGenerator
interface. - physicalName() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns original file name
- pick(BinaryDocValues, BytesRefBuilder, DocIdSetIterator, int, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
- pick(SortedDocValues, DocIdSetIterator, int, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
- pick(SortedNumericDocValues) - Method in enum org.elasticsearch.search.MultiValueMode
- pick(SortedNumericDocValues, long, DocIdSetIterator, int, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
- pick(SortedSetDocValues) - Method in enum org.elasticsearch.search.MultiValueMode
- pick(SortedBinaryDocValues) - Method in enum org.elasticsearch.search.MultiValueMode
- pick(SortedNumericDoubleValues) - Method in enum org.elasticsearch.search.MultiValueMode
- pick(SortedNumericDoubleValues, double, DocIdSetIterator, int, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
- pid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
The process id.
- pidFile() - Method in class org.elasticsearch.env.Environment
-
The PID file location (can be null if no PID file is configured)
- PidFile - Class in org.elasticsearch.common
-
Process ID file abstraction that writes the current pid into a file and optionally removes it on system exit.
- PIDFILE_SETTING - Static variable in class org.elasticsearch.env.Environment
- ping(Consumer<ZenPing.PingCollection>, TimeValue) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
-
Sends three rounds of pings notifying the specified
Consumer
when pinging is complete. - ping(Consumer<ZenPing.PingCollection>, TimeValue) - Method in interface org.elasticsearch.discovery.zen.ZenPing
- ping(Consumer<ZenPing.PingCollection>, TimeValue, TimeValue) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
-
a variant of
UnicastZenPing.ping(Consumer, TimeValue)
, but allows separating the scheduling duration from the duration used for request level time outs. - PING - org.elasticsearch.transport.TransportRequestOptions.Type
- PING_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.NodesFaultDetection
- PING_INTERVAL_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- PING_RETRIES_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- PING_SCHEDULE - Static variable in class org.elasticsearch.transport.TransportSettings
- PING_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- PING_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- PingCollection() - Constructor for class org.elasticsearch.discovery.zen.ZenPing.PingCollection
- PingContextProvider - Interface in org.elasticsearch.discovery.zen
- pingInterval - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- PingRequest() - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- PingResponse(DiscoveryNode, DiscoveryNode, ClusterState) - Constructor for class org.elasticsearch.discovery.zen.ZenPing.PingResponse
- pingRetryCount - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- pingRetryTimeout - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- pipeline() - Method in class org.elasticsearch.action.bulk.BulkRequest
- pipeline(String) - Method in class org.elasticsearch.action.bulk.BulkRequest
- pipeline(String) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
- Pipeline - Class in org.elasticsearch.ingest
-
A pipeline is a list of
Processor
instances grouped under a unique id. - Pipeline(String, String, Integer, CompoundProcessor) - Constructor for class org.elasticsearch.ingest.Pipeline
- PipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations
-
A factory that knows how to create an
PipelineAggregator
of a specific type. - PipelineAggregationBuilder(String, String[]) - Constructor for class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Constructs a new pipeline aggregator factory.
- PipelineAggregationSpec(String, Writeable.Reader<? extends PipelineAggregationBuilder>, Writeable.Reader<? extends PipelineAggregator>, PipelineAggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Specification of a
PipelineAggregator
. - PipelineAggregationSpec(ParseField, Writeable.Reader<? extends PipelineAggregationBuilder>, Writeable.Reader<? extends PipelineAggregator>, PipelineAggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Specification of a
PipelineAggregator
. - PipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- PipelineAggregator(String, String[], Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- PipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
Read from a stream.
- PipelineAggregator.Parser - Interface in org.elasticsearch.search.aggregations.pipeline
-
Parse the
PipelineAggregationBuilder
from aXContentParser
. - PipelineAggregatorBuilders - Class in org.elasticsearch.search.aggregations.pipeline
- pipelineAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- pipelineAggregators() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- pipelineAggregators() - Method in class org.elasticsearch.search.query.QuerySearchResult
- pipelineAggregators(List<SiblingPipelineAggregator>) - Method in class org.elasticsearch.search.query.QuerySearchResult
- PipelineConfiguration - Class in org.elasticsearch.ingest
-
Encapsulates a pipeline's id and configuration as a blob
- PipelineConfiguration(String, BytesReference, XContentType) - Constructor for class org.elasticsearch.ingest.PipelineConfiguration
- PipelineProcessor - Class in org.elasticsearch.ingest
- PipelineProcessor.Factory - Class in org.elasticsearch.ingest
- pipelines() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
-
Get the list of pipelines that were a part of this response.
- PipelineStat(String, IngestStats.Stats) - Constructor for class org.elasticsearch.ingest.IngestStats.PipelineStat
- PlainActionFuture<T> - Class in org.elasticsearch.action.support
- PlainActionFuture() - Constructor for class org.elasticsearch.action.support.PlainActionFuture
- PlainBlobMetaData - Class in org.elasticsearch.common.blobstore.support
- PlainBlobMetaData(String, long) - Constructor for class org.elasticsearch.common.blobstore.support.PlainBlobMetaData
- PlainHighlighter - Class in org.elasticsearch.search.fetch.subphase.highlight
- PlainHighlighter() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.PlainHighlighter
- PlainListenableActionFuture<T> - Class in org.elasticsearch.action.support
- PlainListenableActionFuture() - Constructor for class org.elasticsearch.action.support.PlainListenableActionFuture
- PlainShardIterator - Class in org.elasticsearch.cluster.routing
- PlainShardIterator(ShardId, List<ShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.PlainShardIterator
-
Creates a
PlainShardIterator
instance that iterates over a subset of the given shards this the a givenshardId
. - PlainShardsIterator - Class in org.elasticsearch.cluster.routing
-
A simple
ShardsIterator
that iterates a list or sub-list ofshard indexRoutings
. - PlainShardsIterator(List<ShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.PlainShardsIterator
- PlainTransportFuture<V extends TransportResponse> - Class in org.elasticsearch.transport
- PlainTransportFuture(TransportResponseHandler<V>) - Constructor for class org.elasticsearch.transport.PlainTransportFuture
- planDeletionAsNonPrimary(Engine.Delete) - Method in class org.elasticsearch.index.engine.InternalEngine
- planDeletionAsPrimary(Engine.Delete) - Method in class org.elasticsearch.index.engine.InternalEngine
- PLANE - org.elasticsearch.common.geo.GeoDistance
- planeDistance(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- planeDistance(double, double, double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Return the distance (in meters) between 2 lat,lon geo points using a simple tangential plane this provides a faster alternative to
GeoUtils.arcDistance(double, double, double, double)
but is inaccurate for distances greater than 4 decimal degrees - planeDistanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- planIndexingAsNonPrimary(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- planIndexingAsPrimary(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- PLATFORM_NAME - Static variable in class org.elasticsearch.plugins.Platforms
- platformName(String, String) - Static method in class org.elasticsearch.plugins.Platforms
-
Return the platform name based on the OS name and - darwin-x86_64 - linux-x86-64 - windows-x86_64 For *nix platforms this is more-or-less `uname -s`-`uname -m` converted to lower case.
- Platforms - Class in org.elasticsearch.plugins
-
Encapsulates platform-dependent methods for handling native components of plugins.
- Plugin - Class in org.elasticsearch.plugins
-
An extension point allowing to plug in custom functionality.
- Plugin() - Constructor for class org.elasticsearch.plugins.Plugin
- PluginInfo - Class in org.elasticsearch.plugins
-
An in-memory representation of the plugin descriptor.
- PluginInfo(String, String, String, Version, String, String, List<String>, boolean) - Constructor for class org.elasticsearch.plugins.PluginInfo
-
Construct plugin info.
- PluginInfo(StreamInput) - Constructor for class org.elasticsearch.plugins.PluginInfo
-
Construct plugin info from a stream.
- plugins() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
- plugins(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should information about plugins be returned
- PluginsAndModules - Class in org.elasticsearch.action.admin.cluster.node.info
-
Information about plugins and modules
- PluginsAndModules(List<PluginInfo>, List<PluginInfo>) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- PluginsAndModules(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- pluginsFile() - Method in class org.elasticsearch.env.Environment
- PluginsService - Class in org.elasticsearch.plugins
- PluginsService(Settings, Path, Path, Path, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.plugins.PluginsService
-
Constructs a new PluginService
- plus(long, TemporalUnit) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plus(TemporalAmount) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusDays(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusHours(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusMinutes(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusMonths(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusNanos(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusSeconds(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusSkippedClasses(Class...) - Method in class org.elasticsearch.common.inject.internal.SourceProvider
-
Returns a new instance that also skips
moreClassesToSkip
. - plusWeeks(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusYears(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- point() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Returns the center point of the distance query.
- point(double, double) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets the center point of the query.
- point(double, double) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The point to create the range distance facets from.
- point(PointBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- point(GeoPoint) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets the center point for the query.
- POINT - org.elasticsearch.common.geo.GeoShapeType
- PointBuilder - Class in org.elasticsearch.common.geo.builders
- PointBuilder() - Constructor for class org.elasticsearch.common.geo.builders.PointBuilder
-
Create a point at [0.0,0.0]
- PointBuilder(double, double) - Constructor for class org.elasticsearch.common.geo.builders.PointBuilder
- PointBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.PointBuilder
- points() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
- points() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the points to create the range distance facets from.
- points(GeoPoint...) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The point to create the range distance facets from.
- POINTS_ONLY - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults
-
Deprecated.
- POINTS_ONLY - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Names
-
Deprecated.
- pointsOnly - Variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- pointsOnly() - Method in class org.elasticsearch.common.geo.XShapeCollection
- pointsOnly() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- poll() - Method in class org.elasticsearch.common.collect.EvictingQueue
- poll() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- poll(long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- pollLast() - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
Removes the last (e.g.
- pollLastElement() - Method in class org.elasticsearch.search.profile.AbstractProfiler
-
Removes the last (e.g.
- polygon(PolygonBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- polygon(PolygonBuilder) - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
Add a shallow copy of the polygon to the multipolygon.
- POLYGON - org.elasticsearch.common.geo.GeoShapeType
- PolygonBuilder - Class in org.elasticsearch.common.geo.builders
-
The
PolygonBuilder
implements the groundwork to create polygons. - PolygonBuilder(CoordinatesBuilder) - Constructor for class org.elasticsearch.common.geo.builders.PolygonBuilder
- PolygonBuilder(CoordinatesBuilder, ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.PolygonBuilder
- PolygonBuilder(LineStringBuilder, ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.PolygonBuilder
- PolygonBuilder(LineStringBuilder, ShapeBuilder.Orientation, boolean) - Constructor for class org.elasticsearch.common.geo.builders.PolygonBuilder
- PolygonBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.PolygonBuilder
-
Read from a stream.
- polygonLucene(Coordinate[][]) - Static method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- polygons() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
get the list of polygons
- polygonS4J(GeometryFactory, Coordinate[][]) - Static method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- POPULAR - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Only suggest terms that occur in more docs then the original suggest text term.
- populateCommonFields(MapperService, SuggestionSearchContext.SuggestionContext) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Transfers the text, prefix, regex, analyzer, field, size and shard size settings from the original
SuggestionBuilder
to the targetSuggestionSearchContext.SuggestionContext
- PORT - Static variable in class org.elasticsearch.transport.TransportSettings
- PORT_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- portOrRange - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- ports() - Method in class org.elasticsearch.common.transport.PortsRange
- PortsRange - Class in org.elasticsearch.common.transport
- PortsRange(String) - Constructor for class org.elasticsearch.common.transport.PortsRange
- PortsRange.PortCallback - Interface in org.elasticsearch.common.transport
- posIncAttr - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- position - Variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- position() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- position() - Method in class org.elasticsearch.common.io.stream.StreamOutput
- position() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- position(Coordinate, Coordinate, double) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
- POSITION_INCREMENT_GAP - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper.Defaults
- POSITION_INCREMENT_GAP - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
-
The default position_increment_gap is set to 100 so that phrase queries of reasonably high slop will not match across field values.
- positionIncrementGap(int) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- positions() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- positions(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the positions for each term if stored or skip.
- Positions - org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- positiveQuery() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
Get the positive query for this boosting query.
- positiveTimeSetting(String, Setting<TimeValue>, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- positiveTimeSetting(String, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- post() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- post(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- POST - org.elasticsearch.rest.RestRequest.Method
- POST_FILTER_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- POST_RECOVERY - org.elasticsearch.index.shard.IndexShardState
- POST_TAG_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- POST_TAGS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- postAdded() - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
- postCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Called after collection of all document is done.
- postCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- postCollection() - Method in class org.elasticsearch.search.aggregations.BucketCollector
-
Post-collection callback.
- postCollection() - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- postCollection() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- postDelete(ShardId, Engine.Delete, Exception) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- postDelete(ShardId, Engine.Delete, Exception) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called after the delete operation occurred with engine level exception.
- postDelete(ShardId, Engine.Delete, Engine.DeleteResult) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- postDelete(ShardId, Engine.Delete, Engine.DeleteResult) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called after the delete operation occurred.
- postDelete(ShardId, Engine.Delete, Engine.DeleteResult) - Method in class org.elasticsearch.indices.IndexingMemoryController
- postFilter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the post filter for this request
- postFilter(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets a filter (analyzer) that is applied to each of the generated tokens before they are passed to the actual phrase scorer.
- postFilter(QueryBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a filter that will be executed after the query has been executed and only has affect on the search hits (not aggregations).
- postFilter(DirectCandidateGenerator.Candidate, CharsRefBuilder, BytesRefBuilder, List<DirectCandidateGenerator.Candidate>) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- POSTFILTER_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- postIndex(ShardId, Engine.Index, Exception) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- postIndex(ShardId, Engine.Index, Exception) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called after the indexing operation occurred with engine level exception.
- postIndex(ShardId, Engine.Index, Engine.IndexResult) - Method in class org.elasticsearch.index.IndexingSlowLog
- postIndex(ShardId, Engine.Index, Engine.IndexResult) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- postIndex(ShardId, Engine.Index, Engine.IndexResult) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called after the indexing operation occurred.
- postIndex(ShardId, Engine.Index, Engine.IndexResult) - Method in class org.elasticsearch.indices.IndexingMemoryController
- postings(PostingsEnum, int) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- postingsFormat() - Static method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.AllFieldMapper
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
-
Called after
FieldMapper.parse(ParseContext)
on theRootObjectMapper
. - postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.UidFieldMapper
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- postProcess(MapperService) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- postProcess(MapperService) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- postRecovery(String) - Method in class org.elasticsearch.index.shard.IndexShard
- postTag() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the post-tag for the highlighter set with
PhraseSuggestionBuilder.highlight(String, String)
- postTags - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- postTags() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- postTags() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- postTags(String...) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set the post tags that will be used for highlighting.
- pre() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- pre(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- PRE_60_NODE_CHECKPOINT - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
-
Represents a checkpoint coming from a pre-6.0 node
- PRE_TAG_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- PRE_TAGS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- PreBuiltAnalyzerProvider - Class in org.elasticsearch.index.analysis
- PreBuiltAnalyzerProvider(String, AnalyzerScope, Analyzer) - Constructor for class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
- PreBuiltAnalyzerProviderFactory - Class in org.elasticsearch.index.analysis
- PreBuiltAnalyzerProviderFactory(String, PreBuiltCacheFactory.CachingStrategy, Supplier<Analyzer>) - Constructor for class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
- PreBuiltAnalyzers - Enum in org.elasticsearch.indices.analysis
- PreBuiltCacheFactory - Class in org.elasticsearch.indices.analysis
- PreBuiltCacheFactory.CachingStrategy - Enum in org.elasticsearch.indices.analysis
-
The strategy of caching the analyzer ONE Exactly one version is stored.
- PreBuiltCacheFactory.PreBuiltCache<T> - Interface in org.elasticsearch.indices.analysis
- PreBuiltTokenizers - Enum in org.elasticsearch.indices.analysis
- PRECEDENCE - org.elasticsearch.index.query.SimpleQueryStringFlag
- preceding(int) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
-
Must be called with increasing offset.
- precision - Variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- precision() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- precision() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- precision(double) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the precision use o make suggestions
- precision(double, DistanceUnit) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the precision use o make suggestions
- precision(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- precision(int) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the precision use o make suggestions
- precision(String) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the precision use o make suggestions
- PRECISION - Static variable in class org.elasticsearch.common.geo.GeoHashUtils
-
maximum precision for geohash strings
- PRECISION - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults
-
Deprecated.
- PRECISION - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Names
-
Deprecated.
- PRECISION_THRESHOLD_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- precisionFromThreshold(long) - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
-
Compute the required precision so that
count
distinct entries would be counted with linear counting. - precisionInMeters() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- precisionThreshold() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
-
Get the precision threshold.
- precisionThreshold(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
-
Set a precision threshold.
- preCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- preCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- preCollection() - Method in class org.elasticsearch.search.aggregations.BucketCollector
-
Pre collection callback.
- preCollection() - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
-
Called before initial collection and between successive collection runs.
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- PRECONDITION_FAILED - org.elasticsearch.rest.RestStatus
-
The precondition given in one or more of the request-header fields evaluated to false when it was tested on the server.
- PreConfiguredAnalysisComponent<T> - Class in org.elasticsearch.index.analysis
-
Shared implementation for pre-configured analysis components.
- PreConfiguredAnalysisComponent(String, PreBuiltCacheFactory.CachingStrategy) - Constructor for class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- PreConfiguredAnalysisComponent(String, PreBuiltCacheFactory.PreBuiltCache<T>) - Constructor for class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- PreConfiguredCharFilter - Class in org.elasticsearch.index.analysis
-
Provides pre-configured, shared
CharFilter
s. - PreConfiguredCharFilter(String, PreBuiltCacheFactory.CachingStrategy, boolean, BiFunction<Reader, Version, Reader>) - Constructor for class org.elasticsearch.index.analysis.PreConfiguredCharFilter
- PreConfiguredTokenFilter - Class in org.elasticsearch.index.analysis
-
Provides pre-configured, shared
TokenFilter
s. - PreConfiguredTokenizer - Class in org.elasticsearch.index.analysis
-
Provides pre-configured, shared
Tokenizer
s. - preDelete(ShardId, Engine.Delete) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- preDelete(ShardId, Engine.Delete) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called before the delete occurs.
- predict() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Gets the number of predictions that should be returned.
- predict(int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Sets the number of predictions that should be returned.
- predict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Predicts the next `n` values in the series.
- PREFER_NODES - org.elasticsearch.cluster.routing.Preference
-
Route to preferred nodes, if possible
- preferAttributesActiveInitializingShardsIt(List<String>, DiscoveryNodes) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- preferAttributesActiveInitializingShardsIt(List<String>, DiscoveryNodes, int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- preference - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest
- preference() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- preference() - Method in class org.elasticsearch.action.explain.ExplainRequest
- preference() - Method in class org.elasticsearch.action.get.GetRequest
- preference() - Method in class org.elasticsearch.action.get.MultiGetRequest
- preference() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- preference() - Method in class org.elasticsearch.action.search.SearchRequest
- preference() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- preference() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- preference() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- preference() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the preference of the original
SearchRequest.preference()
. - preference() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- preference(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
- preference(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets the preference to execute the search.
- Preference - Enum in org.elasticsearch.cluster.routing
-
Routing Preference Type
- preferNodeActiveInitializingShardsIt(Set<String>) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- preFilter(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets a filter (analyzer) that is applied to each of the tokens passed to this candidate generator.
- preFilter(BytesRef, CharsRefBuilder, BytesRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- PREFILTER_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- prefix - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- prefix() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the prefix for this suggestion
- prefix(String) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Sets the prefix to provide completions for.
- prefix(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- prefix(String, Fuzziness) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Same as
CompletionSuggestionBuilder.prefix(String)
with fuzziness offuzziness
- prefix(String, FuzzyOptions) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Same as
CompletionSuggestionBuilder.prefix(String)
with full fuzzy options seeFuzzyOptions.Builder
- PREFIX - org.elasticsearch.index.query.SimpleQueryStringFlag
- PREFIX - Static variable in class org.elasticsearch.common.util.concurrent.ThreadContext
- PREFIX_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- PREFIX_LENGTH_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- PREFIX_LENGTH_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- prefixKeySetting(String, Function<String, Setting<T>>) - Static method in class org.elasticsearch.common.settings.Setting
-
This setting type allows to validate settings that have the same type and a common prefix.
- prefixLength() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- prefixLength() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets the length of a length of common (non-fuzzy) prefix for fuzzy match queries
- prefixLength() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- prefixLength() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- prefixLength() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the minimum prefix length that must match setting.
- prefixLength(int) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- prefixLength(int) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets the length of a length of common (non-fuzzy) prefix for fuzzy match queries
- prefixLength(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- prefixLength(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- prefixLength(int) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets the number of minimal prefix characters that must match in order be a candidate suggestion.
- prefixLength(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets the number of minimal prefix characters that must match in order be a candidate suggestion.
- prefixQuery(Object) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
-
Completion prefix query
- prefixQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing terms with a specified prefix.
- prefixQuery(String, MultiTermQuery.RewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- prefixQuery(String, MultiTermQuery.RewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- prefixQuery(String, MultiTermQuery.RewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- PrefixQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents containing terms with a specified prefix.
- PrefixQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.PrefixQueryBuilder
-
A Query that matches documents containing terms with a specified prefix.
- PrefixQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.PrefixQueryBuilder
-
Read from a stream.
- PrefixTrees() - Constructor for class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.PrefixTrees
-
Deprecated.
- preFlightCheckForNoOp(Engine.NoOp) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Executes a pre-flight check for a given NoOp.
- preGetSubLeafCollectors() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Can be overridden by aggregator implementations that like the perform an operation before the leaf collectors of children aggregators are instantiated for the next segment.
- preGetSubLeafCollectors() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- preIndex(ShardId, Engine.Index) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- preIndex(ShardId, Engine.Index) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called before the indexing occurs.
- preMultiTermQueryRewrite(Query) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- prepare(UpdateRequest, IndexShard, boolean, LongSupplier) - Method in class org.elasticsearch.action.update.UpdateHelper
-
Prepares an update request by converting it into an index or delete request or an update response (no action).
- prepare(ShardId, UpdateRequest, boolean, GetResult, LongSupplier) - Method in class org.elasticsearch.action.update.UpdateHelper
-
Prepares an update request by converting it into an index or delete request or an update response (no action, in the event of a noop).
- PREPARE_TRANSLOG - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- prepareAliases() - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to add/remove aliases from indices.
- prepareAliasesExist(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to check to existence of aliases from indices.
- prepareAllocationExplain() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- prepareAnalyze() - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text/texts.
- prepareAnalyze(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text.
- prepareAnalyze(String, String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- prepareBulk() - Method in interface org.elasticsearch.client.Client
-
Executes a bulk of index / delete operations.
- prepareBulk() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareBulk(String, String) - Method in interface org.elasticsearch.client.Client
-
Executes a bulk of index / delete operations with default index and/or type
- prepareBulk(String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareCancelTasks(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Cancel active tasks
- prepareClearCache(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Clear indices cache.
- prepareClearScroll() - Method in interface org.elasticsearch.client.Client
-
Clears the search contexts associated with specified scroll ids.
- prepareClearScroll() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareClose(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Closes one or more indices based on their index name.
- prepareClusterStats() - Method in interface org.elasticsearch.client.ClusterAdminClient
- prepareCreate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Creates an index using an explicit request allowing to specify the settings of the index.
- prepareCreateSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Creates a new snapshot.
- prepareDelete() - Method in interface org.elasticsearch.client.Client
-
Deletes a document from the index based on the index, type and id.
- prepareDelete() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareDelete(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index based on the index name.
- prepareDelete(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Deletes a document from the index based on the index, type and id.
- prepareDelete(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareDeletePipeline() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Deletes a stored ingest pipeline
- prepareDeletePipeline(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Deletes a stored ingest pipeline
- prepareDeleteRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Unregisters a repository.
- prepareDeleteSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete snapshot.
- prepareDeleteStoredScript() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete a script from the cluster state
- prepareDeleteStoredScript(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete a script from the cluster state
- prepareDeleteTemplate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index template.
- prepareEnvironment(Settings, Terminal) - Static method in class org.elasticsearch.node.InternalSettingsPreparer
-
Prepares the settings by gathering all elasticsearch system properties, optionally loading the configuration settings, and then replacing all property placeholders.
- prepareEnvironment(Settings, Terminal, Map<String, String>, Path) - Static method in class org.elasticsearch.node.InternalSettingsPreparer
-
Prepares the settings by gathering all elasticsearch system properties, optionally loading the configuration settings, and then replacing all property placeholders.
- prepareExecute(Action<Request, Response, RequestBuilder>) - Method in interface org.elasticsearch.client.ElasticsearchClient
-
Prepares a request builder to execute, specified by
Action
. - prepareExecute(Action<Request, Response, RequestBuilder>) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareExists(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices exists.
- prepareExplain(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Computes a score explanation for the specified request.
- prepareExplain(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareFieldCaps(String...) - Method in interface org.elasticsearch.client.Client
-
Builder for the field capabilities request.
- prepareFieldCaps(String...) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareFlush(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly flush one or more indices (releasing memory from the node).
- prepareForceMerge(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly force merge one or more indices into a the number of segments.
- prepareForIndexRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
-
called before starting to copy index files over
- prepareForTranslogOperations(boolean, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
Implementation of
RecoveryTargetHandler
- prepareForTranslogOperations(boolean, int, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Prepares the target to receive translog operations, after all file have been copied
- prepareForTranslogOperations(boolean, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- prepareGet() - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type and id.
- prepareGet() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareGet(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type (optional) and id.
- prepareGet(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareGetAliases(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get specific index aliases that exists in particular indices and / or by name.
- prepareGetFieldMappings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the mappings of specific fields
- prepareGetIndex() - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get index metadata for particular indices.
- prepareGetMappings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- prepareGetPipeline(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a stored ingest pipeline
- prepareGetRepositories(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Gets repositories.
- prepareGetSettings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Returns a builder for a per index settings get request.
- prepareGetSnapshots(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot.
- prepareGetStoredScript() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a script from the cluster state
- prepareGetStoredScript(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a script from the cluster state
- prepareGetTask(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Fetch a task by id.
- prepareGetTask(TaskId) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Fetch a task by id.
- prepareGetTemplates(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Gets an index template (optional).
- prepareHealth(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The health of the cluster.
- prepareIndex() - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- prepareIndex() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareIndex(String, String) - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- prepareIndex(String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareIndex(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- prepareIndex(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareIndex(DocumentMapperForType, Version, SourceToParse, long, long, long, VersionType, Engine.Operation.Origin, long, boolean, long, long) - Static method in class org.elasticsearch.index.shard.IndexShard
- prepareListTasks(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
List active tasks
- prepareMultiGet() - Method in interface org.elasticsearch.client.Client
-
Multi get documents.
- prepareMultiGet() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareMultiSearch() - Method in interface org.elasticsearch.client.Client
-
Performs multiple search requests.
- prepareMultiSearch() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareMultiTermVectors() - Method in interface org.elasticsearch.client.Client
-
Multi get term vectors.
- prepareMultiTermVectors() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareNodesHotThreads(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a request builder to fetch top N hot-threads samples per node.
- prepareNodesInfo(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes info of the cluster.
- prepareNodesStats(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes stats of the cluster.
- prepareNodesUsage(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes usage of the cluster.
- prepareOpen(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Opens one or more indices based on their index name.
- preparePendingClusterTasks() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a list of the pending cluster tasks, that are scheduled to be executed.
- preparePutMapping(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- preparePutPipeline(String, BytesReference) - Method in interface org.elasticsearch.client.ClusterAdminClient
- preparePutPipeline(String, BytesReference, XContentType) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Stores an ingest pipeline
- preparePutRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Registers a snapshot repository.
- preparePutStoredScript() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Store a script in the cluster state
- preparePutTemplate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- prepareRecoveries(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices recoveries
- prepareRefresh(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly refresh one or more indices (making the content indexed since the last refresh searchable).
- prepareReloadSecureSettings() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Re initialize each cluster node and pass them the secret store password.
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestCancelTasksAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterSearchShardsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStatsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestCreateSnapshotAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteRepositoryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteSnapshotAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteStoredScriptAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetSnapshotsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetStoredScriptAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetTaskAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesUsageAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestPendingClusterTasksAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutRepositoryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutStoredScriptAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestRemoteClusterInfoAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestRestoreSnapshotAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestSnapshotsStatusAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestVerifyRepositoryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestCloseIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestCreateIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestFlushAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestForceMergeAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetAliasesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetAllAliasesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetFieldMappingAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetMappingAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexDeleteAliasesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexPutAliasAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesAliasesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesSegmentsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesShardStoresAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestOpenIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestRecoveryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestRefreshAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestRolloverIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestSyncedFlushAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeStatusAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestValidateQueryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestCatAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestBulkAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestCountAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestDeleteAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestGetAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestGetSourceAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestMultiGetAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestMultiTermVectorsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestUpdateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.ingest.RestDeletePipelineAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.ingest.RestGetPipelineAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.ingest.RestPutPipelineAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.ingest.RestSimulatePipelineAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.RestFieldCapabilitiesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.RestMainAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestClearScrollAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestExplainAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestSearchAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.BaseRestHandler
-
Prepare the request for execution.
- prepareReroute() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Update settings in the cluster.
- prepareResizeIndex(String, String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Resize an index using an explicit request allowing to specify the settings, mappings and aliases of the target index of the index.
- prepareRestoreSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restores a snapshot.
- prepareRolloverIndex(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Swaps the index pointed to by an alias given all provided conditions are satisfied
- prepareSearch(String...) - Method in interface org.elasticsearch.client.Client
-
Search across one or more indices and one or more types with a query.
- prepareSearch(String...) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareSearchScroll(String) - Method in interface org.elasticsearch.client.Client
-
A search scroll request to continue searching a previous scrollable search request.
- prepareSearchScroll(String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareSearchShards() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns list of shards the given search would be executed on.
- prepareSearchShards(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns list of shards the given search would be executed on.
- prepareSegments(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The segments of one or more indices.
- prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Replay the wrapped collector, but only on a selection of buckets.
- prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
- prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
-
Replay the wrapped collector, but only on a selection of buckets.
- prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- prepareSettings(Settings) - Static method in class org.elasticsearch.node.InternalSettingsPreparer
-
Prepares the settings by gathering all elasticsearch system properties and setting defaults.
- prepareShardStores(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The shard stores info of one or more indices.
- prepareSimulatePipeline(BytesReference) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Deprecated.
- prepareSimulatePipeline(BytesReference, XContentType) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Simulates an ingest pipeline
- prepareSnapshotStatus() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- prepareSnapshotStatus(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- prepareState() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The state of the cluster.
- prepareStats(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices stats.
- prepareSyncedFlush(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly sync flush one or more indices (write sync id to shards for faster recovery).
- prepareTermVector() - Method in interface org.elasticsearch.client.Client
-
Deprecated.
- prepareTermVector() - Method in class org.elasticsearch.client.support.AbstractClient
-
Deprecated.
- prepareTermVector(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Deprecated.
- prepareTermVector(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
-
Deprecated.
- prepareTermVectors() - Method in interface org.elasticsearch.client.Client
-
Builder for the term vector request.
- prepareTermVectors() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareTermVectors(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Builder for the term vector request.
- prepareTermVectors(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareTypesExists(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices exists.
- prepareUpdate() - Method in interface org.elasticsearch.client.Client
-
Updates a document based on a script.
- prepareUpdate() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareUpdate(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Updates a document based on a script.
- prepareUpdate(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareUpdateSettings() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Update settings in the cluster.
- prepareUpdateSettings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Update indices settings.
- prepareUpgrade(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check upgrade status of one or more indices
- prepareUpgradeStatus(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly upgrade one or more indices
- prepareValidateQuery(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Validate a query for correctness.
- prepareVerifyRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Verifies a repository.
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.AllFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.IdFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
-
Called before
FieldMapper.parse(ParseContext)
on theRootObjectMapper
. - preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.UidFieldMapper
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- preProcess(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- preProcess(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
-
Should be called before executing the main query and after all other parameters have been set.
- preProcess(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
- preProcess(SearchContext) - Method in class org.elasticsearch.search.aggregations.AggregationPhase
- preProcess(SearchContext) - Method in class org.elasticsearch.search.dfs.DfsPhase
- preProcess(SearchContext) - Method in class org.elasticsearch.search.fetch.FetchPhase
- preProcess(SearchContext) - Method in class org.elasticsearch.search.query.QueryPhase
- preProcess(SearchContext) - Method in class org.elasticsearch.search.rescore.RescorePhase
- preProcess(SearchContext) - Method in interface org.elasticsearch.search.SearchPhase
-
Performs pre processing of the search context before the execute.
- preProcess(SearchContext) - Method in class org.elasticsearch.search.suggest.SuggestPhase
- PreProcessModule - Interface in org.elasticsearch.common.inject
-
A module can implement this interface to allow to pre process other modules before an injector is created.
- PRESERVE_POSITION_INCREMENTS - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- PRESERVE_SEP - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Include this flag in the options parameter to
#XAnalyzingSuggester(Analyzer,Analyzer,int,int,int,boolean,FST,boolean,int,int,int,int,int)
to preserve token separators when matching. - PRESERVE_SEPARATORS - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- preserveContext(Runnable) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Saves the current thread context and wraps command in a Runnable that restores that context before running command.
- preserveContext(Runnable) - Method in interface org.elasticsearch.threadpool.Scheduler
-
Does nothing by default but can be used by subclasses to save the current thread context and wraps the command in a Runnable that restores that context before running the command.
- preserveContext(Runnable) - Method in class org.elasticsearch.threadpool.ThreadPool
- preservePositionIncrements() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- preservePositionIncrements(boolean) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- preserveSep() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- preserveSeparators(boolean) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- PreShardSyncedFlushRequest() - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- PreShardSyncedFlushRequest(ShardId) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- preSpanQueryRewrite(Query) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- preTag() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the pre-tag for the highlighter set with
PhraseSuggestionBuilder.highlight(String, String)
- preTags - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- preTags() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- preTags() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- preTags(String...) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set the pre tags that will be used for highlighting.
- prettyPrint() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- prettyPrint() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- prettyPrint() - Method in class org.elasticsearch.common.StopWatch
-
Return a string with a table describing all tasks performed.
- previous() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- previousLevel() - Method in class org.elasticsearch.index.query.support.NestedScope
-
Sets the previous nested level as current nested level and removes and returns the current nested level.
- previousMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- previousState() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
The previous cluster state for this change event.
- PRIMARIES - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- PRIMARIES - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- primary - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- primary - Variable in class org.elasticsearch.index.shard.ShardStateMetaData
- primary() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- primary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
iff this shard is a primary. - primary() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- PRIMARY - org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Allocated as primary
- PRIMARY - org.elasticsearch.cluster.routing.Preference
-
Route to primary shards
- PRIMARY - org.elasticsearch.index.engine.Engine.Operation.Origin
- PRIMARY - org.elasticsearch.index.mapper.SourceToParse.Origin
- PRIMARY_FAILED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of a failed primary while the replica was initializing.
- PRIMARY_FIRST - org.elasticsearch.cluster.routing.Preference
-
Route to primary shards first
- PRIMARY_TERM_NAME - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- primaryActiveInitializingShardIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- PrimaryContext(long, Map<String, ReplicationTracker.CheckpointState>, IndexShardRoutingTable) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- PrimaryContext(StreamInput) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- primaryFirstActiveInitializingShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- PrimaryMissingActionException - Exception in org.elasticsearch.action
- PrimaryMissingActionException(String) - Constructor for exception org.elasticsearch.action.PrimaryMissingActionException
- PrimaryMissingActionException(StreamInput) - Constructor for exception org.elasticsearch.action.PrimaryMissingActionException
- PrimaryOperationTransportHandler() - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryOperationTransportHandler
- PrimaryReplicaSyncer - Class in org.elasticsearch.index.shard
- PrimaryReplicaSyncer(TaskManager, PrimaryReplicaSyncer.SyncAction) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer
- PrimaryReplicaSyncer(TransportService, TransportResyncReplicationAction) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer
- PrimaryReplicaSyncer.ResyncRequest - Class in org.elasticsearch.index.shard
- PrimaryReplicaSyncer.ResyncTask - Class in org.elasticsearch.index.shard
- PrimaryReplicaSyncer.ResyncTask.Status - Class in org.elasticsearch.index.shard
- PrimaryReplicaSyncer.SyncAction - Interface in org.elasticsearch.index.shard
- PrimaryResult(ReplicaRequest, Response) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- PrimaryResult(ReplicaRequest, Response, Exception) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
-
Result of executing a primary operation expects
finalResponseIfSuccessful
orfinalFailure
to be not-null - primaryShard() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- PrimaryShardAllocator - Class in org.elasticsearch.gateway
-
The primary shard allocator allocates unassigned primary shards to nodes that hold valid copies of the unassigned primaries.
- PrimaryShardAllocator() - Constructor for class org.elasticsearch.gateway.PrimaryShardAllocator
- primaryShardIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator only on the primary shard.
- primaryShardsActive() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Calculates the number of primary shards in active state in routing table
- primaryShardsUnassigned() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Calculates the number of primary shards in the routing table the are in
ShardRoutingState.UNASSIGNED
state. - primaryTerm - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- primaryTerm - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicasProxy
- primaryTerm - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- primaryTerm - Variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- primaryTerm() - Method in class org.elasticsearch.index.engine.Engine.Operation
- primaryTerm() - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
The primary term of this retention lease collection.
- primaryTerm() - Method in class org.elasticsearch.index.translog.Translog.Delete
- primaryTerm() - Method in class org.elasticsearch.index.translog.Translog.Index
- primaryTerm() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- primaryTerm() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- primaryTerm(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
returns the primary term for the given shard.
- primaryTerm(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
The term of the current selected primary.
- primaryTerm(int, long) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
sets the primary term for the given shard.
- printAdditionalHelp(Terminal) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- printBoostAndQueryName(XContentBuilder) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- printTo(Writer, long, Chronology, int, DateTimeZone, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
We adjust the instant by displayOffset to adjust for the offset that might have been added in
DateTimeFormatter.printTo(Appendable, long, Chronology)
when using a time zone. - printTo(Writer, ReadablePartial, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
- printTo(StringBuffer, long, Chronology, int, DateTimeZone, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
We adjust the instant by displayOffset to adjust for the offset that might have been added in
DateTimeFormatter.printTo(Appendable, long, Chronology)
when using a time zone. - printTo(StringBuffer, ReadablePartial, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
- PrioritizedCallable<T> - Class in org.elasticsearch.common.util.concurrent
- PrioritizedCallable(Priority) - Constructor for class org.elasticsearch.common.util.concurrent.PrioritizedCallable
- PrioritizedEsThreadPoolExecutor - Class in org.elasticsearch.common.util.concurrent
-
A prioritizing executor which uses a priority queue as a work queue.
- PrioritizedEsThreadPoolExecutor.Pending - Class in org.elasticsearch.common.util.concurrent
- PrioritizedRunnable - Class in org.elasticsearch.common.util.concurrent
- PrioritizedRunnable(Priority) - Constructor for class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
- priority - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- priority() - Method in class org.elasticsearch.cluster.ClusterStateTaskConfig.Basic
- priority() - Method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
The
Priority
for this cluster state update task configuration. - priority() - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
- priority() - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- priority() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedCallable
- priority() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
- Priority - Enum in org.elasticsearch.common
- PriorityComparator - Class in org.elasticsearch.gateway
-
A comparator that compares ShardRouting based on it's indexes priority (index.priority), it's creation date (index.creation_date), or eventually by it's index name in reverse order.
- PriorityComparator() - Constructor for class org.elasticsearch.gateway.PriorityComparator
- PrivateBinder - Interface in org.elasticsearch.common.inject
-
Returns a binder whose configuration information is hidden from its environment by default.
- PrivateElements - Interface in org.elasticsearch.common.inject.spi
-
A private collection of elements that are hidden from the enclosing injector or module by default.
- PrivateElementsImpl - Class in org.elasticsearch.common.inject.internal
- PrivateElementsImpl(Object) - Constructor for class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- PrivateIndex - org.elasticsearch.common.settings.Setting.Property
-
Indicates an index-level setting that is privately managed.
- PrivateModule - Class in org.elasticsearch.common.inject
-
A module whose configuration information is hidden from its environment by default.
- PrivateModule() - Constructor for class org.elasticsearch.common.inject.PrivateModule
- probablySingleFieldRequest() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- Probes - Class in org.elasticsearch.monitor
- Probes() - Constructor for class org.elasticsearch.monitor.Probes
- proceed(Task, String, Request, ActionListener<Response>) - Method in interface org.elasticsearch.action.support.ActionFilterChain
-
Continue processing the request.
- process() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node Process be returned.
- process() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node Process be returned.
- process(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node Process be returned.
- process(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node Process be returned.
- process(Version, MappingMetaData, String) - Method in class org.elasticsearch.action.index.IndexRequest
- processAllocation(RoutingAllocation) - Method in class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
-
Process any changes needed to the allocation based on this fetch result.
- processAsyncFetch(List<T>, List<FailedNodeException>, long) - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
Called by the response handler of the async action to fetch data.
- processButSkipLucene(boolean, long, long) - Static method in class org.elasticsearch.index.engine.InternalEngine.DeletionStrategy
- processButSkipLucene(boolean, long, long) - Static method in class org.elasticsearch.index.engine.InternalEngine.IndexingStrategy
- ProcessClusterEventTimeoutException - Exception in org.elasticsearch.cluster.metadata
- ProcessClusterEventTimeoutException(StreamInput) - Constructor for exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
- ProcessClusterEventTimeoutException(TimeValue, String) - Constructor for exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
- processDanglingIndices(MetaData) - Method in class org.elasticsearch.gateway.DanglingIndicesState
-
Process dangling indices based on the provided meta data, handling cleanup, finding new dangling indices, and allocating outstanding ones.
- processed - Variable in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
-
whether the task has been processed already
- processExistingRecoveries(RoutingAllocation) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
Process existing recoveries of replicas and see if we need to cancel them if we find a better match.
- processField(RootObjectMapper.Builder, String, Object, Version) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.TypeParser
- processInfo(long) - Method in class org.elasticsearch.monitor.process.ProcessProbe
- ProcessInfo - Class in org.elasticsearch.monitor.process
- ProcessInfo(long, boolean, long) - Constructor for class org.elasticsearch.monitor.process.ProcessInfo
- ProcessInfo(StreamInput) - Constructor for class org.elasticsearch.monitor.process.ProcessInfo
- processMessageReceived(Request, TransportChannel) - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- processModule(Module) - Method in interface org.elasticsearch.common.inject.PreProcessModule
- Processor - Interface in org.elasticsearch.ingest
-
A processor implementation may modify the data belonging to a document.
- PROCESSOR_RESULT_FIELD - Static variable in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- Processor.Factory - Interface in org.elasticsearch.ingest
-
A factory that knows how to construct a processor based on a map of maps.
- Processor.Parameters - Class in org.elasticsearch.ingest
-
Infrastructure class that holds services that can be used by processor factories to create processor instances and that gets passed around to all
IngestPlugin
s. - ProcessorInfo - Class in org.elasticsearch.ingest
- ProcessorInfo(String) - Constructor for class org.elasticsearch.ingest.ProcessorInfo
- ProcessorInfo(StreamInput) - Constructor for class org.elasticsearch.ingest.ProcessorInfo
-
Read from a stream.
- PROCESSORS_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- PROCESSORS_SETTING - Static variable in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Settings key to manually set the number of available processors.
- ProcessorStat(String, IngestStats.Stats) - Constructor for class org.elasticsearch.ingest.IngestStats.ProcessorStat
- processPendingDeletes(Index, IndexSettings, TimeValue) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
- processPendingDeletes(Index, IndexSettings, TimeValue) - Method in class org.elasticsearch.indices.IndicesService
-
Processes all pending deletes for the given index.
- ProcessProbe - Class in org.elasticsearch.monitor.process
- processRanges(Function<RangeAggregator.Range, RangeAggregator.Range>) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
-
Resolve any strings in the ranges so we have a number value for the from and to of each range.
- processReaders(IndexReader, IndexReader) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- processRecoverySettings(ClusterSettings, RecoverySettings) - Method in class org.elasticsearch.node.Node
- processResponse(Response) - Method in class org.elasticsearch.rest.action.RestActionListener
- processResponse(Response) - Method in class org.elasticsearch.rest.action.RestResponseListener
- processScale(double, double) - Method in interface org.elasticsearch.index.query.functionscore.DecayFunction
-
The final scale parameter is computed from the scale parameter given by the user and a value.
- processService() - Method in class org.elasticsearch.monitor.MonitorService
- ProcessService - Class in org.elasticsearch.monitor.process
- ProcessService(Settings) - Constructor for class org.elasticsearch.monitor.process.ProcessService
- processStats() - Method in class org.elasticsearch.monitor.process.ProcessProbe
- ProcessStats - Class in org.elasticsearch.monitor.process
- ProcessStats(long, long, long, ProcessStats.Cpu, ProcessStats.Mem) - Constructor for class org.elasticsearch.monitor.process.ProcessStats
- ProcessStats(StreamInput) - Constructor for class org.elasticsearch.monitor.process.ProcessStats
- ProcessStats.Cpu - Class in org.elasticsearch.monitor.process
- ProcessStats.Mem - Class in org.elasticsearch.monitor.process
- processTasks(CancelTasksRequest, Consumer<CancellableTask>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- processTasks(ListTasksRequest, Consumer<Task>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- processTasks(TasksRequest, Consumer<OperationTask>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- PRODUCTION - org.elasticsearch.common.inject.Stage
-
We want to catch errors as early as possible and take performance hits up front.
- profile() - Method in class org.elasticsearch.action.search.SearchResponseSections
-
Returns the profile results for this search response (including all shards).
- profile() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Return whether to profile query execution, or
null
if unspecified. - profile(boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should the query be profiled.
- PROFILE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- PROFILE_FIELD - Static variable in class org.elasticsearch.search.profile.SearchProfileShardResults
- profileAddresses() - Method in class org.elasticsearch.transport.TransportInfo
- profileBoundAddresses() - Method in class org.elasticsearch.transport.TcpTransport
- profileBoundAddresses() - Method in interface org.elasticsearch.transport.Transport
-
Further profile bound addresses
- profileName - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- ProfileResult - Class in org.elasticsearch.search.profile
-
This class is the internal representation of a profiled Query, corresponding to a single node in the query tree.
- ProfileResult(String, String, Map<String, Long>, List<ProfileResult>) - Constructor for class org.elasticsearch.search.profile.ProfileResult
- ProfileResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.ProfileResult
-
Read from a stream.
- profileResults - Variable in class org.elasticsearch.action.search.SearchResponseSections
- profileResults(ProfileShardResult) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Sets the finalized profiling results for this query
- Profilers - Class in org.elasticsearch.search.profile
-
Wrapper around all the profilers that makes management easier.
- Profilers(ContextIndexSearcher) - Constructor for class org.elasticsearch.search.profile.Profilers
-
Sole constructor.
- profileSettings - Variable in class org.elasticsearch.transport.TcpTransport
- ProfileSettings(Settings, String) - Constructor for class org.elasticsearch.transport.TcpTransport.ProfileSettings
- ProfileShardResult - Class in org.elasticsearch.search.profile
- ProfileShardResult(List<QueryProfileShardResult>, AggregationProfileShardResult) - Constructor for class org.elasticsearch.search.profile.ProfileShardResult
- ProfileShardResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.ProfileShardResult
- profileTree - Variable in class org.elasticsearch.search.profile.AbstractProfiler
- ProfileWeight - Class in org.elasticsearch.search.profile.query
-
Weight wrapper that will compute how much time it takes to build the
Scorer
and then return aScorer
that is wrapped in order to compute timings as well. - ProfileWeight(Query, Weight, QueryProfileBreakdown) - Constructor for class org.elasticsearch.search.profile.query.ProfileWeight
- ProfilingAggregator - Class in org.elasticsearch.search.profile.aggregation
- ProfilingAggregator(Aggregator, AggregationProfiler) - Constructor for class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- ProfilingLeafBucketCollector - Class in org.elasticsearch.search.profile.aggregation
- ProfilingLeafBucketCollector(LeafBucketCollector, AggregationProfileBreakdown) - Constructor for class org.elasticsearch.search.profile.aggregation.ProfilingLeafBucketCollector
- ProvidedBy - Annotation Type in org.elasticsearch.common.inject
-
A pointer to the default provider type for a type.
- Provider<T> - Interface in org.elasticsearch.common.inject
-
An object capable of providing instances of type
T
. - ProviderBinding<T extends Provider<?>> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a
Provider
that delegates to the binding for the provided type. - ProviderInstanceBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a provider instance.
- ProviderInstanceBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- ProviderInstanceBindingImpl(Object, Key<T>, Scoping, Set<InjectionPoint>, Provider<? extends T>) - Constructor for class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- ProviderInstanceBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Provider<? extends T>, Set<InjectionPoint>) - Constructor for class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- ProviderKeyBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a provider key.
- ProviderLookup<T> - Class in org.elasticsearch.common.inject.spi
-
A lookup of the provider for a type.
- ProviderLookup(Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.spi.ProviderLookup
- ProviderLookup.ProviderImpl<T> - Class in org.elasticsearch.common.inject.spi
- ProviderMethod<T> - Class in org.elasticsearch.common.inject.internal
-
A provider that invokes a method and returns its result.
- ProviderMethodsModule - Class in org.elasticsearch.common.inject.internal
-
Creates bindings to methods annotated with @
Provides
. - providerOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type modelling a
Provider
that provides elements of typeelementType
. - Providers - Class in org.elasticsearch.common.inject.util
-
Static utility methods for creating and working with instances of
Provider
. - ProviderWithDependencies<T> - Interface in org.elasticsearch.common.inject.spi
-
A provider with dependencies on other injected types.
- Provides - Annotation Type in org.elasticsearch.common.inject
-
Annotates methods of a
Module
to create a provider method binding. - ProvisionException - Exception in org.elasticsearch.common.inject
-
Indicates that there was a runtime failure while providing an instance.
- ProvisionException(Iterable<Message>) - Constructor for exception org.elasticsearch.common.inject.ProvisionException
-
Creates a ConfigurationException containing
messages
. - ProvisionException(String) - Constructor for exception org.elasticsearch.common.inject.ProvisionException
- ProvisionException(String, Throwable) - Constructor for exception org.elasticsearch.common.inject.ProvisionException
- PROXY_AUTHENTICATION - org.elasticsearch.rest.RestStatus
-
This code is similar to 401 (Unauthorized), but indicates that the client must first authenticate itself with the proxy.
- prune(Predicate<Transport.ResponseContext>) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Removes and returns all
Transport.ResponseContext
instances that match the predicate - pruneUnreferencedFiles(String, Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
This method removes all files from the given directory that are not referenced by the given segments file.
- publish(ClusterChangedEvent, int, Discovery.AckListener) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
-
publishes a cluster change event to other nodes.
- publish(ClusterChangedEvent, Discovery.AckListener) - Method in interface org.elasticsearch.discovery.Discovery
-
Publish all the changes to the cluster from the master (can be called just by the master).
- publish(ClusterChangedEvent, Discovery.AckListener) - Method in class org.elasticsearch.discovery.single.SingleNodeDiscovery
- publish(ClusterChangedEvent, Discovery.AckListener) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- PUBLISH_DIFF_ENABLE_SETTING - Static variable in class org.elasticsearch.discovery.DiscoverySettings
- PUBLISH_HOST - Static variable in class org.elasticsearch.transport.TransportSettings
- PUBLISH_HOST_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- PUBLISH_PORT - Static variable in class org.elasticsearch.transport.TransportSettings
- PUBLISH_PORT_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- PUBLISH_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.DiscoverySettings
-
sets the timeout for a complete publishing cycle, including both sending and committing.
- publishAddress() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- PublishClusterStateAction - Class in org.elasticsearch.discovery.zen
- PublishClusterStateAction(TransportService, NamedWriteableRegistry, PublishClusterStateAction.IncomingClusterStateListener, DiscoverySettings) - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateAction
- PublishClusterStateAction.CommitClusterStateRequest - Class in org.elasticsearch.discovery.zen
- PublishClusterStateAction.IncomingClusterStateListener - Interface in org.elasticsearch.discovery.zen
- PublishClusterStateStats - Class in org.elasticsearch.discovery.zen
-
Class encapsulating stats about the PublishClusterStateAction
- PublishClusterStateStats(long, long, long) - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateStats
- PublishClusterStateStats(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateStats
- publishHosts - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- publishPort - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- put(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- put(long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- put(long, T) - Method in interface org.elasticsearch.common.util.concurrent.ConcurrentMapLong
- put(long, T) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
-
Put this new (key, value) pair into this hash table and return the value that was previously associated with
key
or null in case of an insertion. - put(E) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- put(Item, Consumer<Exception>) - Method in class org.elasticsearch.common.util.concurrent.AsyncIOProcessor
-
Adds the given item to the queue.
- put(Long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- put(Object, Object) - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
- put(Object, Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
- put(String, boolean) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the boolean value.
- put(String, double) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the double value.
- put(String, float) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the float value.
- put(String, int) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the int value.
- put(String, long) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the long value.
- put(String, long, TimeUnit) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the time value.
- put(String, long, ByteSizeUnit) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the size value.
- put(String, Enum<?>) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets an enum setting with the provided setting key and enum instance.
- put(String, Object) - Method in class org.elasticsearch.script.DeprecationMap
- put(String, String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a setting with the provided setting key and value.
- put(String, Path) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a path setting with the provided setting key and path.
- put(String, Level) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets an level setting with the provided setting key and level instance.
- put(String, Version) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets an lucene version setting with the provided setting key and lucene version instance.
- put(String, ByteSizeValue) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a byteSizeValue setting with the provided setting key and byteSizeValue.
- put(String, TimeValue) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a time value setting with the provided setting key and value.
- put(String, ScriptDocValues<?>) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- put(String, Version) - Method in class org.elasticsearch.common.settings.Settings.Builder
- put(K, V) - Method in class org.elasticsearch.common.cache.Cache
-
Associates the specified value with the specified key in this map.
- put(K, V) - Method in class org.elasticsearch.common.collect.MapBuilder
- put(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- put(IndexMetaData.Builder) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- put(IndexMetaData, boolean) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- put(IndexTemplateMetaData) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- put(IndexTemplateMetaData.Builder) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- put(Settings) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets all the provided settings including secure settings
- put(Settings, boolean) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets all the provided settings.
- put(MetadataFieldMapper.Builder<?, ?>) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
- put(Version, T) - Method in interface org.elasticsearch.indices.analysis.PreBuiltCacheFactory.PreBuiltCache
- PUT - org.elasticsearch.rest.RestRequest.Method
- putAlias(AliasMetaData) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- putAlias(AliasMetaData) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- putAlias(AliasMetaData.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- putAlias(AliasMetaData.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- putAll(IntObjectAssociativeContainer<? extends VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- putAll(ObjectObjectAssociativeContainer<? extends KType, ? extends VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- putAll(Iterable<? extends IntObjectCursor<? extends VType>>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- putAll(Iterable<? extends ObjectObjectCursor<? extends KType, ? extends VType>>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- putAll(Map) - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
- putAll(Map) - Method in class org.elasticsearch.search.lookup.SourceLookup
- putAll(Map<? extends Long, ? extends T>) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- putAll(Map<? extends String, ?>) - Method in class org.elasticsearch.script.DeprecationMap
- putAll(Map<? extends String, ? extends ScriptDocValues<?>>) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- putAll(Map<Integer, VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
Puts all the entries in the map to the builder.
- putAll(Map<K, V>) - Method in class org.elasticsearch.common.collect.MapBuilder
- putAll(Map<KType, VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
Puts all the entries in the map to the builder.
- putContext(SearchContext) - Method in class org.elasticsearch.search.SearchService
- putCustom(String, Map<String, String>) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- putCustom(String, ClusterState.Custom) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- putCustom(String, MetaData.Custom) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- putHeader(String, String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Puts a header into the context
- putHeader(Map<String, String>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Puts all of the given headers into this context
- putIfAbsent(long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- putIfAbsent(long, T) - Method in interface org.elasticsearch.common.util.concurrent.ConcurrentMapLong
- putIfAbsent(Long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- putInContext(String, Object) - Method in class org.elasticsearch.search.internal.ScrollContext
-
Puts the object into the context
- PutIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
- PutIndexTemplateRequest - Class in org.elasticsearch.action.admin.indices.template.put
-
A request to create an index template.
- PutIndexTemplateRequest() - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- PutIndexTemplateRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Constructs a new put index template request with the provided name.
- PutIndexTemplateRequestBuilder - Class in org.elasticsearch.action.admin.indices.template.put
- PutIndexTemplateRequestBuilder(ElasticsearchClient, PutIndexTemplateAction) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
- PutIndexTemplateRequestBuilder(ElasticsearchClient, PutIndexTemplateAction, String) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
- putInSyncAllocationIds(int, Set<String>) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- putList(String, String...) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and an array of values.
- putList(String, List<String>) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and a list of values.
- putMapper(Mapper) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- putMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- putMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- putMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- putMapping(String, CompressedXContent) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- putMapping(PutMappingClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
- putMapping(PutMappingRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- putMapping(PutMappingRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- putMapping(MappingMetaData) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- PutMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.put
- PutMappingClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Cluster state update request that allows to put a mapping
- PutMappingClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- putMappingRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Create a create mapping request against one or more indices.
- PutMappingRequest - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Puts mapping definition registered under a specific type into one or more indices.
- PutMappingRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- PutMappingRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Constructs a new put mapping request against one or more indices.
- PutMappingRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Builder for a put mapping request
- PutMappingRequestBuilder(ElasticsearchClient, PutMappingAction) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
- putNull(String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a null value for the given setting key
- putPipeline(Map<DiscoveryNode, IngestInfo>, PutPipelineRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.ingest.IngestService
-
Stores the specified pipeline definition in the request.
- putPipeline(PutPipelineRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Stores an ingest pipeline
- putPipeline(PutPipelineRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Stores an ingest pipeline
- PutPipelineAction - Class in org.elasticsearch.action.ingest
- PutPipelineAction() - Constructor for class org.elasticsearch.action.ingest.PutPipelineAction
- PutPipelineRequest - Class in org.elasticsearch.action.ingest
- PutPipelineRequest(String, BytesReference) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequest
-
Deprecated.use
PutPipelineRequest(String, BytesReference, XContentType)
to avoid content type auto-detection - PutPipelineRequest(String, BytesReference, XContentType) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequest
-
Create a new pipeline request with the id and source along with the content type of the source
- PutPipelineRequestBuilder - Class in org.elasticsearch.action.ingest
- PutPipelineRequestBuilder(ElasticsearchClient, PutPipelineAction) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequestBuilder
- PutPipelineRequestBuilder(ElasticsearchClient, PutPipelineAction, String, BytesReference) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequestBuilder
-
Deprecated.
- PutPipelineRequestBuilder(ElasticsearchClient, PutPipelineAction, String, BytesReference, XContentType) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequestBuilder
- PutPipelineTransportAction - Class in org.elasticsearch.action.ingest
- PutPipelineTransportAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IngestService, TransportNodesInfoAction) - Constructor for class org.elasticsearch.action.ingest.PutPipelineTransportAction
- putProperties(Map<String, String>, Function<String, String>) - Method in class org.elasticsearch.common.settings.Settings.Builder
- putRepository(PutRepositoryRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Registers a snapshot repository.
- putRepository(PutRepositoryRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Registers a snapshot repository.
- PutRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Register repository action
- putRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Registers snapshot repository
- PutRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Register repository request.
- PutRepositoryRequest() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- PutRepositoryRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Constructs a new put repository request with the provided name.
- PutRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Register repository request builder
- PutRepositoryRequestBuilder(ElasticsearchClient, PutRepositoryAction) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Constructs register repository request
- PutRepositoryRequestBuilder(ElasticsearchClient, PutRepositoryAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Constructs register repository request for the repository with a given name
- PutRequest(String, String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- PutResponse(boolean, IndexTemplateMetaData) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutResponse
- putRolloverInfo(RolloverInfo) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- putStoredScript(PutStoredScriptRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Store a script in the cluster state
- putStoredScript(PutStoredScriptRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Store a script in the cluster state
- putStoredScript(ClusterService, PutStoredScriptRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.script.ScriptService
- PutStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- PutStoredScriptRequest - Class in org.elasticsearch.action.admin.cluster.storedscripts
- PutStoredScriptRequest() - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- PutStoredScriptRequest(String, String, BytesReference, XContentType, StoredScriptSource) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- PutStoredScriptRequestBuilder - Class in org.elasticsearch.action.admin.cluster.storedscripts
- PutStoredScriptRequestBuilder(ElasticsearchClient, PutStoredScriptAction) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequestBuilder
- putTemplate(PutIndexTemplateRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- putTemplate(PutIndexTemplateRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- putTemplate(MetaDataIndexTemplateService.PutRequest, MetaDataIndexTemplateService.PutListener) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService
- putTransient(String, Object) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Puts a transient header object into this context
Q
- QUADTREE - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.PrefixTrees
-
Deprecated.
- QUADTREE_LEVELS - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults
-
Deprecated.
- quadTreeCellHeight(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the height (in meters) of quadtree cells at a specific level
- quadTreeCellSize(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the size (in meters) of quadtree cells at a specific level
- quadTreeCellWidth(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the width (in meters) of quadtree cells at a specific level
- quadTreeLevelsForPrecision(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the number of levels needed for a specific precision.
- quadTreeLevelsForPrecision(String) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the number of levels needed for a specific precision.
- QUARTER - org.elasticsearch.common.rounding.DateTimeUnit
- QUARTER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- QuarterOfYear - Static variable in class org.elasticsearch.common.joda.Joda
- Quarters - Static variable in class org.elasticsearch.common.joda.Joda
- Queries - Class in org.elasticsearch.common.lucene.search
- Queries() - Constructor for class org.elasticsearch.common.lucene.search.Queries
- query - Variable in class org.elasticsearch.index.query.InnerHitContextBuilder
- query - Variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlighterContext
- query() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- query() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The query to validate.
- query() - Method in class org.elasticsearch.action.explain.ExplainRequest
- query() - Method in class org.elasticsearch.index.cache.IndexCache
- query() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the query that defines which documents the function_score query will be executed on.
- query() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Returns the nested query to execute.
- query() - Method in class org.elasticsearch.index.query.ParsedQuery
-
The query parsed.
- query() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the query for this request
- query() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- query() - Method in class org.elasticsearch.search.internal.SearchContext
-
The query to execute, might be rewritten.
- query() - Method in class org.elasticsearch.search.internal.SubSearchContext
- query() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- query(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- query(QueryBuilder) - Method in class org.elasticsearch.action.explain.ExplainRequest
- query(QueryBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the search query for this request.
- QUERY - Static variable in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction.Fields
- QUERY_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_AND_FETCH - org.elasticsearch.action.search.SearchType
-
Deprecated.
- QUERY_ARRAY - Static variable in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- QUERY_CAN_MATCH_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_FETCH_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- QUERY_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- QUERY_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- QUERY_ID_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_STRING_ALLOW_LEADING_WILDCARD - Static variable in class org.elasticsearch.index.IndexSettings
- QUERY_STRING_ANALYZE_WILDCARD - Static variable in class org.elasticsearch.index.IndexSettings
- QUERY_STRING_LENIENT_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- QUERY_THEN_FETCH - org.elasticsearch.action.search.SearchType
-
The query is executed against all shards, but only enough information is returned (not the document content).
- queryBoost() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- queryBoost() - Method in class org.elasticsearch.search.internal.SearchContext
- QueryBuilder - Interface in org.elasticsearch.index.query
- QueryBuilders - Class in org.elasticsearch.index.query
-
Utility class to create search queries.
- queryCache - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- queryCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- queryCache() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- queryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- queryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- QueryCache - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- QueryCache - Interface in org.elasticsearch.index.cache.query
- QueryCacheStats - Class in org.elasticsearch.index.cache.query
- QueryCacheStats() - Constructor for class org.elasticsearch.index.cache.query.QueryCacheStats
- QueryCacheStats(long, long, long, long, long) - Constructor for class org.elasticsearch.index.cache.query.QueryCacheStats
- queryCollectors() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- queryCollectors() - Method in class org.elasticsearch.search.internal.SearchContext
-
Return a view of the additional query collectors that should be run for this context.
- QueryExplanation - Class in org.elasticsearch.action.admin.indices.validate.query
- QueryExplanation(String, int, boolean, String, String) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- QueryFetchSearchResult - Class in org.elasticsearch.search.fetch
- QueryFetchSearchResult() - Constructor for class org.elasticsearch.search.fetch.QueryFetchSearchResult
- QueryFetchSearchResult(StreamInput) - Constructor for class org.elasticsearch.search.fetch.QueryFetchSearchResult
- QueryFetchSearchResult(QuerySearchResult, FetchSearchResult) - Constructor for class org.elasticsearch.search.fetch.QueryFetchSearchResult
- queryName - Variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- queryName() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Returns the query name for the query.
- queryName() - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Returns the arbitrary name assigned to the query (see named queries).
- queryName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- queryName(String) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Sets the query name for the query.
- queryName(String) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Sets the arbitrary name to be assigned to the query (see named queries).
- queryName(String) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- QueryParser<QB extends QueryBuilder> - Interface in org.elasticsearch.index.query
-
Defines a query parser that is able to parse
QueryBuilder
s fromXContent
. - QueryParserHelper - Class in org.elasticsearch.index.search
-
Helpers to extract and expand field names and boosts
- QueryParsers - Class in org.elasticsearch.index.query.support
- QueryPhase - Class in org.elasticsearch.search.query
-
Query phase of a search request, used to run the query and get back from each shard information about the matching documents (document ids and score or sort criteria) so that matches can be reduced on the coordinating node
- QueryPhase() - Constructor for class org.elasticsearch.search.query.QueryPhase
- QueryPhaseExecutionException - Exception in org.elasticsearch.search.query
- QueryPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.query.QueryPhaseExecutionException
- QueryPhaseExecutionException(SearchContext, String) - Constructor for exception org.elasticsearch.search.query.QueryPhaseExecutionException
- QueryPhaseExecutionException(SearchContext, String, Throwable) - Constructor for exception org.elasticsearch.search.query.QueryPhaseExecutionException
- QueryProfileBreakdown - Class in org.elasticsearch.search.profile.query
-
A record of timings for the various operations that may happen during query execution.
- QueryProfileBreakdown() - Constructor for class org.elasticsearch.search.profile.query.QueryProfileBreakdown
-
Sole constructor.
- QueryProfiler - Class in org.elasticsearch.search.profile.query
-
This class acts as a thread-local storage for profiling a query.
- QueryProfiler() - Constructor for class org.elasticsearch.search.profile.query.QueryProfiler
- QueryProfileShardResult - Class in org.elasticsearch.search.profile.query
-
A container class to hold the profile results for a single shard in the request.
- QueryProfileShardResult(List<ProfileResult>, long, CollectorResult) - Constructor for class org.elasticsearch.search.profile.query.QueryProfileShardResult
- QueryProfileShardResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.query.QueryProfileShardResult
-
Read from a stream.
- QueryRescoreContext(int) - Constructor for class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- QueryRescoreMode - Enum in org.elasticsearch.search.rescore
- QueryRescorer - Class in org.elasticsearch.search.rescore
- QueryRescorer() - Constructor for class org.elasticsearch.search.rescore.QueryRescorer
- QueryRescorer.QueryRescoreContext - Class in org.elasticsearch.search.rescore
- QueryRescorerBuilder - Class in org.elasticsearch.search.rescore
- QueryRescorerBuilder(StreamInput) - Constructor for class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Read from a stream.
- QueryRescorerBuilder(QueryBuilder) - Constructor for class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Creates a new
QueryRescorerBuilder
instance - queryResult() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- queryResult() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- queryResult() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- queryResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- queryResult() - Method in class org.elasticsearch.search.internal.SearchContext
- queryResult() - Method in class org.elasticsearch.search.internal.SubSearchContext
- queryResult() - Method in class org.elasticsearch.search.query.QuerySearchResult
- queryResult() - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- queryResult() - Method in class org.elasticsearch.search.SearchPhaseResult
-
Returns the query result iff it's included in this response otherwise
null
- QueryRewriteContext - Class in org.elasticsearch.index.query
-
Context object used to rewrite
QueryBuilder
instances into simplified version. - QueryRewriteContext(NamedXContentRegistry, NamedWriteableRegistry, Client, LongSupplier) - Constructor for class org.elasticsearch.index.query.QueryRewriteContext
- QuerySearchRequest - Class in org.elasticsearch.search.query
- QuerySearchRequest() - Constructor for class org.elasticsearch.search.query.QuerySearchRequest
- QuerySearchRequest(OriginalIndices, long, AggregatedDfs) - Constructor for class org.elasticsearch.search.query.QuerySearchRequest
- QuerySearchResult - Class in org.elasticsearch.search.query
- QuerySearchResult() - Constructor for class org.elasticsearch.search.query.QuerySearchResult
- QuerySearchResult(long, SearchShardTarget) - Constructor for class org.elasticsearch.search.query.QuerySearchResult
- QuerySearchResult(StreamInput) - Constructor for class org.elasticsearch.search.query.QuerySearchResult
- QueryShardContext - Class in org.elasticsearch.index.query
-
Context object used to create lucene queries on the shard level.
- QueryShardContext(int, IndexSettings, BitsetFilterCache, Function<IndexReaderContext, IndexSearcher>, BiFunction<MappedFieldType, String, IndexFieldData<?>>, MapperService, SimilarityService, ScriptService, NamedXContentRegistry, NamedWriteableRegistry, Client, IndexReader, LongSupplier, String) - Constructor for class org.elasticsearch.index.query.QueryShardContext
- QueryShardContext(QueryShardContext) - Constructor for class org.elasticsearch.index.query.QueryShardContext
- queryShardContextSupplier() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- QueryShardException - Exception in org.elasticsearch.index.query
-
Exception that is thrown when creating lucene queries on the shard
- QueryShardException(StreamInput) - Constructor for exception org.elasticsearch.index.query.QueryShardException
- QueryShardException(Index, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.query.QueryShardException
-
This constructor is provided for use in unit tests where a
QueryShardContext
may not be available - QueryShardException(QueryShardContext, String, Object...) - Constructor for exception org.elasticsearch.index.query.QueryShardException
- QueryShardException(QueryShardContext, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.query.QueryShardException
- QuerySpec(String, Writeable.Reader<T>, QueryParser<T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.QuerySpec
-
Specification of custom
Query
. - QuerySpec(ParseField, Writeable.Reader<T>, QueryParser<T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.QuerySpec
-
Specification of custom
Query
. - queryString() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- queryStringAllowLeadingWildcard() - Method in class org.elasticsearch.index.query.QueryShardContext
- queryStringAnalyzeWildcard() - Method in class org.elasticsearch.index.query.QueryShardContext
- queryStringLenient() - Method in class org.elasticsearch.index.query.QueryShardContext
- queryStringQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that parses a query string and runs it.
- QueryStringQueryBuilder - Class in org.elasticsearch.index.query
-
A query that parses a query string and runs it.
- QueryStringQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.QueryStringQueryBuilder
- QueryStringQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Read from a stream.
- QueryStringQueryParser - Class in org.elasticsearch.index.search
-
A
XQueryParser
that uses theMapperService
in order to build smarter queries based on the mapping information. - QueryStringQueryParser(QueryShardContext, boolean) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
-
Defaults to all queryiable fields extracted from the mapping for query terms
- QueryStringQueryParser(QueryShardContext, String) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
- QueryStringQueryParser(QueryShardContext, String, boolean) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
- QueryStringQueryParser(QueryShardContext, Map<String, Float>) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
- QueryStringQueryParser(QueryShardContext, Map<String, Float>, boolean) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
- queryStringTermQuery(Term) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
A term query to use when parsing a query string.
- QueryTimingType - Enum in org.elasticsearch.search.profile.query
- queryTypes() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Returns the narrowed down explicit types, or, if not set, all types.
- QueryValidationException - Exception in org.elasticsearch.index.query
-
This exception can be used to indicate various reasons why validation of a query has failed.
- QueryValidationException() - Constructor for exception org.elasticsearch.index.query.QueryValidationException
- queryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- QUEUE - org.elasticsearch.common.util.PageCacheRecycler.Type
- QueueResizingEsThreadPoolExecutor - Class in org.elasticsearch.common.util.concurrent
-
An extension to thread pool executor, which automatically adjusts the queue size of the
ResizableBlockingQueue
according to Little's Law. - queueSize - Variable in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- quote(String) - Static method in class org.elasticsearch.common.Strings
-
Quote the given String with single quotes.
- quoteAnalyzer() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string for phrase searches.
- quoteAnalyzer(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string for phrase searches.
- quoteFieldSuffix() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- quoteFieldSuffix() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Return the suffix to append to field names for phrase matching.
- quoteFieldSuffix() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Return the suffix to append for phrase matching, or
null
if no suffix should be appended. - quoteFieldSuffix(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
An optional field name suffix to automatically try and add to the field searched when using quoted text.
- quoteFieldSuffix(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Set the suffix to append to field names for phrase matching.
- quoteFieldSuffix(String) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Set the suffix to append to field names for phrase matching.
R
- radius() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Get the radius of the circle without unit
- radius(double, String) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Set the radius of the circle
- radius(double, DistanceUnit) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Set the radius of the circle
- radius(String) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Set the radius of the circle.
- radius(DistanceUnit.Distance) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Set the radius of the circle
- RamAccountingTermsEnum - Class in org.elasticsearch.index.fielddata
-
TermsEnum
that takes a CircuitBreaker, increasing the breaker every time.next(...)
is called. - RamAccountingTermsEnum(TermsEnum, CircuitBreaker, AbstractIndexFieldData.PerValueEstimator, String) - Constructor for class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Returns byte size of the underlying FST.
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.ByteBufferReference
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.BytesArray
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.BytesReference
-
The amount of memory used by this BytesReference
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- ramBytesUsed() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
-
Returns the number of bytes used by the underlying
ByteArray
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.Ordinals
-
The memory size this ordinals take.
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.SinglePackedOrdinals
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVAtomicFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVBytesAtomicFieldData
- ramTree - Variable in class org.elasticsearch.index.engine.Segment
- RANDOM_SHARD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- randomAllActiveShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Returns an unordered iterator over all active shards (including replicas).
- randomBase64UUID() - Static method in class org.elasticsearch.common.UUIDs
-
Returns a Base64 encoded version of a Version 4.0 compatible UUID as defined here: http://www.ietf.org/rfc/rfc4122.txt, using a private
SecureRandom
instance - randomBase64UUID(Random) - Static method in class org.elasticsearch.common.UUIDs
-
Returns a Base64 encoded version of a Version 4.0 compatible UUID as defined here: http://www.ietf.org/rfc/rfc4122.txt, using the provided
Random
instance - randomBase64UUIDSecureString() - Static method in class org.elasticsearch.common.UUIDs
-
Returns a Base64 encoded
SecureString
of a Version 4.0 compatible UUID as defined here: http://www.ietf.org/rfc/rfc4122.txt, using a privateSecureRandom
instance - randomFunction() - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- Randomness - Class in org.elasticsearch.common
-
Provides factory methods for producing reproducible sources of randomness.
- RandomScoreFunction - Class in org.elasticsearch.common.lucene.search.function
-
Pseudo randomly generate a score for each
LeafScoreFunction.score(int, float)
. - RandomScoreFunction(int, int, IndexFieldData<?>) - Constructor for class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
-
Creates a RandomScoreFunction.
- RandomScoreFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
-
A function that computes a random score for the matched documents
- RandomScoreFunctionBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- RandomScoreFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
Read from a stream.
- range() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- range(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Range
aggregation with the given name. - Range - Interface in org.elasticsearch.search.aggregations.bucket.range
-
A
range
aggregation. - Range(String, Double, Double) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder.Range
- Range(String, Double, Double) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- Range(String, Double, String, Double, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- Range(String, String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- Range(String, BytesRef, BytesRef) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator.Range
- Range(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder.Range
-
Read from a stream.
- Range(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
-
Read from a stream.
- Range(RangeFieldMapper.RangeType, Object, Object, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- Range.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.range
-
A bucket associated with a specific range
- RangeAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- RangeAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Read from a stream.
- RangeAggregationBuilder(RangeAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- RangeAggregator - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregator(String, AggregatorFactories, ValuesSource.Numeric, DocValueFormat, InternalRange.Factory, RangeAggregator.Range[], boolean, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- RangeAggregator.Range - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregator.Unmapped<R extends RangeAggregator.Range> - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, RangeAggregator.Range[], boolean, InternalRange.Factory<?, ?>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregatorFactory
- rangeFactory - Variable in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- RangeFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for indexing numeric and date ranges, and creating queries - RangeFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- RangeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- RangeFieldMapper.Range - Class in org.elasticsearch.index.mapper
-
Class defining a range
- RangeFieldMapper.RangeFieldType - Class in org.elasticsearch.index.mapper
- RangeFieldMapper.RangeType - Enum in org.elasticsearch.index.mapper
-
Enum defining the type of range
- RangeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, DateTimeZone, DateMathParser, QueryShardContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, DateTimeZone, DateMathParser, QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Factory method for range queries.
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, DateTimeZone, DateMathParser, QueryShardContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, DateTimeZone, DateMathParser, QueryShardContext) - Method in class org.elasticsearch.index.mapper.SimpleMappedFieldType
- rangeQuery(Object, Object, boolean, boolean, QueryShardContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- rangeQuery(Object, Object, boolean, boolean, QueryShardContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- rangeQuery(Object, Object, boolean, boolean, QueryShardContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- rangeQuery(Object, Object, boolean, boolean, QueryShardContext) - Method in class org.elasticsearch.index.mapper.SimpleMappedFieldType
-
Same as
SimpleMappedFieldType.rangeQuery(Object, Object, boolean, boolean, ShapeRelation, DateTimeZone, DateMathParser, QueryShardContext)
but without the trouble of relations or date-specific options. - rangeQuery(Object, Object, boolean, boolean, QueryShardContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- rangeQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents within an range of terms.
- rangeQuery(String, boolean, Object, Object, boolean, boolean, ShapeRelation, DateTimeZone, DateMathParser, QueryShardContext) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- rangeQuery(String, Object, Object, boolean, boolean, boolean) - Method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- RangeQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents within an range of terms.
- RangeQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.RangeQueryBuilder
-
A Query that matches documents within an range of terms.
- RangeQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.RangeQueryBuilder
-
Read from a stream.
- ranges - Variable in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- ranges() - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- RANGES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- rangeType - Variable in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- rank(long) - Method in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- rateLimiter() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- RateLimitingInputStream - Class in org.elasticsearch.index.snapshots.blobstore
-
Rate limiting wrapper for InputStream
- RateLimitingInputStream(InputStream, RateLimiter, RateLimitingInputStream.Listener) - Constructor for class org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream
- RateLimitingInputStream.Listener - Interface in org.elasticsearch.index.snapshots.blobstore
- RatioValue - Class in org.elasticsearch.common.unit
-
Utility class to represent ratio and percentage values between 0 and 100
- RatioValue(double) - Constructor for class org.elasticsearch.common.unit.RatioValue
- RAW - Static variable in interface org.elasticsearch.search.DocValueFormat
- rawPath() - Method in class org.elasticsearch.rest.RestRequest
-
The non decoded, raw path provided.
- RawTaskStatus - Class in org.elasticsearch.tasks
-
Raw, unparsed status from the task results index.
- RawTaskStatus(BytesReference) - Constructor for class org.elasticsearch.tasks.RawTaskStatus
- RawTaskStatus(StreamInput) - Constructor for class org.elasticsearch.tasks.RawTaskStatus
-
Read from a stream.
- read() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- read() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- read() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- read() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- read() - Method in class org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream
- read() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
- read() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- read(byte[]) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- read(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- read(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- read(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- read(byte[], int, int) - Method in class org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream
- read(byte[], int, int) - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
- read(BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
-
Reads and parses the blob with given name, applying name translation using the {link #blobName} method
- read(BytesReference) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
- read(StreamInput) - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- read(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- read(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Allows to read an alias from the provided input stream
- read(StreamInput) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- read(StreamInput) - Method in interface org.elasticsearch.common.io.stream.Writeable.Reader
-
Read
V
-type value from a stream. - read(StreamInput) - Static method in class org.elasticsearch.common.rounding.Rounding.Streams
- read(StreamInput) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
- read(StreamInput) - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
- read(StreamInput) - Method in class org.elasticsearch.transport.PlainTransportFuture
- read(StreamInput) - Method in class org.elasticsearch.transport.TransportChannelResponseHandler
- read(StreamInput) - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- read(StreamInput, long, long, DocValueFormat) - Method in interface org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket.Reader
- read(StreamInput, String) - Method in class org.elasticsearch.cluster.NamedDiffableValueSerializer
- read(StreamInput, K) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueReader
- read(StreamInput, K) - Method in class org.elasticsearch.cluster.DiffableUtils.StringSetValueSerializer
- read(StreamInput, K) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Reads value from stream.
- read(StreamInput, DocValueFormat, boolean) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket.Reader
- read(NamedXContentRegistry, Path) - Method in class org.elasticsearch.gateway.MetaDataStateFormat
-
Reads the state from a given file and compares the expected version against the actual version of the state.
- read(BufferedChecksumStreamInput) - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- READ - org.elasticsearch.cluster.block.ClusterBlockLevel
- READ_WRITE - Static variable in enum org.elasticsearch.cluster.block.ClusterBlockLevel
- readAggregatedDfs(StreamInput) - Static method in class org.elasticsearch.search.dfs.AggregatedDfs
- readAggregations(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
- readAllLines(InputStream) - Static method in class org.elasticsearch.common.io.Streams
- readAllLines(InputStream, Consumer<String>) - Static method in class org.elasticsearch.common.io.Streams
- readAllowed() - Method in class org.elasticsearch.index.shard.IndexShard
- readAnalyzeToken(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- readAnalyzeTokenList(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- readArray(Writeable.Reader<T>, IntFunction<T[]>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an array from the stream using the specified
Writeable.Reader
to read array elements from the stream. - readBlob(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Creates a new
InputStream
for the given blob name. - readBlob(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- readBlob(BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
-
Reads and parses the blob with given blob name.
- readBlob(BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
Reads blob with specified name without resolving the blobName using using
BlobStoreFormat.blobName(java.lang.String)
method. - readBoolean() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a boolean.
- readBooleanProperty(String, String, Map<String, Object>, String, boolean) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readBoundTransportAddress(StreamInput) - Static method in class org.elasticsearch.common.transport.BoundTransportAddress
- readBuild(StreamInput) - Static method in class org.elasticsearch.Build
- readBulkItem(StreamInput) - Static method in class org.elasticsearch.action.bulk.BulkItemRequest
- readBulkItem(StreamInput) - Static method in class org.elasticsearch.action.bulk.BulkItemResponse
- readByte() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- readByte() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readByte() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- readByte() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads and returns a single byte.
- readByte() - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- readByte() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readByteArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a specified number of bytes into an array at the specified offset.
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.BaseTranslogReader
-
reads bytes at position into the given buffer, filling it.
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.TranslogReader
-
reads an operation at the given position into the given buffer.
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.TranslogWriter
- readBytesRef() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readBytesRef(int) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readBytesReference() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a bytes reference from this stream, might hold an actual reference to the underlying bytes of the stream.
- readBytesReference(int) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a bytes reference from this stream, might hold an actual reference to the underlying bytes of the stream.
- readCharFilteredText(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- readClusterBlock(StreamInput) - Static method in class org.elasticsearch.cluster.block.ClusterBlock
- readCompressedString(StreamInput) - Static method in class org.elasticsearch.common.compress.CompressedXContent
- readDiff(StreamInput, String) - Method in class org.elasticsearch.cluster.NamedDiffableValueSerializer
- readDiff(StreamInput, K) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueReader
- readDiff(StreamInput, K) - Method in class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- readDiff(StreamInput, K) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Reads value as diff from stream if this serializer supports diffable values.
- readDiffFrom(Class<? extends T>, String, StreamInput) - Static method in class org.elasticsearch.cluster.AbstractNamedDiffable
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.block.ClusterBlocks
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.MappingMetaData
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.MetaData
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.RestoreInProgress
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.ingest.IngestMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.ingest.PipelineConfiguration
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.script.ScriptMetaData
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.script.StoredScriptSource
-
Required for
ScriptMetaData.ScriptMetadataDiff
. - readDiffFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState
- readDiffFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
- readDiffFrom(Writeable.Reader<T>, StreamInput) - Static method in class org.elasticsearch.cluster.AbstractDiffable
- readDocumentField(StreamInput) - Static method in class org.elasticsearch.common.document.DocumentField
- readDocumentRequest(StreamInput) - Static method in interface org.elasticsearch.action.DocWriteRequest
-
read a document write (index/delete/update) request
- readDouble() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readDoubleArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readDoubleLE(byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Read a double in little-endian format.
- readEmptyResultFrom(StreamInput) - Static method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.EmptyResult
- readEnum(Class<E>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an enum with type E that was serialized based on the value of it's ordinal
- readEnumSet(Class<E>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an enum with type E that was serialized based on the value of it's ordinal
- reader - Variable in class org.elasticsearch.common.io.stream.NamedWriteableRegistry.Entry
-
A reader capability of reading
- reader - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- reader - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
- reader - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- reader() - Method in class org.elasticsearch.index.engine.Engine.Searcher
- reader() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- readerContext() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- readerKey - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- readerValue() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- readException() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readException(StreamInput, int) - Static method in exception org.elasticsearch.ElasticsearchException
- readExplanation(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readFailure(StreamInput) - Static method in class org.elasticsearch.action.get.MultiGetResponse.Failure
- readFailure(StreamInput) - Static method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
- readFetchSearchResult(StreamInput) - Static method in class org.elasticsearch.search.fetch.FetchSearchResult
- readFieldDoc(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readFieldStats(StreamInput) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- readFieldStats(StreamInput, ObjectObjectHashMap<String, CollectionStatistics>) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- readFloat() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readFloatArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readFloatLE(byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Read a float in little-endian format.
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ActionRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ActionResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction.NodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction.NodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction.NodeStatsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction.NodeUsageRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction.ClusterStatsNodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.ShardUpgradeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.bulk.BulkItemResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.bulk.BulkRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.bulk.BulkResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.delete.DeleteRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.DocWriteResponse
- readFrom(StreamInput) - Static method in enum org.elasticsearch.action.DocWriteResponse.Result
- readFrom(StreamInput) - Method in class org.elasticsearch.action.explain.ExplainRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.explain.ExplainResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.GetRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.GetResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.MultiGetItemResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.MultiGetRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.MultiGetResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.index.IndexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ingest.GetPipelineRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.main.MainResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.ClearScrollResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.MultiSearchRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.MultiSearchResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.SearchRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.SearchResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.SearchTransportService.SearchFreeContextResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.search.ShardSearchFailure
- readFrom(StreamInput) - Static method in class org.elasticsearch.action.support.ActiveShardCount
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.EmptyResult
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.master.MasterNodeReadRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.BaseNodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.BaseNodeResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- readFrom(StreamInput) - Static method in enum org.elasticsearch.action.support.WriteRequest.RefreshPolicy
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.action.update.UpdateRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.action.update.UpdateResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.block.ClusterBlock
- readFrom(StreamInput) - Static method in enum org.elasticsearch.cluster.health.ClusterHealthStatus
-
Read from a stream.
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.MetaData
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Reads restore status from stream input
- readFrom(StreamInput) - Static method in enum org.elasticsearch.cluster.routing.allocation.AllocationDecision
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Reads a
AllocationCommands
from aStreamInput
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- readFrom(StreamInput) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
-
Read in a RoutingExplanations object
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RecoverySource
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- readFrom(StreamInput) - Static method in enum org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- readFrom(StreamInput) - Method in class org.elasticsearch.common.document.DocumentField
- readFrom(StreamInput) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
- readFrom(StreamInput) - Method in interface org.elasticsearch.common.io.stream.Streamable
-
Set this object's fields from a StreamInput.
- readFrom(StreamInput) - Static method in enum org.elasticsearch.common.Priority
- readFrom(StreamInput) - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- readFrom(StreamInput) - Static method in enum org.elasticsearch.common.unit.ByteSizeUnit
-
Reads a
ByteSizeUnit
from a givenStreamInput
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.MembershipAction.JoinRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.MembershipAction.LeaveRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction.CommitClusterStateRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.RejoinClusterRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeGatewayMetaState
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.engine.CommitStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.engine.Segment
- readFrom(StreamInput) - Method in class org.elasticsearch.index.engine.SegmentsStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.flush.FlushStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.get.GetResult
- readFrom(StreamInput) - Method in class org.elasticsearch.index.get.GetStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.merge.MergeStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.refresh.RefreshStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.index.reindex.ReindexRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.index.shard.DocsStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.shard.IndexingStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.shard.ShardId
- readFrom(StreamInput) - Method in class org.elasticsearch.index.store.StoreStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.translog.TranslogStats
- readFrom(StreamInput) - Method in class org.elasticsearch.index.warmer.WarmerStats
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.NodeIndicesStats
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryFinalizeRecoveryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryWaitForClusterStateRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- readFrom(StreamInput) - Static method in class org.elasticsearch.ingest.PipelineConfiguration
- readFrom(StreamInput) - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.persistent.PersistentTaskResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- readFrom(StreamInput) - Method in class org.elasticsearch.repositories.VerificationFailure
- readFrom(StreamInput) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction.VerifyNodeRepositoryRequest
- readFrom(StreamInput) - Static method in enum org.elasticsearch.rest.RestStatus
- readFrom(StreamInput) - Static method in enum org.elasticsearch.script.ScriptType
-
Reads an int from the input stream and converts it to a
ScriptType
. - readFrom(StreamInput) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceParserHelper
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
- readFrom(StreamInput) - Static method in enum org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Deserialize the GapPolicy from the input stream
- readFrom(StreamInput) - Static method in enum org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.SeasonalityType
-
Deserialize the SeasonalityType from the input stream
- readFrom(StreamInput) - Method in class org.elasticsearch.search.dfs.AggregatedDfs
- readFrom(StreamInput) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- readFrom(StreamInput) - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- readFrom(StreamInput) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- readFrom(StreamInput) - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- readFrom(StreamInput) - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.search.query.QuerySearchRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.search.query.QuerySearchResult
- readFrom(StreamInput) - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- readFrom(StreamInput) - Method in class org.elasticsearch.search.SearchHit
- readFrom(StreamInput) - Method in class org.elasticsearch.search.SearchHits
- readFrom(StreamInput) - Method in class org.elasticsearch.search.SearchService.CanMatchResponse
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.Suggest
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- readFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- readFrom(StreamInput) - Method in class org.elasticsearch.snapshots.RestoreInfo
- readFrom(StreamInput) - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
- readFrom(StreamInput) - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.BytesTransportRequest
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.TransportMessage
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.TransportRequest
- readFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState
- readFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
- readFrom(StreamInput, BigArrays) - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- readFromFileChannel(FileChannel, long, byte[], int, int) - Static method in class org.elasticsearch.common.io.Channels
-
read length bytes from position of a file channel.
- readFromFileChannel(FileChannel, long, int) - Static method in class org.elasticsearch.common.io.Channels
-
read length bytes from position of a file channel
- readFromFileChannel(FileChannel, long, ByteBuffer) - Static method in class org.elasticsearch.common.io.Channels
-
read from a file channel into a byte buffer, starting at a certain position.
- readFromFileChannelWithEofException(FileChannel, long, byte[], int, int) - Static method in class org.elasticsearch.common.io.Channels
-
read length bytes from position of a file channel.
- readFromFileChannelWithEofException(FileChannel, long, ByteBuffer) - Static method in class org.elasticsearch.common.io.Channels
-
read from a file channel into a byte buffer, starting at a certain position.
- readFromProperties(Path) - Static method in class org.elasticsearch.plugins.PluginInfo
-
Reads the plugin descriptor file.
- readFromStream(StreamInput) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.common.geo.GeoDistance
-
Creates a GeoDistance instance from an input stream
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.common.geo.ShapeRelation
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.common.geo.SpatialStrategy
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
-
Read a
DistanceUnit
from aStreamInput
. - readFromStream(StreamInput) - Static method in enum org.elasticsearch.index.query.GeoExecType
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.index.query.GeoValidationMethod
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.index.query.Operator
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.index.search.MatchQuery.Type
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.index.search.MatchQuery.ZeroTermsQuery
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.index.VersionType
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.aggregations.support.ValueType
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.rescore.QueryRescoreMode
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.sort.SortMode
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.sort.SortOrder
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.suggest.SortBy
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
- readFromStream(StreamInput) - Static method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
- readFromStream(StreamInput) - Static method in class org.elasticsearch.tasks.TaskId
-
Read a TaskId from a stream.
- readFromThin(StreamInput, Index) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- readFromWithId(long, StreamInput) - Method in class org.elasticsearch.search.query.QuerySearchResult
- readFully(byte[]) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readFully(InputStream, byte[]) - Static method in class org.elasticsearch.common.io.Streams
- readFully(InputStream, byte[], int, int) - Static method in class org.elasticsearch.common.io.Streams
- readFully(Reader, char[]) - Static method in class org.elasticsearch.common.io.Streams
- readFully(Reader, char[], int, int) - Static method in class org.elasticsearch.common.io.Streams
- readGenericValue() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readGeoPoint() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a
GeoPoint
from this stream input - readGetResult(StreamInput) - Static method in class org.elasticsearch.index.get.GetResult
- readGlobalCheckpoint(Path, String) - Static method in class org.elasticsearch.index.translog.Translog
-
Reads the sequence numbers global checkpoint from the translog checkpoint.
- readHeaders(StreamInput) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Reads the headers from the stream into the current context
- readHighlightField(StreamInput) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- readHistogramOrder(StreamInput, boolean) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Streams
-
ONLY FOR HISTOGRAM ORDER: Backwards compatibility logic to read a
BucketOrder
from aStreamInput
. - readHistoryOperations(String, MapperService, long) - Method in class org.elasticsearch.index.engine.Engine
-
Creates a new history snapshot for reading operations since
startingSeqNo
(inclusive). - readHistoryOperations(String, MapperService, long) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Creates a new history snapshot for reading operations since the provided seqno.
- readHistoryOperations(String, MapperService, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- readImmutableOpenIntMapDiff(StreamInput, DiffableUtils.KeySerializer<Integer>, DiffableUtils.ValueSerializer<Integer, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenMaps
- readImmutableOpenIntMapDiff(StreamInput, DiffableUtils.KeySerializer<Integer>, Writeable.Reader<T>, Writeable.Reader<Diff<T>>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenIntMaps of Diffable objects using Diffable proto object
- readImmutableOpenMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenMaps
- readImmutableOpenMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, Writeable.Reader<T>, Writeable.Reader<Diff<T>>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenMaps of Diffable objects using Diffable proto object
- readIndexShardStats(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- readIndicesOptions(StreamInput) - Static method in class org.elasticsearch.action.support.IndicesOptions
- readIndicesStats(StreamInput) - Static method in class org.elasticsearch.indices.NodeIndicesStats
- readInstant() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an
Instant
from the stream with nanosecond resolution - readInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads four bytes and returns an int.
- readIntArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readIntLE(byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Read an int in little-endian format.
- readIntProperty(String, String, Map<String, Object>, String, Integer) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readItem(StreamInput) - Static method in class org.elasticsearch.action.get.MultiGetRequest.Item
- readItem(StreamInput) - Static method in class org.elasticsearch.action.search.MultiSearchResponse.Item
- readItemResponse(StreamInput) - Static method in class org.elasticsearch.action.get.MultiGetItemResponse
- readItemResponse(StreamInput) - Static method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
- readJdkMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two Maps of Diffable objects
- readJdkMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, Writeable.Reader<T>, Writeable.Reader<Diff<T>>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two Maps of Diffable objects using Diffable proto object
- readKey(StreamInput) - Method in interface org.elasticsearch.cluster.DiffableUtils.KeySerializer
- readKilobytes() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- readLastCommittedSegmentsInfo() - Method in class org.elasticsearch.index.store.Store
-
Returns the last committed segments info for this store
- readList(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property of type list from the specified configuration map.
- readList(Writeable.Reader<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a list of objects.
- readListShardStoreNodeOperationResponse(StreamInput) - Static method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
- readLock - Variable in class org.elasticsearch.index.engine.Engine
- readLock - Variable in class org.elasticsearch.index.translog.Translog
- readLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads eight bytes and returns a long.
- readLongArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readLongLE(byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Write a long in little-endian format.
- readMap() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readMap(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property of type map from the specified configuration map.
- readMap(Writeable.Reader<K>, Writeable.Reader<V>) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readMapOfLists(Writeable.Reader<K>, Writeable.Reader<V>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read a
Map
ofK
-type keys toV
-typeList
s. - readMessageLength(BytesReference) - Static method in class org.elasticsearch.transport.TcpTransport
-
Validates the first 6 bytes of the message header and returns the length of the message.
- readMetadataSnapshot(Path, ShardId, NodeEnvironment.ShardLocker, Logger) - Static method in class org.elasticsearch.index.store.Store
-
Reads a MetadataSnapshot from the given index locations or returns an empty snapshot if it can't be read.
- readMinTranslogGeneration(Path, String) - Static method in class org.elasticsearch.index.translog.Translog
-
Returns the minimum translog generation retained by the translog at the given location.
- readMultiLineFormat(BytesReference, XContent, CheckedBiConsumer<SearchRequest, XContentParser, IOException>, String[], IndicesOptions, String[], String, String, NamedXContentRegistry, boolean) - Static method in class org.elasticsearch.action.search.MultiSearchRequest
- readMultiValueModeFrom(StreamInput) - Static method in enum org.elasticsearch.search.MultiValueMode
- readNamedWriteable(Class<C>) - Method in class org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- readNamedWriteable(Class<C>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a
NamedWriteable
from the current stream, by first reading its name and then looking for the corresponding entry in the registry by name, so that the proper object can be read and returned. - readNamedWriteable(Class<C>, String) - Method in class org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- readNamedWriteable(Class<C>, String) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a
NamedWriteable
from the current stream with the given name. - readNamedWriteableList(Class<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a list of
NamedWriteable
s. - readNode(StreamInput) - Static method in class org.elasticsearch.repositories.VerificationFailure
- readNodeHotThreads(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- readNodeInfo(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- readNodeResponse(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- readNodeResponse(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Read the
BaseNodesResponse.nodes
from the stream. - readNodesFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodesGatewayMetaState
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodesGatewayStartedShards
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
- readNodeStats(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- readNodeStats(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- readObject(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property as an
Object
from the specified configuration map. - ReadOnlyEngine - Class in org.elasticsearch.index.engine
-
A basic read-only engine that allows switching a shard to be true read-only temporarily or permanently.
- ReadOnlyEngine(EngineConfig, SeqNoStats, TranslogStats, boolean, Function<DirectoryReader, DirectoryReader>) - Constructor for class org.elasticsearch.index.engine.ReadOnlyEngine
-
Creates a new ReadOnlyEngine.
- readOperation(StreamInput) - Static method in interface org.elasticsearch.index.translog.Translog.Operation
-
Reads the type and the operation from the given stream.
- readOperation(Translog.Location) - Method in class org.elasticsearch.index.translog.Translog
-
Reads and returns the operation from the given location if the generation it references is still available.
- readOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- readOperations(StreamInput, String) - Static method in class org.elasticsearch.index.translog.Translog
-
Reads a list of operations written with
Translog.writeOperations(StreamOutput, List)
- readOptionalArray(Writeable.Reader<T>, IntFunction<T[]>) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalBoolean() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalBytesReference() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an optional bytes reference from this stream.
- readOptionalCommitStatsFrom(StreamInput) - Static method in class org.elasticsearch.index.engine.CommitStats
- readOptionalDouble() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalFloat() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalInstant() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an optional
Instant
from the stream. - readOptionalList(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property of type list from the specified configuration map.
- readOptionalLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalMap(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property of type map from the specified configuration map.
- readOptionalNamedWriteable(Class<C>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an optional
NamedWriteable
. - readOptionalRestoreInfo(StreamInput) - Static method in class org.elasticsearch.snapshots.RestoreInfo
-
Reads optional restore info from
StreamInput
- readOptionalStreamable(Supplier<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Serializes a potential null value.
- readOptionalString() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalStringArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalStringOrIntProperty(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readOptionalStringProperty(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified optional property from the specified configuration map.
- readOptionalText() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalTimeValue() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an optional
TimeValue
from the stream, returning null if no TimeValue was written. - readOptionalTimeZone() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an optional DateTimeZone.
- readOptionalVInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalWriteable(Writeable.Reader<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOrder(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Streams
-
Read a
BucketOrder
from aStreamInput
. - readOriginalIndices(StreamInput) - Static method in class org.elasticsearch.action.OriginalIndices
- readPerFieldAnalyzer(Map<String, Object>) - Static method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- readProcessor(Map<String, Processor.Factory>, ScriptService, String, Object) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readProcessor(Map<String, Processor.Factory>, ScriptService, String, Map<String, Object>) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readProcessorConfigs(List<Map<String, Object>>, ScriptService, Map<String, Processor.Factory>) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readQueryExplanation(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- readQueryFetchSearchResult(StreamInput) - Static method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- readQuerySearchResult(StreamInput) - Static method in class org.elasticsearch.search.query.QuerySearchResult
- readRecoveryState(StreamInput) - Static method in class org.elasticsearch.indices.recovery.RecoveryState
- readRecoveryStats(StreamInput) - Static method in class org.elasticsearch.index.recovery.RecoveryStats
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Deserialize a request from an input stream
- readResponseFrom(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- readScoreDoc(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readSearchHit(StreamInput) - Static method in class org.elasticsearch.search.SearchHit
- readSearchHits(StreamInput) - Static method in class org.elasticsearch.search.SearchHits
- readSegment(StreamInput) - Static method in class org.elasticsearch.index.engine.Segment
- readSegmentInfos(IndexCommit) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Reads the segments infos from the given commit, failing if it fails to load
- readSegmentInfos(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Reads the segments infos, failing if it fails to load
- readSet(Writeable.Reader<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a set of objects
- readSettingsFromStream(StreamInput) - Static method in class org.elasticsearch.common.settings.Settings
- readShardId(StreamInput) - Static method in class org.elasticsearch.index.shard.ShardId
- readShardOperationFailed(StreamInput) - Static method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
- readShardRestoreStatus(StreamInput) - Static method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Reads restore status from stream input
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Deserialize a shard-level result from an input stream
- readShardsAcknowledged(StreamInput) - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- readShardSearchFailure(StreamInput) - Static method in class org.elasticsearch.action.search.ShardSearchFailure
- readShardSegments(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- readShardSnapshotStatus(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- readShardsSyncedFlushResult(StreamInput) - Static method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- readShardStats(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- readShardUpgradeStatus(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- readShort() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readSize(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.BaseTranslogReader
-
read the size of the op (i.e., number of bytes, including the op size) written at the given position
- readSize(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Read a size under the assumption that a value of 0 means unlimited.
- readSnapshotStats(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- readSnapshotStatus(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Reads snapshot status from stream input
- readSortField(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readSortType(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readSortValue(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readStackTrace(T, StreamInput) - Static method in exception org.elasticsearch.ElasticsearchException
-
Deserializes stacktrace elements as well as suppressed exceptions from the given output stream and adds it to the given exception.
- readStats(StreamInput) - Static method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- readStats(StreamInput) - Static method in class org.elasticsearch.index.shard.IndexingStats.Stats
- readStoreFilesMetaData(StreamInput) - Static method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- readStoreStatus(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- readStreamableList(Supplier<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readString() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readStringArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readStringList() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a list of strings.
- readStringOrIntProperty(String, String, Map<String, Object>, String, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readStringProperty(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readStringProperty(String, String, Map<String, Object>, String, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readSuggest(StreamInput) - Static method in class org.elasticsearch.search.suggest.Suggest
- readSyncedFlushResponse(StreamInput) - Static method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- readTaskResponse(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- readTaskResponse(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- readTaskResponse(StreamInput) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- readTermStats(StreamInput, Term[]) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- readTermVectorsRequest(StreamInput) - Static method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- readText() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readTimeValue() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read a
TimeValue
from the stream - readTimeZone() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read a DateTimeZone.
- readTopDocs(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readURIParameters(TermVectorsRequest, RestRequest) - Static method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- readVersion(StreamInput) - Static method in class org.elasticsearch.Version
- readVInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an int stored in variable-length format.
- readVIntArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readVLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a long stored in variable-length format.
- readVLong(ByteArrayDataInput) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Same as DataOutput#readVLong but can read negative values (read on 9 bytes).
- readVLongArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readZLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
- REAL_WORD_LIKELIHOOD - Static variable in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
- REALLOCATED_REPLICA - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
A better replica location is identified and causes the existing replica allocation to be cancelled.
- realtime() - Method in class org.elasticsearch.action.get.GetRequest
- realtime() - Method in class org.elasticsearch.action.get.MultiGetRequest
- realtime() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- realtime() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return whether term vectors should be generated real-time (default to true).
- realtime() - Method in class org.elasticsearch.index.engine.Engine.Get
- realtime(boolean) - Method in class org.elasticsearch.action.get.GetRequest
- realtime(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
- realtime(boolean) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- realtime(boolean) - Method in interface org.elasticsearch.action.RealtimeRequest
- realtime(boolean) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- realtime(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- RealtimeRequest - Interface in org.elasticsearch.action
-
Indicates that a request can execute in realtime (reads from the translog).
- realWordErrorLikelihood() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the
PhraseSuggestionBuilder.realWordErrorLikelihood(float)
parameter - realWordErrorLikelihood(float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the likelihood of a term being a misspelled even if the term exists in the dictionary.
- realWordLikelihood - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- reason - Variable in class org.elasticsearch.action.ShardOperationFailedException
- reason - Variable in class org.elasticsearch.index.shard.IndexShard.ShardFailure
- reason() - Method in class org.elasticsearch.action.ShardOperationFailedException
-
The reason of the failure.
- reason() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Returns failure reason
- reason() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- reason() - Method in annotation type org.elasticsearch.common.SuppressLoggerChecks
- reason() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.NodeRemovalClusterStateTaskExecutor.Task
- reason() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- reason() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- reason() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot failure reason;
null
if the snapshot succeeded. - REASON_AGGREGATION - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_AGGREGATION_GLOBAL - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- REASON_SEARCH_CANCELLED - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_COUNT - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_MIN_SCORE - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_MULTI - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_POST_FILTER - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_TERMINATE_AFTER_COUNT - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_TIMEOUT - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_TOP_HITS - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- reassignTask(String, PersistentTasksCustomMetaData.Assignment) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
-
Reassigns the task to another node
- rebalance(Decision, AllocationDecision, DiscoveryNode, int, List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Creates a decision for whether to move the shard to a different node to form a better cluster balance.
- RebalanceOnlyWhenActiveAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
Only allow rebalancing when all shards are active within the shard replication group.
- RebalanceOnlyWhenActiveAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.RebalanceOnlyWhenActiveAllocationDecider
- receiveBufferSize - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- receiveFileInfo(List<String>, List<Long>, List<String>, List<Long>, int) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- receiveFileInfo(List<String>, List<Long>, List<String>, List<Long>, int) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Notifies the target of the files it is going to receive
- receiveFileInfo(List<String>, List<Long>, List<String>, List<Long>, int) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- ReceiveTimeoutTransportException - Exception in org.elasticsearch.transport
- ReceiveTimeoutTransportException(DiscoveryNode, String, String) - Constructor for exception org.elasticsearch.transport.ReceiveTimeoutTransportException
- ReceiveTimeoutTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ReceiveTimeoutTransportException
- RECIPROCAL - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- RECOVER_AFTER_DATA_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- RECOVER_AFTER_MASTER_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- RECOVER_AFTER_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- RECOVER_AFTER_TIME_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- recoverAfterTime() - Method in class org.elasticsearch.gateway.GatewayService
- recovered() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
-
number of bytes recovered for this file (so far).
- recoveredBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of bytes recovered so far, including both existing and reused
- recoveredBytesPercent() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
percent of bytes recovered out of total files bytes *to be* recovered
- recoveredFileCount() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
number of file that were recovered (excluding on ongoing files)
- recoveredFilesPercent() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
percent of recovered (i.e., not reused) files out of the total files to be recovered
- recoveredOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
returns the total number of translog operations recovered so far
- recoveredPercent() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- RecoverFilesRecoveryException - Exception in org.elasticsearch.indices.recovery
- RecoverFilesRecoveryException(StreamInput) - Constructor for exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- RecoverFilesRecoveryException(ShardId, int, ByteSizeValue, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- recoverFrom() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- recoverFrom(Index) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- recoverFromLocalShards(BiConsumer<String, MappingMetaData>, List<IndexShard>) - Method in class org.elasticsearch.index.shard.IndexShard
- recoverFromStore() - Method in class org.elasticsearch.index.shard.IndexShard
- recoverFromTranslog(Engine.TranslogRecoveryRunner, long) - Method in class org.elasticsearch.index.engine.Engine
-
Performs recovery from the transaction log up to
recoverUpToSeqNo
(inclusive). - recoverFromTranslog(Engine.TranslogRecoveryRunner, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- recoverFromTranslog(Engine.TranslogRecoveryRunner, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- recoveries(RecoveryRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices recoveries
- recoveries(RecoveryRequest, ActionListener<RecoveryResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices recoveries
- RecoveriesCollection - Class in org.elasticsearch.indices.recovery
-
This class holds a collection of all on going recoveries on the current node (i.e., the node is the target node of those recoveries).
- RecoveriesCollection(Logger, ThreadPool, LongConsumer) - Constructor for class org.elasticsearch.indices.recovery.RecoveriesCollection
- RecoveriesCollection.RecoveryRef - Class in org.elasticsearch.indices.recovery
-
a reference to
RecoveryTarget
, which implementsAutoCloseable
. - RECOVERING - org.elasticsearch.index.shard.IndexShardState
- recoverToTarget(ActionListener<RecoveryResponse>) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
performs the recovery from the local engine to the target
- recovery() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- recovery(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Recovery - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- RECOVERY - org.elasticsearch.transport.TransportRequestOptions.Type
- RECOVERY_SOURCE_NAME - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper
- RecoveryAction - Class in org.elasticsearch.action.admin.indices.recovery
-
Recovery information action
- RecoveryCleanFilesRequest - Class in org.elasticsearch.indices.recovery
- RecoveryCleanFilesRequest() - Constructor for class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- RecoveryCounter - Class in org.elasticsearch.index.engine
-
RecoveryCounter keeps tracks of the number of ongoing recoveries for a particular
Store
- recoveryDiff(Store.MetadataSnapshot) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns a diff between the two snapshots that can be used for recovery.
- RecoveryEngineException - Exception in org.elasticsearch.index.engine
- RecoveryEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.RecoveryEngineException
- RecoveryEngineException(ShardId, int, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.RecoveryEngineException
- RecoveryFailedException - Exception in org.elasticsearch.indices.recovery
- RecoveryFailedException(StreamInput) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(ShardId, DiscoveryNode, DiscoveryNode, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(ShardId, DiscoveryNode, DiscoveryNode, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(RecoveryState, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(StartRecoveryRequest, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(StartRecoveryRequest, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFileChunkRequest - Class in org.elasticsearch.indices.recovery
- RecoveryFileChunkRequest() - Constructor for class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- RecoveryFileChunkRequest(long, ShardId, StoreFileMetaData, long, BytesReference, boolean, int, long) - Constructor for class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- RecoveryFilesInfoRequest - Class in org.elasticsearch.indices.recovery
- RecoveryFilesInfoRequest() - Constructor for class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- RecoveryFinalizeRecoveryRequest - Class in org.elasticsearch.indices.recovery
- RecoveryFinalizeRecoveryRequest() - Constructor for class org.elasticsearch.indices.recovery.RecoveryFinalizeRecoveryRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryFinalizeRecoveryRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryWaitForClusterStateRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- RecoveryRef(RecoveryTarget) - Constructor for class org.elasticsearch.indices.recovery.RecoveriesCollection.RecoveryRef
-
Important:
AbstractRefCounted.tryIncRef()
should be *successfully* called on status before - RecoveryRequest - Class in org.elasticsearch.action.admin.indices.recovery
-
Request for recovery information
- RecoveryRequest() - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
Constructs a request for recovery information for all shards
- RecoveryRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
Constructs a request for recovery information for all shards for the given indices
- RecoveryRequestBuilder - Class in org.elasticsearch.action.admin.indices.recovery
-
Recovery information request builder.
- RecoveryRequestBuilder(ElasticsearchClient, RecoveryAction) - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryRequestBuilder
-
Constructs a new recovery information request builder.
- RecoveryResponse - Class in org.elasticsearch.action.admin.indices.recovery
-
Information regarding the recovery state of indices and their associated shards.
- RecoveryResponse - Class in org.elasticsearch.indices.recovery
- RecoveryResponse() - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- RecoveryResponse(int, int, int, Map<String, List<RecoveryState>>, List<DefaultShardOperationFailedException>) - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
-
Constructs recovery information for a collection of indices and associated shards.
- RecoverySettings - Class in org.elasticsearch.indices.recovery
- RecoverySettings(Settings, ClusterSettings) - Constructor for class org.elasticsearch.indices.recovery.RecoverySettings
- recoverySource() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns recovery source for the given shard.
- RecoverySource - Class in org.elasticsearch.cluster.routing
-
Represents the recovery source of a shard.
- RecoverySource() - Constructor for class org.elasticsearch.cluster.routing.RecoverySource
- RecoverySource.EmptyStoreRecoverySource - Class in org.elasticsearch.cluster.routing
-
Recovery from a fresh copy
- RecoverySource.ExistingStoreRecoverySource - Class in org.elasticsearch.cluster.routing
-
Recovery from an existing on-disk store
- RecoverySource.LocalShardsRecoverySource - Class in org.elasticsearch.cluster.routing
-
recovery from other shards on same node (shrink index action)
- RecoverySource.PeerRecoverySource - Class in org.elasticsearch.cluster.routing
-
peer recovery from a primary shard
- RecoverySource.SnapshotRecoverySource - Class in org.elasticsearch.cluster.routing
-
recovery from a snapshot
- RecoverySource.Type - Enum in org.elasticsearch.cluster.routing
- RecoverySourceHandler - Class in org.elasticsearch.indices.recovery
-
RecoverySourceHandler handles the three phases of shard recovery, which is everything relating to copying the segment files as well as sending translog operations across the wire once the segments have been copied.
- RecoverySourceHandler(IndexShard, RecoveryTargetHandler, StartRecoveryRequest, int, int) - Constructor for class org.elasticsearch.indices.recovery.RecoverySourceHandler
- recoveryState - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- recoveryState() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the current
RecoveryState
if this shard is recovering or has been recovering. - recoveryState() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Returns the recovery state associated with this shard.
- RecoveryState - Class in org.elasticsearch.indices.recovery
-
Keeps track of state related to shard recovery.
- RecoveryState(ShardRouting, DiscoveryNode, DiscoveryNode) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState
- RecoveryState(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState
- RecoveryState.File - Class in org.elasticsearch.indices.recovery
- RecoveryState.Index - Class in org.elasticsearch.indices.recovery
- RecoveryState.Stage - Enum in org.elasticsearch.indices.recovery
- RecoveryState.Timer - Class in org.elasticsearch.indices.recovery
- RecoveryState.Translog - Class in org.elasticsearch.indices.recovery
- RecoveryState.VerifyIndex - Class in org.elasticsearch.indices.recovery
- recoveryStats - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- recoveryStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
returns stats about ongoing recoveries, both source and target
- RecoveryStats - Class in org.elasticsearch.index.recovery
-
Recovery related statistics, starting at the shard level and allowing aggregation to indices and node level
- RecoveryStats() - Constructor for class org.elasticsearch.index.recovery.RecoveryStats
- RecoveryTarget - Class in org.elasticsearch.indices.recovery
-
Represents a recovery where the current node is the target node of the recovery.
- RecoveryTarget(IndexShard, DiscoveryNode, PeerRecoveryTargetService.RecoveryListener, LongConsumer) - Constructor for class org.elasticsearch.indices.recovery.RecoveryTarget
-
Creates a new recovery target object that represents a recovery to the provided shard.
- RecoveryTargetHandler - Interface in org.elasticsearch.indices.recovery
- RecoveryTranslogOperationsRequest - Class in org.elasticsearch.indices.recovery
- RecoveryTranslogOperationsRequest() - Constructor for class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- RecoveryWaitForClusterStateRequest - Class in org.elasticsearch.indices.recovery
- RecoveryWaitForClusterStateRequest() - Constructor for class org.elasticsearch.indices.recovery.RecoveryWaitForClusterStateRequest
- rectangleContainsPoint(Rectangle, double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
check if point is within a rectangle todo: move this to lucene Rectangle class
- RECURSIVE - org.elasticsearch.common.geo.SpatialStrategy
- recursiveBinding() - Method in class org.elasticsearch.common.inject.internal.Errors
- recursiveImplementationType() - Method in class org.elasticsearch.common.inject.internal.Errors
- recursiveProviderType() - Method in class org.elasticsearch.common.inject.internal.Errors
- recycle(T) - Method in class org.elasticsearch.common.recycler.AbstractRecyclerC
- recycle(T) - Method in interface org.elasticsearch.common.recycler.Recycler.C
-
Recycle the data.
- Recycler<T> - Interface in org.elasticsearch.common.recycler
-
A recycled object, note, implementations should support calling obtain and then recycle on different threads.
- Recycler.C<T> - Interface in org.elasticsearch.common.recycler
- Recycler.Factory<T> - Interface in org.elasticsearch.common.recycler
- Recycler.V<T> - Interface in org.elasticsearch.common.recycler
- Recyclers - Enum in org.elasticsearch.common.recycler
- RED - org.elasticsearch.cluster.health.ClusterHealthStatus
- reduce(List<B>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- reduce(List<B>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Reduces the given aggregations to a single one and returns it.
- reduce(List<InternalAggregations>, List<SiblingPipelineAggregator>, InternalAggregation.ReduceContext) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Reduces the given list of aggregations as well as the provided top-level pipeline aggregators.
- reduce(List<InternalAggregations>, InternalAggregation.ReduceContext) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Reduces the given list of aggregations as well as the top-level pipeline aggregators extracted from the first
InternalAggregations
object found in the list. - reduce(List<Suggest.Suggestion<CompletionSuggestion.Entry>>) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- reduce(List<Suggest.Suggestion<T>>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
Merges the result of another suggestion into this suggestion.
- reduce(List<T>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- reduce(Map<String, List<Suggest.Suggestion>>) - Static method in class org.elasticsearch.search.suggest.Suggest
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketselector.BucketSelectorPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
- REDUCE - org.elasticsearch.search.profile.aggregation.AggregationTimingType
- ReduceContext(BigArrays, ScriptService, boolean) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- ReduceContext(BigArrays, ScriptService, IntConsumer, boolean) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- reducedType() - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- reducedType() - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- reducedType() - Method in class org.elasticsearch.index.fielddata.fieldcomparator.FloatValuesComparatorSource
- reducedType() - Method in class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- reducedType() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- reduceScript() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Get the
reduce
script. - reduceScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Set the
reduce
script. - ReduceScript(Map<String, Object>, List<Object>) - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- ReduceSearchPhaseException - Exception in org.elasticsearch.action.search
-
A failure during a reduce phase (when receiving results from several shards, and reducing them into one or more results and possible actions).
- ReduceSearchPhaseException(String, String, Throwable, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.ReduceSearchPhaseException
- ReduceSearchPhaseException(StreamInput) - Constructor for exception org.elasticsearch.action.search.ReduceSearchPhaseException
- reduceTo(List<Suggest.Suggestion<CompletionSuggestion.Entry>>) - Static method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
-
Reduces suggestions to a single suggestion containing at most top
Suggest.Suggestion.getSize()
options acrosstoReduce
- refCount() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
-
Returns the current reference count.
- refCount() - Method in class org.elasticsearch.index.store.Store
-
Returns the current reference count.
- RefCounted - Interface in org.elasticsearch.common.util.concurrent
-
An interface for objects that need to be notified when all reference to itself are not in user anymore.
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.miscellaneous.DisableGraphAttributeImpl
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- refresh - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- refresh() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- refresh() - Method in class org.elasticsearch.action.get.GetRequest
- refresh() - Method in class org.elasticsearch.action.get.MultiGetRequest
- refresh() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- refresh() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
-
Refreshes the ClusterInfo in a blocking fashion
- refresh() - Method in class org.elasticsearch.common.cache.Cache
-
Force any outstanding size-based and time-based evictions to occur
- refresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Returns a new instance to cache
- refresh(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- refresh(boolean) - Method in class org.elasticsearch.action.get.GetRequest
-
Should a refresh be executed before this get operation causing the operation to return the latest value.
- refresh(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
- refresh(boolean) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- refresh(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Call refresh on the indexes we've written to after the request ends?
- refresh(String) - Method in class org.elasticsearch.index.engine.Engine
-
Synchronously refreshes the engine for new search operations to reflect the latest changes.
- refresh(String) - Method in class org.elasticsearch.index.engine.InternalEngine
- refresh(String) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- refresh(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Writes all indexing changes to disk and opens a new searcher reflecting all changes.
- refresh(RefreshRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly refresh one or more indices (making the content indexed since the last refresh searchable).
- refresh(RefreshRequest, ActionListener<RefreshResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly refresh one or more indices (making the content indexed since the last refresh searchable).
- Refresh - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- REFRESH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.fs.FsService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.os.OsService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.process.ProcessService
- RefreshAction - Class in org.elasticsearch.action.admin.indices.refresh
- RefreshFailedEngineException - Exception in org.elasticsearch.index.engine
- RefreshFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.RefreshFailedEngineException
- RefreshFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.RefreshFailedEngineException
- refreshIfNeeded(String, long) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Refresh this engine **internally** iff the requesting seq_no is greater than the last refreshed checkpoint.
- refreshInterval() - Method in class org.elasticsearch.monitor.process.ProcessInfo
- RefreshListeners - Class in org.elasticsearch.index.shard
-
Allows for the registration of listeners that are called when a change becomes visible for search.
- RefreshListeners(IntSupplier, Runnable, Executor, Logger, ThreadContext) - Constructor for class org.elasticsearch.index.shard.RefreshListeners
- refreshMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
-
Refreshes mappings if they are not the same between original and parsed version
- refreshNeeded() - Method in class org.elasticsearch.index.engine.Engine
- refreshNeeded() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- refreshNeeded() - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Returns true if there are pending listeners.
- refreshRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a refresh indices request.
- RefreshRequest - Class in org.elasticsearch.action.admin.indices.refresh
-
A refresh request making all operations performed since the last refresh available for search.
- RefreshRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
- RefreshRequestBuilder - Class in org.elasticsearch.action.admin.indices.refresh
-
A refresh request making all operations performed since the last refresh available for search.
- RefreshRequestBuilder(ElasticsearchClient, RefreshAction) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
- RefreshResponse - Class in org.elasticsearch.action.admin.indices.refresh
-
The response of a refresh action.
- refreshStats() - Method in class org.elasticsearch.index.shard.IndexShard
- RefreshStats - Class in org.elasticsearch.index.refresh
- RefreshStats() - Constructor for class org.elasticsearch.index.refresh.RefreshStats
- RefreshStats(long, long, int) - Constructor for class org.elasticsearch.index.refresh.RefreshStats
- REG - org.elasticsearch.transport.TransportRequestOptions.Type
- regex - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- regex() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the regex for this suggestion
- regex(String) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Sets a regular expression pattern for prefixes to provide completions for.
- regex(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- regex(String, RegexOptions) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Same as
CompletionSuggestionBuilder.regex(String)
with full regular expression options seeRegexOptions.Builder
- Regex - Class in org.elasticsearch.common.regex
- Regex() - Constructor for class org.elasticsearch.common.regex.Regex
- REGEX - org.elasticsearch.index.mapper.DynamicTemplate.MatchType
- REGEX_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- regexOptions - Variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- RegexOptions - Class in org.elasticsearch.search.suggest.completion
-
Regular expression options for completion suggester
- RegexOptions.Builder - Class in org.elasticsearch.search.suggest.completion
-
Options for regular expression queries
- RegexpFlag - Enum in org.elasticsearch.index.query
-
Regular expression syntax flags.
- regexpQuery(Object, int, int) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
-
Completion prefix regular expression query
- regexpQuery(String, int, int, MultiTermQuery.RewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- regexpQuery(String, int, int, MultiTermQuery.RewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- regexpQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing terms with a specified regular expression.
- RegexpQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that does fuzzy matching for a specific value.
- RegexpQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.RegexpQueryBuilder
-
Constructs a new regex query.
- RegexpQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.RegexpQueryBuilder
-
Read from a stream.
- register(String, String, TaskAwareRequest) - Method in class org.elasticsearch.tasks.TaskManager
-
Registers a task without parent task
- register(String, T) - Method in class org.elasticsearch.common.NamedRegistry
- register(MembersInjector<? super I>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Registers a members injector for type
I
. - register(InjectionListener<? super I>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Registers an injection listener for type
I
. - register(T, String) - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Register a parser.
- register(T, ParseField) - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Register a parser.
- REGISTER_CONNECTION_LISTENER_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- registerAsDeprecatedHandler(RestRequest.Method, String, RestHandler, String, DeprecationLogger) - Method in class org.elasticsearch.rest.RestController
-
Registers a REST handler to be executed when the provided
method
andpath
match the request. - registerAsyncAction(BiConsumer<Client, ActionListener<?>>) - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Registers an async action that must be executed before the next rewrite round in order to make progress.
- registerAsyncAction(BiConsumer<Client, ActionListener<?>>) - Method in class org.elasticsearch.index.query.QueryShardContext
- registerBreaker(BreakerSettings) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
-
Allows to register of a custom circuit breaker.
- registerBreaker(BreakerSettings) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
-
Allows to register a custom circuit breaker.
- registerBreaker(BreakerSettings) - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
- registerClusterSettingsListeners(ClusterSettings) - Method in class org.elasticsearch.script.ScriptModule
-
Allow the script service to register any settings update handlers on the cluster settings
- registerConnectionListener - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- registerDerivedNodeNameWithLogger(String) - Method in class org.elasticsearch.node.Node
-
If the node name was derived from the node id this is called with the node name as soon as it is available so that we can register the node name with the logger.
- registerErrorListener() - Static method in class org.elasticsearch.common.logging.LogConfigurator
-
Registers a listener for status logger errors.
- registerHandler(RestRequest.Method, String, RestHandler) - Method in class org.elasticsearch.rest.RestController
-
Registers a REST handler to be executed when one of the provided methods and path match the request.
- registerInternalRepository(String, String) - Method in class org.elasticsearch.repositories.RepositoriesService
- registerProxyAction(TransportService, String, Writeable.Reader<? extends TransportResponse>) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Registers a proxy request handler that allows to forward requests for the given action to another node.
- registerProxyActionWithDynamicResponseType(TransportService, String, Function<TransportRequest, Writeable.Reader<? extends TransportResponse>>) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Registers a proxy request handler that allows to forward requests for the given action to another node.
- registerRepository(RepositoriesService.RegisterRepositoryRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Registers new repository in the cluster
- RegisterRepositoryRequest(String, String, String, boolean) - Constructor for class org.elasticsearch.repositories.RepositoriesService.RegisterRepositoryRequest
-
Constructs new register repository request
- registerRequestHandler(String, String, boolean, boolean, Writeable.Reader<Request>, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(String, String, Writeable.Reader<Request>, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(String, Supplier<Request>, String, boolean, boolean, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(String, Supplier<Request>, String, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(RequestHandlerRegistry<Request>) - Method in class org.elasticsearch.transport.TcpTransport
- registerRequestHandler(RequestHandlerRegistry<Request>) - Method in interface org.elasticsearch.transport.Transport
-
Registers a new request handler
- registerRequestHandler(TransportService, SearchService) - Static method in class org.elasticsearch.action.search.SearchTransportService
- registerRequestHandlers(String, TransportService, Supplier<ResyncReplicationRequest>, Supplier<ResyncReplicationRequest>, String) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- registerRequestHandlers(String, TransportService, Supplier<Request>, Supplier<ReplicaRequest>, String) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- registerSmoothingModels(List<NamedWriteableRegistry.Entry>) - Static method in class org.elasticsearch.search.SearchModule
- registerWithDeprecatedHandler(RestRequest.Method, String, RestHandler, RestRequest.Method, String, DeprecationLogger) - Method in class org.elasticsearch.rest.RestController
-
Registers a REST handler to be executed when the provided
method
andpath
match the request, or when provided withdeprecatedMethod
anddeprecatedPath
. - rehash(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
-
Deprecated.no replacement - values will always be rehashed
- ReindexAction - Class in org.elasticsearch.index.reindex
- ReindexRequest - Class in org.elasticsearch.index.reindex
-
Request to reindex some documents from one index to another.
- ReindexRequest() - Constructor for class org.elasticsearch.index.reindex.ReindexRequest
- ReindexRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.ReindexRequest
- ReindexRequestBuilder - Class in org.elasticsearch.index.reindex
- ReindexRequestBuilder(ElasticsearchClient, Action<ReindexRequest, BulkByScrollResponse, ReindexRequestBuilder>) - Constructor for class org.elasticsearch.index.reindex.ReindexRequestBuilder
- REINITIALIZED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
When a shard moves from started back to initializing, for example, during shadow replica
- reinitializeMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.engine.Engine
-
A primary shard calls this method to re-initialize the max_seq_no_of_updates marker using the max_seq_no from Lucene index and translog before replaying the local translog in its local recovery.
- reinitializeMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.engine.InternalEngine
- reinitializeMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- reinitializeReplicaShard() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Reinitializes a replica shard, giving it a fresh allocation id
- rejected() - Method in class org.elasticsearch.common.util.concurrent.EsAbortPolicy
- rejected() - Method in interface org.elasticsearch.common.util.concurrent.XRejectedExecutionHandler
-
The number of rejected executions.
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.elasticsearch.common.util.concurrent.EsAbortPolicy
- rejoin(String) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- RejoinClusterRequest() - Constructor for class org.elasticsearch.discovery.zen.ZenDiscovery.RejoinClusterRequest
- relation() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- relation() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- relation(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- relation(ShapeRelation) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Sets the relation of query shape and indexed shape.
- relativeTimeInMillis() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Returns a value of milliseconds that may be used for relative time calculations.
- relativeTimeSupplier - Variable in class org.elasticsearch.ingest.Processor.Parameters
- Releasable - Interface in org.elasticsearch.common.lease
-
Specialization of
AutoCloseable
that may only throw anElasticsearchException
. - ReleasableBytesStreamOutput - Class in org.elasticsearch.common.io.stream
-
An bytes stream output that allows providing a
BigArrays
instance expecting it to require releasing its content (ReleasableBytesStreamOutput.bytes()
) once done. - ReleasableBytesStreamOutput(int, BigArrays) - Constructor for class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
- ReleasableBytesStreamOutput(BigArrays) - Constructor for class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
- ReleasableLock - Class in org.elasticsearch.common.util.concurrent
-
Releasable lock used inside of Engine implementations
- ReleasableLock(Lock) - Constructor for class org.elasticsearch.common.util.concurrent.ReleasableLock
- ReleasablePagedBytesReference - Class in org.elasticsearch.common.bytes
-
An extension to
PagedBytesReference
that requires releasing its content. - ReleasablePagedBytesReference(ByteArray, int, Releasable) - Constructor for class org.elasticsearch.common.bytes.ReleasablePagedBytesReference
- Releasables - Enum in org.elasticsearch.common.lease
-
Utility methods to work with
Releasable
s. - release() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- release() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- release() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- releaseOnce(Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Equivalent to
Releasables.wrap(Releasable...)
but can be called multiple times without double releasing. - reload(Settings) - Method in interface org.elasticsearch.plugins.ReloadablePlugin
-
Called to trigger the rebuilt of the plugin's internal members.
- RELOAD_INTERVAL_HIGH - Static variable in class org.elasticsearch.watcher.ResourceWatcherService
- RELOAD_INTERVAL_LOW - Static variable in class org.elasticsearch.watcher.ResourceWatcherService
- RELOAD_INTERVAL_MEDIUM - Static variable in class org.elasticsearch.watcher.ResourceWatcherService
- ReloadablePlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
s that can be reloaded. - reloadException() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- reloadSPI(ClassLoader) - Method in interface org.elasticsearch.plugins.ExtensiblePlugin
-
Reload any SPI implementations from the given classloader.
- relocate(String, long) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Relocate the shard to another node.
- relocated(Consumer<ReplicationTracker.PrimaryContext>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Completes the relocation.
- relocateShard(ShardRouting, String, long, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Relocate a shard to another node, adding the target initializing shard as well as assigning it.
- relocating() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
iff the this shard is currently relocating to another node. - RELOCATING - org.elasticsearch.cluster.routing.ShardRoutingState
-
The shard is in the process being relocated.
- relocatingNodeId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The relocating node id the shard is either relocating to or relocating from.
- relocationCompleted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetaDataUpdater
- relocationCompleted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- relocationCompleted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- relocationCompleted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- relocationCompleted(ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called on relocation source when relocation completes after relocation target is started.
- relocationSourceRemoved(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- relocationSourceRemoved(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- relocationSourceRemoved(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- relocationSourceRemoved(ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called on replica relocation target when replica relocation source fails.
- relocationStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- relocationStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- relocationStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- relocationStarted(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when relocation of a started shard is initiated.
- remaining() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- remaining() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
Return the number of shards remaining in this
ShardsIterator
- remainingCapacity() - Method in class org.elasticsearch.common.collect.EvictingQueue
- remainingCapacity() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- REMOTE_CLUSTER_COMPRESS - Static variable in class org.elasticsearch.transport.RemoteClusterService
- REMOTE_CLUSTER_INDEX_SEPARATOR - Static variable in class org.elasticsearch.transport.RemoteClusterAware
- REMOTE_CLUSTER_PING_SCHEDULE - Static variable in class org.elasticsearch.transport.RemoteClusterService
- REMOTE_CLUSTER_SKIP_UNAVAILABLE - Static variable in class org.elasticsearch.transport.RemoteClusterService
- REMOTE_CLUSTERS_PROXY - Static variable in class org.elasticsearch.transport.RemoteClusterAware
-
A proxy address for the remote cluster.
- REMOTE_CLUSTERS_SEEDS - Static variable in class org.elasticsearch.transport.RemoteClusterAware
-
A list of initial seed nodes to discover eligible nodes from the remote cluster
- REMOTE_CONNECTIONS_PER_CLUSTER - Static variable in class org.elasticsearch.transport.RemoteClusterService
-
The maximum number of connections that will be established to a remote cluster.
- REMOTE_INITIAL_CONNECTION_TIMEOUT_SETTING - Static variable in class org.elasticsearch.transport.RemoteClusterService
-
The initial connect timeout for remote cluster connections
- REMOTE_NODE_ATTRIBUTE - Static variable in class org.elasticsearch.transport.RemoteClusterService
-
The name of a node attribute to select nodes that should be connected to in the remote cluster.
- remoteAddress() - Method in class org.elasticsearch.transport.TransportMessage
- remoteAddress(TransportAddress) - Method in class org.elasticsearch.transport.TransportMessage
- RemoteClusterAware - Class in org.elasticsearch.transport
-
Base class for all services and components that need up-to-date information about the registered remote clusters
- RemoteClusterAware(Settings) - Constructor for class org.elasticsearch.transport.RemoteClusterAware
-
Creates a new
RemoteClusterAware
instance - RemoteClusterAwareRequest - Interface in org.elasticsearch.transport
- RemoteClusterService - Class in org.elasticsearch.transport
-
Basic service for accessing remote clusters via gateway nodes
- RemoteConnectionInfo - Class in org.elasticsearch.transport
-
This class encapsulates all remote cluster information to be rendered on
_remote/info
requests. - RemoteConnectionInfo(StreamInput) - Constructor for class org.elasticsearch.transport.RemoteConnectionInfo
- RemoteInfo - Class in org.elasticsearch.index.reindex
- RemoteInfo(String, String, int, String, BytesReference, String, String, Map<String, String>, TimeValue, TimeValue) - Constructor for class org.elasticsearch.index.reindex.RemoteInfo
- RemoteInfo(StreamInput) - Constructor for class org.elasticsearch.index.reindex.RemoteInfo
-
Read from a stream.
- RemoteInfoAction - Class in org.elasticsearch.action.admin.cluster.remote
- RemoteInfoAction() - Constructor for class org.elasticsearch.action.admin.cluster.remote.RemoteInfoAction
- RemoteInfoRequest - Class in org.elasticsearch.action.admin.cluster.remote
- RemoteInfoRequest() - Constructor for class org.elasticsearch.action.admin.cluster.remote.RemoteInfoRequest
- RemoteInfoRequestBuilder - Class in org.elasticsearch.action.admin.cluster.remote
- RemoteInfoRequestBuilder(ElasticsearchClient, RemoteInfoAction) - Constructor for class org.elasticsearch.action.admin.cluster.remote.RemoteInfoRequestBuilder
- RemoteInfoResponse - Class in org.elasticsearch.action.admin.cluster.remote
- RemoteRecoveryTargetHandler - Class in org.elasticsearch.indices.recovery
- RemoteRecoveryTargetHandler(long, ShardId, TransportService, DiscoveryNode, RecoverySettings, Consumer<Long>) - Constructor for class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- remoteShardFailed(ShardId, String, long, boolean, String, Exception, ActionListener<Void>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
Send a shard failed request to the master node to update the cluster state with the failure of a shard on another node.
- RemoteTransportException - Exception in org.elasticsearch.transport
-
A remote exception for an action.
- RemoteTransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.RemoteTransportException
- RemoteTransportException(String, TransportAddress, String, Throwable) - Constructor for exception org.elasticsearch.transport.RemoteTransportException
- RemoteTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.RemoteTransportException
- removalListener(RemovalListener<K, V>) - Method in class org.elasticsearch.common.cache.CacheBuilder
- RemovalListener<K,V> - Interface in org.elasticsearch.common.cache
- RemovalNotification<K,V> - Class in org.elasticsearch.common.cache
- RemovalNotification(K, V, RemovalNotification.RemovalReason) - Constructor for class org.elasticsearch.common.cache.RemovalNotification
- RemovalNotification.RemovalReason - Enum in org.elasticsearch.common.cache
- remove() - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Build a new
AliasAction
to remove aliases. - remove() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
Unsupported operation, just there for the interface.
- remove() - Method in class org.elasticsearch.common.collect.EvictingQueue
- remove() - Method in class org.elasticsearch.index.mapper.ContentPath
- remove() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks.Iter
- remove() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles.Iter
- remove() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks.Iter
- remove() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles.Iter
- remove() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket.Iter
- remove(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- remove(long) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- remove(long) - Method in interface org.elasticsearch.common.util.concurrent.ConcurrentMapLong
- remove(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
-
Remove the entry which has this key in the hash table and return the associated value or null if there was no entry associated with this key.
- remove(long) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Removes and return the
Transport.ResponseContext
for the given request ID or returnsnull
if no context is associated with this request ID. - remove(Object) - Method in class org.elasticsearch.common.collect.EvictingQueue
- remove(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- remove(Object) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- remove(Object) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- remove(Object) - Method in class org.elasticsearch.script.DeprecationMap
- remove(Object) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- remove(Object) - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
- remove(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
- remove(Object, Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- remove(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- remove(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- remove(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- remove(String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Removes the provided setting from the internal map holding the current list of settings.
- remove(K) - Method in class org.elasticsearch.common.collect.MapBuilder
- remove(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- remove(Listener) - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Unregisters a listener
- remove(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- Remove(String, String) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.Remove
-
Build the operation.
- REMOVE - org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- REMOVE_INDEX - org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- removeAlias(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- removeAlias(String[], String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Removes aliases from the index.
- removeAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Removes an alias from the index.
- removeAlias(String, String[]) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Removes aliases from the index.
- removeAll(IntContainer) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- removeAll(ObjectContainer<? super KType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- removeAll(IntObjectPredicate<? super VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- removeAll(IntPredicate) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- removeAll(ObjectObjectPredicate<? super KType, ? super VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- removeAll(ObjectPredicate<? super KType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- removeAll(Collection<?>) - Method in class org.elasticsearch.common.collect.EvictingQueue
- removeAllAliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- removeAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- removeAllocationId(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Remove the allocation id of the provided shard from the set of in-sync shard copies
- removeAndAdd(long) - Method in class org.elasticsearch.common.util.BytesRefHash
- removeAndAdd(long) - Method in class org.elasticsearch.common.util.LongHash
- removeAndAdd(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- removeAndIgnore(UnassignedInfo.AllocationStatus, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
Removes and ignores the unassigned shard (will be ignored for this run, but will be added back to unassigned once the metadata is constructed again).
- removeAppender(Logger, Appender) - Static method in class org.elasticsearch.common.logging.Loggers
- removeApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Removes an applier of updated cluster states.
- removeApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Removes an applier of updated cluster states.
- removeBan(TaskId) - Method in class org.elasticsearch.tasks.TaskManager
-
Removes the ban for the specified parent task.
- removeConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
- removeContext(long) - Method in class org.elasticsearch.search.SearchService
- RemoveCorruptedLuceneSegmentsAction - Class in org.elasticsearch.index.shard
-
Removes corrupted Lucene index segments
- RemoveCorruptedLuceneSegmentsAction() - Constructor for class org.elasticsearch.index.shard.RemoveCorruptedLuceneSegmentsAction
- RemoveCorruptedShardDataCommand - Class in org.elasticsearch.index.shard
- RemoveCorruptedShardDataCommand() - Constructor for class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- RemoveCorruptedShardDataCommand(boolean) - Constructor for class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- RemoveCorruptedShardDataCommand.CleanStatus - Enum in org.elasticsearch.index.shard
- removeCorruptionMarker() - Method in class org.elasticsearch.index.store.Store
-
Deletes all corruption markers from this store.
- removeCurrentReference() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- removeCustom(String) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- removeCustom(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- removeCustom(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- removed() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- removedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- removeField(String) - Method in class org.elasticsearch.ingest.IngestDocument
-
Removes the field identified by the provided path.
- removeField(TemplateScript.Factory) - Method in class org.elasticsearch.ingest.IngestDocument
-
Removes the field identified by the provided path.
- removeGlobalBlock(int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeIndex() - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Build a new
AliasAction
to remove an index. - removeIndex(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
- removeIndex(Index, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason, String) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Removes the given index from this service and releases all associated resources.
- removeIndex(Index, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason, String) - Method in class org.elasticsearch.indices.IndicesService
- RemoveIndex(String) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.RemoveIndex
- removeIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeIndexBlocks(String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeIndexBlockWithId(String, int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- removeLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.common.component.LifecycleComponent
- removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.repositories.FilterRepository
- removeListener() - Method in enum org.elasticsearch.action.ThreadingModel
- removeListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Removes a listener for updated cluster states.
- removeListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Removes a listener for updated cluster states.
- removeListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- removeListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- removeListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.ConnectionManager
- removeMapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- removeMessageListener(TransportMessageListener) - Method in class org.elasticsearch.transport.TcpTransport
- removeMessageListener(TransportMessageListener) - Method in interface org.elasticsearch.transport.Transport
- removeOpenIndexOutputs(String) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
-
remove and
IndexOutput
for a given file. - removeOperation() - Method in enum org.elasticsearch.action.ThreadingModel
- removePersistentTask(String, ActionListener<PersistentTasksCustomMetaData.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Removes the persistent task
- RemovePersistentTaskAction - Class in org.elasticsearch.persistent
- RemovePersistentTaskAction.Request - Class in org.elasticsearch.persistent
- RemovePersistentTaskAction.RequestBuilder - Class in org.elasticsearch.persistent
- RemovePersistentTaskAction.TransportAction - Class in org.elasticsearch.persistent
- removeRelocationSource() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Removes relocation source of a non-primary shard.
- removeReplica() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- RemoveRequest() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.RemoveRequest
- RemoveRequest(String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveRequest
- RemoveRequest(ShardId, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.RemoveRequest
- RemoveResponse(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveResponse
- removeRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Removes an existing retention lease.
- removeRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Removes an existing retention lease.
- removeShard(int, String) - Method in class org.elasticsearch.index.IndexService
- removeShard(int, String) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Removes shard with given id.
- removeShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- removeSnapshot(SnapshotId) - Method in class org.elasticsearch.repositories.RepositoryData
-
Remove a snapshot and remove any indices that no longer exist in the repository due to the deletion of the snapshot.
- removeStaleIdsWithoutRoutings(ClusterState, List<StaleShard>, Logger) - Static method in class org.elasticsearch.cluster.routing.allocation.IndexMetaDataUpdater
-
Removes allocation ids from the in-sync set for shard copies for which there is no routing entries in the routing table.
- removeTask(String) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
-
Removes the task
- removeTemplate(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- removeTemplates(MetaDataIndexTemplateService.RemoveRequest, MetaDataIndexTemplateService.RemoveListener) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService
- removeThreadContext(ThreadContext) - Static method in class org.elasticsearch.common.logging.DeprecationLogger
-
Remove the
ThreadContext
used to add deprecation headers to network responses. - removeTimeoutListener(TimeoutClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Removes a timeout listener for updated cluster states.
- removeTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClient
-
Removes a transport address from the list of transport addresses that are used to connect to.
- renameAllTempFiles() - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
-
renames all temporary files to their true name, potentially overriding existing files
- renamePattern() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns rename pattern
- renamePattern(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets rename pattern that should be applied to restored indices.
- renameReplacement() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns rename replacement
- renameReplacement(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets rename replacement
- renameTempFilesSafe(Map<String, String>) - Method in class org.elasticsearch.index.store.Store
-
Renames all the given files from the key of the map to the value of the map.
- renderTemplate(TemplateScript.Factory) - Method in class org.elasticsearch.ingest.IngestDocument
- RenewRequest() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.RenewRequest
- RenewRequest(ShardId, String, long, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.RenewRequest
- renewRetentionLease(String, long, String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Renews an existing retention lease.
- renewRetentionLease(String, long, String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Renews an existing retention lease.
- replace(Long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- replace(Long, T, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- replace(String, String, String) - Static method in class org.elasticsearch.common.Strings
-
Replace all occurrences of a substring within a string with another string.
- REPLACE - org.elasticsearch.common.lucene.search.function.CombineFunction
- replaceAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- replaceAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- replaceAliases(String...) - Method in interface org.elasticsearch.action.AliasesRequest
-
Replaces current aliases with the provided aliases.
- replaceAll(UnaryOperator<T>) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- REPLACED - org.elasticsearch.common.cache.RemovalNotification.RemovalReason
- replaceMissing(NumericDocValues, long) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
NumericDocValues
instance that has a value for every document, returns the same value asvalues
if there is a value for the current document andmissing
otherwise. - replaceMissing(NumericDoubleValues, double) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
NumericDoubleValues
instance that has a value for every document, returns the same value asvalues
if there is a value for the current document andmissing
otherwise. - replaceMissing(ValuesSource.Bytes.WithOrdinals, BytesRef) - Static method in enum org.elasticsearch.search.aggregations.support.MissingValues
- replaceMissing(ValuesSource.Bytes, BytesRef) - Static method in enum org.elasticsearch.search.aggregations.support.MissingValues
- replaceMissing(ValuesSource.GeoPoint, GeoPoint) - Static method in enum org.elasticsearch.search.aggregations.support.MissingValues
- replaceMissing(ValuesSource.Numeric, Number) - Static method in enum org.elasticsearch.search.aggregations.support.MissingValues
- replacePropertyPlaceholders() - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Runs across all the settings set on this builder and replaces
${...}
elements in each setting with another setting already set on this builder. - replay(long...) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
- REPLICA - org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Allocated as a replica
- REPLICA - org.elasticsearch.cluster.routing.Preference
-
Route to replica shards
- REPLICA - org.elasticsearch.index.engine.Engine.Operation.Origin
- REPLICA - org.elasticsearch.index.mapper.SourceToParse.Origin
- REPLICA_ADDED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of explicit addition of a replica.
- REPLICA_FIRST - org.elasticsearch.cluster.routing.Preference
-
Route to replica shards first
- replicaActiveInitializingShardIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- ReplicaAfterPrimaryActiveAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation strategy that only allows for a replica to be allocated when the primary is active.
- ReplicaAfterPrimaryActiveAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ReplicaAfterPrimaryActiveAllocationDecider
- replicaFirstActiveInitializingShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- ReplicaOperationTransportHandler() - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaOperationTransportHandler
- replicaPromoted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- replicaPromoted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- replicaPromoted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- replicaPromoted(ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when started replica is promoted to primary.
- replicaRequest() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.PrimaryResult
- replicaRequest() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- ReplicaResponse(long, long) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- ReplicaResult() - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResult
- ReplicaResult(Exception) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResult
- REPLICAS - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- ReplicaShardAllocator - Class in org.elasticsearch.gateway
- ReplicaShardAllocator() - Constructor for class org.elasticsearch.gateway.ReplicaShardAllocator
- replicaShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- replicaShardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- ReplicasProxy(long) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicasProxy
- ReplicatedWriteRequest<R extends ReplicatedWriteRequest<R>> - Class in org.elasticsearch.action.support.replication
-
Requests that are both ReplicationRequests (run on a shard's primary first, then the replica) and WriteRequest (modify documents on a shard), for example
BulkShardRequest
,IndexRequest
, andDeleteRequest
. - ReplicatedWriteRequest() - Constructor for class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
-
Constructor for deserialization.
- ReplicatedWriteRequest(ShardId) - Constructor for class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- ReplicationGroup - Class in org.elasticsearch.index.shard
-
Replication group for a shard.
- ReplicationGroup(IndexShardRoutingTable, Set<String>, Set<String>) - Constructor for class org.elasticsearch.index.shard.ReplicationGroup
- ReplicationOperation<Request extends ReplicationRequest<Request>,ReplicaRequest extends ReplicationRequest<ReplicaRequest>,PrimaryResultT extends ReplicationOperation.PrimaryResult<ReplicaRequest>> - Class in org.elasticsearch.action.support.replication
- ReplicationOperation(Request, ReplicationOperation.Primary<Request, ReplicaRequest, PrimaryResultT>, ActionListener<PrimaryResultT>, ReplicationOperation.Replicas<ReplicaRequest>, Logger, String) - Constructor for class org.elasticsearch.action.support.replication.ReplicationOperation
- ReplicationOperation.Primary<RequestT extends ReplicationRequest<RequestT>,ReplicaRequestT extends ReplicationRequest<ReplicaRequestT>,PrimaryResultT extends ReplicationOperation.PrimaryResult<ReplicaRequestT>> - Interface in org.elasticsearch.action.support.replication
-
An encapsulation of an operation that is to be performed on the primary shard
- ReplicationOperation.PrimaryResult<RequestT extends ReplicationRequest<RequestT>> - Interface in org.elasticsearch.action.support.replication
- ReplicationOperation.ReplicaResponse - Interface in org.elasticsearch.action.support.replication
-
An interface to encapsulate the metadata needed from replica shards when they respond to operations performed on them.
- ReplicationOperation.Replicas<RequestT extends ReplicationRequest<RequestT>> - Interface in org.elasticsearch.action.support.replication
-
An encapsulation of an operation that will be executed on the replica shards, if present.
- ReplicationOperation.RetryOnPrimaryException - Exception in org.elasticsearch.action.support.replication
- ReplicationRequest<Request extends ReplicationRequest<Request>> - Class in org.elasticsearch.action.support.replication
-
Requests that are run on a particular replica, first on the primary and then on the replicas like
IndexRequest
orTransportShardRefreshAction
. - ReplicationRequest() - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
- ReplicationRequest(ShardId) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
-
Creates a new request with resolved shard id
- ReplicationRequestBuilder<Request extends ReplicationRequest<Request>,Response extends ActionResponse,RequestBuilder extends ReplicationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.replication
- ReplicationRequestBuilder(ElasticsearchClient, Action<Request, Response, RequestBuilder>, Request) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
- ReplicationResponse - Class in org.elasticsearch.action.support.replication
-
Base class for write action responses.
- ReplicationResponse() - Constructor for class org.elasticsearch.action.support.replication.ReplicationResponse
- ReplicationResponse.ShardInfo - Class in org.elasticsearch.action.support.replication
- ReplicationResponse.ShardInfo.Failure - Class in org.elasticsearch.action.support.replication
- ReplicationTask - Class in org.elasticsearch.action.support.replication
-
Task that tracks replication actions.
- ReplicationTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask
- ReplicationTask.Status - Class in org.elasticsearch.action.support.replication
- ReplicationTracker - Class in org.elasticsearch.index.seqno
-
This class is responsible for tracking the replication group with its progress and safety markers (local and global checkpoints).
- ReplicationTracker(ShardId, String, IndexSettings, long, long, LongConsumer, LongSupplier, BiConsumer<RetentionLeases, ActionListener<ReplicationResponse>>) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker
-
Initialize the global checkpoint service.
- ReplicationTracker.CheckpointState - Class in org.elasticsearch.index.seqno
- ReplicationTracker.PrimaryContext - Class in org.elasticsearch.index.seqno
-
Represents the sequence number component of the primary context.
- repoFiles() - Method in class org.elasticsearch.env.Environment
-
The shared filesystem repo locations.
- repositories() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
-
The names of the repositories.
- repositories() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
-
List of repositories to return
- repositories() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Returns list of currently registered repositories
- repositories(String[]) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
-
Sets the list or repositories.
- REPOSITORIES_CHUNK_SIZE_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- REPOSITORIES_COMPRESS_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- REPOSITORIES_LOCATION_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- RepositoriesMetaData - Class in org.elasticsearch.cluster.metadata
-
Contains metadata about registered snapshot repositories
- RepositoriesMetaData(List<RepositoryMetaData>) - Constructor for class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Constructs new repository metadata
- RepositoriesMetaData(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- RepositoriesModule - Class in org.elasticsearch.repositories
-
Sets up classes for Snapshot/Restore.
- RepositoriesModule(Environment, List<RepositoryPlugin>, TransportService, ClusterService, ThreadPool, NamedXContentRegistry) - Constructor for class org.elasticsearch.repositories.RepositoriesModule
- RepositoriesService - Class in org.elasticsearch.repositories
-
Service responsible for maintaining and providing access to snapshot repositories on nodes.
- RepositoriesService(Settings, ClusterService, TransportService, Map<String, Repository.Factory>, Map<String, Repository.Factory>, ThreadPool) - Constructor for class org.elasticsearch.repositories.RepositoriesService
- RepositoriesService.RegisterRepositoryRequest - Class in org.elasticsearch.repositories
-
Register repository request
- RepositoriesService.UnregisterRepositoryRequest - Class in org.elasticsearch.repositories
-
Unregister repository request
- RepositoriesService.VerifyResponse - Class in org.elasticsearch.repositories
-
Verify repository request
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Returns repository name
- repository() - Method in exception org.elasticsearch.repositories.RepositoryException
-
Returns repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Sets repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Sets repository name
- repository(String) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Returns a repository with a given name or null if such repository doesn't exist
- repository(String) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Returns registered repository
- Repository - Interface in org.elasticsearch.repositories
-
An interface for interacting with a repository in snapshot and restore.
- Repository.Factory - Interface in org.elasticsearch.repositories
-
An factory interface for constructing repositories.
- RepositoryData - Class in org.elasticsearch.repositories
-
A class that represents the data in a repository, as captured in the repository's index blob.
- RepositoryData(long, Map<String, SnapshotId>, Map<String, SnapshotState>, Map<IndexId, Set<SnapshotId>>, List<SnapshotId>) - Constructor for class org.elasticsearch.repositories.RepositoryData
- RepositoryException - Exception in org.elasticsearch.repositories
-
Generic repository exception
- RepositoryException(String, String) - Constructor for exception org.elasticsearch.repositories.RepositoryException
- RepositoryException(String, String, Throwable) - Constructor for exception org.elasticsearch.repositories.RepositoryException
- RepositoryException(StreamInput) - Constructor for exception org.elasticsearch.repositories.RepositoryException
- RepositoryMetaData - Class in org.elasticsearch.cluster.metadata
-
Metadata about registered repository
- RepositoryMetaData(String, String, Settings) - Constructor for class org.elasticsearch.cluster.metadata.RepositoryMetaData
-
Constructs new repository metadata
- RepositoryMetaData(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.RepositoryMetaData
- RepositoryMissingException - Exception in org.elasticsearch.repositories
-
Repository missing exception
- RepositoryMissingException(String) - Constructor for exception org.elasticsearch.repositories.RepositoryMissingException
- RepositoryMissingException(StreamInput) - Constructor for exception org.elasticsearch.repositories.RepositoryMissingException
- repositoryName - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- RepositoryPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to add custom snapshot repositories. - RepositoryVerificationException - Exception in org.elasticsearch.repositories
-
Repository verification exception
- RepositoryVerificationException(String, String) - Constructor for exception org.elasticsearch.repositories.RepositoryVerificationException
- RepositoryVerificationException(String, String, Throwable) - Constructor for exception org.elasticsearch.repositories.RepositoryVerificationException
- RepositoryVerificationException(StreamInput) - Constructor for exception org.elasticsearch.repositories.RepositoryVerificationException
- request - Variable in class org.elasticsearch.action.ActionRequestBuilder
- request - Variable in class org.elasticsearch.rest.AbstractRestChannel
- request() - Method in class org.elasticsearch.action.ActionRequestBuilder
- request() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- request() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction.InternalRequest
- request() - Method in interface org.elasticsearch.action.support.WriteRequestBuilder
- request() - Method in class org.elasticsearch.rest.AbstractRestChannel
- request() - Method in interface org.elasticsearch.rest.RestChannel
- request() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- request() - Method in class org.elasticsearch.search.internal.SearchContext
- Request() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- Request() - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.Request
- Request() - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- Request() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- Request() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- Request() - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.Request
- Request() - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- Request() - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- Request() - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- Request() - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- Request(String) - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- Request(String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- Request(String...) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.Request
- Request(String, long, Exception) - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- Request(String, long, PersistentTaskState) - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- Request(String, String, PersistentTaskParams) - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- Request(ShardId) - Constructor for class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction.Request
- Request(ShardId, DiscoveryNode[]) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- Request(ShardId, DiscoveryNode[]) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.Request
- Request(ShardId, RetentionLeases) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- Request(ShardId, RetentionLeases) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- REQUEST - org.elasticsearch.index.translog.Translog.Durability
-
Request durability - translogs are synced for each high level request (bulk, index, delete)
- REQUEST - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The request breaker tracks memory used for particular requests.
- REQUEST - Static variable in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction.Fields
- REQUEST_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- REQUEST_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- REQUEST_CIRCUIT_BREAKER_TYPE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- REQUEST_ENTITY_TOO_LARGE - org.elasticsearch.rest.RestStatus
-
The server is refusing to process a request because the request entity is larger than the server is willing or able to process.
- REQUEST_ID_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- REQUEST_TIMEOUT - org.elasticsearch.rest.RestStatus
-
The client did not produce a request within the time that the server was prepared to wait.
- REQUEST_URI_TOO_LONG - org.elasticsearch.rest.RestStatus
-
The server is refusing to service the request because the Request-URI is longer than the server is willing to interpret.
- RequestBuilder(ElasticsearchClient, CompletionPersistentTaskAction) - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.RequestBuilder
- RequestBuilder(ElasticsearchClient, RemovePersistentTaskAction) - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.RequestBuilder
- RequestBuilder(ElasticsearchClient, StartPersistentTaskAction) - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.RequestBuilder
- RequestBuilder(ElasticsearchClient, UpdatePersistentTaskStatusAction) - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.RequestBuilder
- requestCache - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- requestCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- requestCache() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- requestCache() - Method in class org.elasticsearch.action.search.SearchRequest
- requestCache() - Method in class org.elasticsearch.index.shard.IndexShard
- requestCache() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- requestCache() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- requestCache() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- requestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- requestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- requestCache(Boolean) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets if this request should use the request cache or not, assuming that it can (for example, if "now" is used, it will never be cached).
- RequestCache - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- RequestCacheStats - Class in org.elasticsearch.index.cache.request
- RequestCacheStats() - Constructor for class org.elasticsearch.index.cache.request.RequestCacheStats
- RequestCacheStats(long, long, long, long) - Constructor for class org.elasticsearch.index.cache.request.RequestCacheStats
- REQUESTED_RANGE_NOT_SATISFIED - org.elasticsearch.rest.RestStatus
-
A server SHOULD return a response with this status code if a request included a Range request-header field (section 14.35), and none of the range-specifier values in this field overlap the current extent of the selected resource, and the request did not include an If-Range request-header field.
- RequestHandlerRegistry<Request extends TransportRequest> - Class in org.elasticsearch.transport
- RequestHandlerRegistry(String, Writeable.Reader<Request>, TaskManager, TransportRequestHandler<Request>, String, boolean, boolean) - Constructor for class org.elasticsearch.transport.RequestHandlerRegistry
- requestId - Variable in class org.elasticsearch.search.SearchPhaseResult
- requestId - Variable in class org.elasticsearch.transport.NetworkMessage
- requestInjection(Object) - Method in class org.elasticsearch.common.inject.AbstractModule
- requestInjection(Object) - Method in interface org.elasticsearch.common.inject.Binder
-
Upon successful creation, the
Injector
will inject instance fields and methods of the given object. - requestInjection(TypeLiteral<T>, T) - Method in interface org.elasticsearch.common.inject.Binder
-
Upon successful creation, the
Injector
will inject instance fields and methods of the given object. - requests() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
The list of requests in this bulk request.
- requests() - Method in class org.elasticsearch.action.search.MultiSearchRequest
- Requests - Class in org.elasticsearch.client
-
A handy one stop shop for creating requests (make sure to import static this class).
- Requests() - Constructor for class org.elasticsearch.client.Requests
- REQUESTS_PER_SEC_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- requestStaticInjection(Class<?>...) - Method in class org.elasticsearch.common.inject.AbstractModule
- requestStaticInjection(Class<?>...) - Method in interface org.elasticsearch.common.inject.Binder
-
Upon successful creation, the
Injector
will inject static fields and methods in the given classes. - requestSupplier - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- RequestValidators(Collection<MappingRequestValidator>) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction.RequestValidators
- REQUIRE_FIELD_MATCH_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- requireBinding(Class<?>) - Method in class org.elasticsearch.common.inject.AbstractModule
-
Adds a dependency from this module to
type
. - requireBinding(Key<?>) - Method in class org.elasticsearch.common.inject.AbstractModule
-
Adds a dependency from this module to
key
. - required() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
- required() - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- required(boolean) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper.Builder
- REQUIRED - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper.Defaults
- REQUIRED_SIZE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- requiredContent() - Method in class org.elasticsearch.rest.RestRequest
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- requireFieldMatch - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- requireFieldMatch() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- requireFieldMatch() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- requireFieldMatch(Boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set to true to cause a field to be highlighted only if a query matches that field.
- requireFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- REQUIRES_NAME_SETTING - Static variable in class org.elasticsearch.action.support.DestructiveOperations
-
Setting which controls whether wildcard usage (*, prefix*, _all) is allowed.
- requiresAnalysisSettings() - Method in interface org.elasticsearch.indices.analysis.AnalysisModule.AnalysisProvider
-
If
true
the analysis component created by this provider requires certain settings to be instantiated. - requiresAnalysisSettings(AnalysisModule.AnalysisProvider<T>) - Static method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Mark an
AnalysisModule.AnalysisProvider
as requiring the index's settings. - requireValidHeader(String) - Static method in class org.elasticsearch.rest.DeprecationRestHandler
-
Throw an exception if the
value
is not avalid header
. - requireValue(T, String) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
- requriesAnalysisSettings(AnalysisModule.AnalysisProvider<T>) - Static method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Deprecated.
- reroute() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdMonitor
- reroute(String) - Method in class org.elasticsearch.cluster.routing.RoutingService
-
Initiates a reroute.
- reroute(ClusterRerouteRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Reroutes allocation of shards.
- reroute(ClusterRerouteRequest, ActionListener<ClusterRerouteResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Reroutes allocation of shards.
- reroute(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Reroutes the routing table based on the live nodes.
- reroute(ClusterState, String, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Reroutes the routing table based on the live nodes.
- reroute(ClusterState, AllocationCommands, boolean, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- reroute(ShardId, String) - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
Implement this in order to scheduled another round that causes a call to fetch data.
- REROUTE_CANCELLED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of explicit cancel reroute command.
- RerouteExplanation - Class in org.elasticsearch.cluster.routing.allocation
-
Class encapsulating the explanation for a single
AllocationCommand
taken from the Deciders - RerouteExplanation(AllocationCommand, Decision) - Constructor for class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- rescheduleIfNecessary() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Schedule the task to run after the configured interval if it is not closed and any further conditions imposed by derived classes are met.
- rescore() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- rescore() - Method in class org.elasticsearch.search.internal.SearchContext
- rescore(TopDocs, IndexSearcher, RescoreContext) - Method in class org.elasticsearch.search.rescore.QueryRescorer
- rescore(TopDocs, IndexSearcher, RescoreContext) - Method in interface org.elasticsearch.search.rescore.Rescorer
-
Modifies the result of the previously executed search (
TopDocs
) in place based on the givenRescoreContext
. - RESCORE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- RescoreContext - Class in org.elasticsearch.search.rescore
-
Context available to the rescore while it is running.
- RescoreContext(int, Rescorer) - Constructor for class org.elasticsearch.search.rescore.RescoreContext
-
Build the context.
- RescorePhase - Class in org.elasticsearch.search.rescore
-
Rescore phase of a search request, used to run potentially expensive scoring models against the top matching documents.
- RescorePhase() - Constructor for class org.elasticsearch.search.rescore.RescorePhase
- rescoreQueryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- rescorer() - Method in class org.elasticsearch.search.rescore.RescoreContext
-
The rescorer to actually apply.
- Rescorer - Interface in org.elasticsearch.search.rescore
-
A query rescorer interface used to re-rank the Top-K results of a previously executed search.
- RescorerBuilder<RB extends RescorerBuilder<RB>> - Class in org.elasticsearch.search.rescore
-
The abstract base builder for instances of
RescorerBuilder
. - RescorerBuilder() - Constructor for class org.elasticsearch.search.rescore.RescorerBuilder
-
Construct an empty RescoreBuilder.
- RescorerBuilder(StreamInput) - Constructor for class org.elasticsearch.search.rescore.RescorerBuilder
-
Read from a stream.
- RescorerSpec(String, Writeable.Reader<? extends T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.RescorerSpec
- RescorerSpec(ParseField, Writeable.Reader<? extends T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.RescorerSpec
- rescores() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the bytes representing the rescore builders for this request.
- reset() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- reset() - Method in interface org.elasticsearch.cluster.routing.ShardIterator
-
Resets the iterator.
- reset() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
Resets the iterator to its initial state.
- reset() - Method in class org.elasticsearch.common.inject.internal.Stopwatch
-
Resets and returns elapsed time in milliseconds.
- reset() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- reset() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- reset() - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- reset() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- reset() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- reset() - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- reset() - Method in class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
- reset() - Method in class org.elasticsearch.common.io.stream.StreamOutput
- reset() - Method in class org.elasticsearch.common.io.UTF8StreamWriter
- reset() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- reset() - Method in class org.elasticsearch.common.util.LazyInitializable
-
Clears the value, if it has been previously created by calling
#getOrCompute()
. - reset() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- reset() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- reset() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- reset() - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- reset(double, double) - Method in class org.elasticsearch.common.geo.GeoPoint
- reset(String) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- reset(TokenStream) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- reset(SearchHit, LeafReaderContext, int, IndexSearcher) - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- RESET_CONTENT - org.elasticsearch.rest.RestStatus
-
The server has fulfilled the request and the user agent SHOULD reset the document view which caused the request to be sent.
- resetAndLog(String) - Method in class org.elasticsearch.common.inject.internal.Stopwatch
-
Resets and logs elapsed time in milliseconds.
- resetDigest() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- resetDigest() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- resetFromGeoHash(long) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromGeoHash(String) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromIndexableField(IndexableField) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromIndexHash(long) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromString(String) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromString(String, boolean) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetLat(double) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetLon(double) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetRecovery(long, TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
Resets the recovery and performs a recovery restart on the currently recovering index shard
- resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
-
Set the
ScriptDocValues.Booleans.size()
and ensure that theScriptDocValues.Booleans.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
-
Set the
ScriptDocValues.Doubles.size()
and ensure that theScriptDocValues.Doubles.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
Set the
ScriptDocValues.GeoPoints.size()
and ensure that theScriptDocValues.GeoPoints.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
-
Set the
ScriptDocValues.Longs.size()
and ensure that theScriptDocValues.Longs.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
Set the
SortingNumericDocValues.docValueCount()
and ensure that theSortingNumericDocValues.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
-
Set the
SortingNumericDoubleValues.docValueCount()
and ensure that theSortingNumericDoubleValues.values
array can store at least that many entries. - resize(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- resize(ByteArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(DoubleArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(FloatArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(IntArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(LongArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(ObjectArray<T>, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- ResizeAction - Class in org.elasticsearch.action.admin.indices.shrink
- ResizeAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that ensures we allocate the shards of a target index for resize operations next to the source primaries
- ResizeAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ResizeAllocationDecider
- resizeIndex(ResizeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Resize an index using an explicit request allowing to specify the settings, mappings and aliases of the target index of the index.
- resizeIndex(ResizeRequest, ActionListener<ResizeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Shrinks an index using an explicit request allowing to specify the settings, mappings and aliases of the target index of the index.
- ResizeRequest - Class in org.elasticsearch.action.admin.indices.shrink
-
Request class to shrink an index into a single shard
- ResizeRequest(String, String) - Constructor for class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- ResizeRequestBuilder - Class in org.elasticsearch.action.admin.indices.shrink
- ResizeRequestBuilder(ElasticsearchClient, Action<ResizeRequest, ResizeResponse, ResizeRequestBuilder>) - Constructor for class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- ResizeResponse - Class in org.elasticsearch.action.admin.indices.shrink
-
A response for a resize index action, either shrink or split index.
- ResizeResponse(boolean, boolean, String) - Constructor for class org.elasticsearch.action.admin.indices.shrink.ResizeResponse
- resizeType() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
Returns the resize type or null if this is an ordinary create index request
- resizeType(ResizeType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- ResizeType - Enum in org.elasticsearch.action.admin.indices.shrink
-
The type of the resize operation
- resolve(byte) - Static method in enum org.elasticsearch.common.rounding.DateTimeUnit
- resolve(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- resolve(String) - Static method in enum org.elasticsearch.persistent.decider.AssignmentDecision.Type
- resolve(String) - Static method in enum org.elasticsearch.search.suggest.SortBy
- resolve(String) - Static method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
- resolve(String) - Static method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
- resolve(Index) - Method in class org.elasticsearch.env.NodeEnvironment.NodePath
-
Resolves index directory against this NodePath ${data.paths}/nodes/{node.id}/indices/{index.uuid}
- resolve(QueryShardContext, ValueType, String, Script, Object, DateTimeZone, String) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Resolve a
ValuesSourceConfig
given configuration parameters. - resolve(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment.NodePath
-
Resolves the given shards directory against this NodePath ${data.paths}/nodes/{node.id}/indices/{index.uuid}/{shard.id}
- resolveAggregator(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Resolves the aggregator pointed by this path using the given root as a point of reference.
- resolveAndValidateRouting(MetaData, String, UpdateRequest) - Static method in class org.elasticsearch.action.update.TransportUpdateAction
- resolveBaseCustomLocation(IndexSettings) - Method in class org.elasticsearch.env.NodeEnvironment
-
Resolve the custom path for a index's shard.
- resolveBaseCustomLocation(IndexSettings, Path, int) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Resolve the custom path for a index's shard.
- resolveBindHostAddresses(String[]) - Method in class org.elasticsearch.common.network.NetworkService
-
Resolves
bindHosts
to a list of internet addresses. - resolveBucketValue(MultiBucketsAggregation, InternalMultiBucketAggregation.InternalBucket, String, BucketHelpers.GapPolicy) - Static method in class org.elasticsearch.search.aggregations.pipeline.BucketHelpers
-
Given a path and a set of buckets, this method will return the value inside the agg at that path.
- resolveBucketValue(MultiBucketsAggregation, InternalMultiBucketAggregation.InternalBucket, List<String>, BucketHelpers.GapPolicy) - Static method in class org.elasticsearch.search.aggregations.pipeline.BucketHelpers
- resolveClusterNames(Set<String>, String) - Method in class org.elasticsearch.cluster.metadata.ClusterNameExpressionResolver
-
Resolves the provided cluster expression to matching cluster names.
- resolveConfig(SearchContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- resolveConnectionProfile(ConnectionProfile, ConnectionProfile) - Static method in class org.elasticsearch.transport.ConnectionProfile
-
takes a
ConnectionProfile
resolves it to a fully specified (i.e., no nulls) profile - resolveCustomLocation(IndexSettings, ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Resolve the custom path for a index's shard.
- resolveCustomLocation(IndexSettings, ShardId, Path, int) - Static method in class org.elasticsearch.env.NodeEnvironment
- resolveDateMathExpression(String) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- resolveDefault() - Method in interface org.elasticsearch.common.network.NetworkService.CustomNameResolver
-
Resolves the default value if possible.
- resolveDocumentType(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Resolves a type from a mapping-related request into the type that should be used when merging and updating mappings.
- resolveDocumentType(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Resolves a type from a mapping-related request into the type that should be used when merging and updating mappings.
- resolveExpressions(ClusterState, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Resolve an array of expressions to the set of indices and aliases that these expressions match.
- resolveForScript(String) - Static method in enum org.elasticsearch.search.aggregations.support.ValueType
- resolveHosts(List<String>, int) - Method in interface org.elasticsearch.discovery.zen.UnicastHostsProvider.HostsResolver
- resolveHostsLists(ExecutorService, Logger, List<String>, int, TransportService, TimeValue) - Static method in class org.elasticsearch.discovery.zen.UnicastZenPing
-
Resolves a list of hosts to a list of transport addresses.
- resolveIfPossible(String) - Method in interface org.elasticsearch.common.network.NetworkService.CustomNameResolver
-
Resolves a custom value handling, return
null
if can't handle it. - resolveIndex() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- resolveIndex() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
True if provided index should be resolved when resolving request
- resolveIndex() - Method in class org.elasticsearch.index.shard.ShardPath
- resolveIndex(AnalyzeRequest) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- resolveIndex(GetFieldMappingsIndexRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- resolveIndex(ExplainRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- resolveIndex(FieldCapabilitiesIndexRequest) - Method in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesIndexAction
- resolveIndex(GetRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
- resolveIndex(MultiGetShardRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- resolveIndex(MultiTermVectorsShardRequest) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- resolveIndex(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- resolveIndex(Request) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- resolveIndexFolder(String) - Method in class org.elasticsearch.env.NodeEnvironment
-
Resolves all existing paths to
indexFolderName
in ${data.paths}/nodes/{node.id}/indices - resolveIndexId(String) - Method in class org.elasticsearch.repositories.RepositoryData
-
Resolve the index name to the index id specific to the repository, throwing an exception if the index could not be resolved.
- resolveIndexRouting(String, String, String) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Returns indexing routing for the given index.
- resolveIndices(List<String>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Resolve the given index names to index ids.
- resolveMappingField(QueryShardContext, String, float, boolean, boolean) - Static method in class org.elasticsearch.index.search.QueryParserHelper
-
Resolves the provided pattern or field name from the
QueryShardContext
and return a map of the expanded fields with their original boost. - resolveMappingField(QueryShardContext, String, float, boolean, boolean, String) - Static method in class org.elasticsearch.index.search.QueryParserHelper
-
Resolves the provided pattern or field name from the
QueryShardContext
and return a map of the expanded fields with their original boost. - resolveMappingFields(QueryShardContext, Map<String, Float>) - Static method in class org.elasticsearch.index.search.QueryParserHelper
- resolveMappingFields(QueryShardContext, Map<String, Float>, String) - Static method in class org.elasticsearch.index.search.QueryParserHelper
-
Resolve all the field names and patterns present in the provided map with the
QueryShardContext
and returns a new map containing all the expanded fields with their original boost. - resolveNested(QueryShardContext, String, QueryBuilder) - Static method in class org.elasticsearch.search.sort.SortBuilder
- resolveNested(QueryShardContext, NestedSortBuilder) - Static method in class org.elasticsearch.search.sort.SortBuilder
- resolveNewIndices(List<String>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Resolve the given index names to index ids, creating new index ids for new indices in the repository.
- resolveNode(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Resolve a node with a given id
- resolveNodePath(Path, int) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Resolve a specific nodes/{node.id} path for the specified path and node lock id.
- resolveNodes(String...) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
resolves a set of node "descriptions" to concrete and existing node ids.
- resolveNodes(TasksRequest, ClusterState) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- resolvePrefixTreeStrategy(String) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- resolvePrefixTreeStrategy(SpatialStrategy) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- resolvePublishHostAddresses(String[]) - Method in class org.elasticsearch.common.network.NetworkService
-
Resolves
publishHosts
to a single publish address. - resolveRepoFile(String) - Method in class org.elasticsearch.env.Environment
-
Resolves the specified location against the list of configured repository roots If the specified location doesn't match any of the roots, returns null.
- resolveRepoURL(URL) - Method in class org.elasticsearch.env.Environment
-
Checks if the specified URL is pointing to the local file system and if it does, resolves the specified url against the list of configured repository roots If the specified url doesn't match any of the roots, returns null.
- resolveRequest(NodesRequest, ClusterState) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
resolve node ids to concrete nodes of the incoming request
- resolveRequest(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- resolveRequest(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
- resolveRequest(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- resolveRequest(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- resolveRequest(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- resolveRequest(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
Resolves the request.
- resolveRequest(IndexMetaData, Request) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Resolves derived values in the request.
- resolveRouting(MetaData) - Method in class org.elasticsearch.action.index.IndexRequest
- resolveSearchRouting(ClusterState, String, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Resolves the search routing if in the expression aliases are used.
- resolveSearchRoutingAllIndices(MetaData, String) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Sets the same routing for all indices
- resolveStatesToBeWritten(Set<Index>, Set<Index>, MetaData, MetaData) - Static method in class org.elasticsearch.gateway.GatewayMetaState
-
Loads the current meta state for each index in the new cluster state and checks if it has to be persisted.
- resolveTopmostAggregator(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Resolves the topmost aggregator pointed by this path using the given root as a point of reference.
- resolveTranslog() - Method in class org.elasticsearch.index.shard.ShardPath
- resolveTypeVariable(Type, Class<?>, TypeVariable) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
- resolveValue(String) - Static method in enum org.elasticsearch.index.query.RegexpFlag
-
Resolves the combined OR'ed value for the given list of regular expression flags.
- resolveValue(HasAggregations) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Resolves the value pointed by this path given an aggregations root
- resolveWriteIndexRouting(String, String, String) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Returns indexing routing for the given
aliasOrIndex
. - ResourceAlreadyExistsException - Exception in org.elasticsearch
- ResourceAlreadyExistsException(String, Object...) - Constructor for exception org.elasticsearch.ResourceAlreadyExistsException
- ResourceAlreadyExistsException(StreamInput) - Constructor for exception org.elasticsearch.ResourceAlreadyExistsException
- ResourceAlreadyExistsException(Index) - Constructor for exception org.elasticsearch.ResourceAlreadyExistsException
- ResourceNotFoundException - Exception in org.elasticsearch
-
Generic ResourceNotFoundException corresponding to the
RestStatus.NOT_FOUND
status code - ResourceNotFoundException(String, Object...) - Constructor for exception org.elasticsearch.ResourceNotFoundException
- ResourceNotFoundException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.ResourceNotFoundException
- ResourceNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.ResourceNotFoundException
- ResourceWatcher - Interface in org.elasticsearch.watcher
-
Abstract resource watcher interface.
- ResourceWatcherService - Class in org.elasticsearch.watcher
-
Generic resource watcher service Other elasticsearch services can register their resource watchers with this service using
ResourceWatcherService.add(ResourceWatcher)
method. - ResourceWatcherService(Settings, ThreadPool) - Constructor for class org.elasticsearch.watcher.ResourceWatcherService
- ResourceWatcherService.Frequency - Enum in org.elasticsearch.watcher
- respond(ActionListener<TransportResponse.Empty>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResult
- respond(ActionListener<TransportResponse.Empty>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
- respond(ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- respond(ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- respondIfPossible(Exception) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
-
Respond if the refresh has occurred and the listener is ready.
- respondIfPossible(Exception) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
-
Respond if the refresh has occurred and the listener is ready.
- Response() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.Response
- Response() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Response
- Response(boolean, List<ScrollableHitSource.SearchFailure>, long, List<? extends ScrollableHitSource.Hit>, String) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.Response
- ResponseCollectorService - Class in org.elasticsearch.node
-
Collects statistics about queue size, response time, and service time of tasks executed on each node, making the EWMA of the values available to the coordinating node.
- ResponseCollectorService(ClusterService) - Constructor for class org.elasticsearch.node.ResponseCollectorService
- ResponseCollectorService.ComputedNodeStats - Class in org.elasticsearch.node
-
Struct-like class encapsulating a point-in-time snapshot of a particular node's statistics.
- ResponseHandlerFailureTransportException - Exception in org.elasticsearch.transport
-
A failure to handle the response of a transaction action.
- ResponseHandlerFailureTransportException(Throwable) - Constructor for exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
- ResponseHandlerFailureTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
- ResponseHandlers() - Constructor for class org.elasticsearch.transport.Transport.ResponseHandlers
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
-
Parameters used for controlling the response and thus might not be consumed during preparation of the request execution in
BaseRestHandler.prepareRequest(RestRequest, NodeClient)
. - responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- responseParams() - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
- responseParams() - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- responseParams() - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- responseParams() - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- responseParams() - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- responseParams() - Method in class org.elasticsearch.rest.action.search.RestSearchAction
- responseParams() - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
- responseParams() - Method in class org.elasticsearch.rest.BaseRestHandler
-
Parameters used for controlling the response and thus might not be consumed during preparation of the request execution in
BaseRestHandler.prepareRequest(RestRequest, NodeClient)
. - responseSupplier - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- responseTime - Variable in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- REST_DECODER - Static variable in class org.elasticsearch.rest.RestUtils
- REST_EXCEPTION_SKIP_STACK_TRACE - Static variable in exception org.elasticsearch.ElasticsearchException
-
Passed in the
ToXContent.Params
ofElasticsearchException.generateThrowableXContent(XContentBuilder, Params, Throwable)
to control if thestack_trace
element should render. - REST_EXCEPTION_SKIP_STACK_TRACE_DEFAULT - Static variable in exception org.elasticsearch.ElasticsearchException
- RestActionListener<Response> - Class in org.elasticsearch.rest.action
-
An action listener that requires
RestActionListener.processResponse(Object)
to be implemented and will automatically handle failures. - RestActionListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestActionListener
- restActions() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Should the node rest actions usage statistics be returned.
- restActions(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Should the node rest actions usage statistics be returned.
- RestActions - Class in org.elasticsearch.rest.action
- RestActions() - Constructor for class org.elasticsearch.rest.action.RestActions
- RestActions.NodesResponseRestListener<NodesResponse extends BaseNodesResponse & ToXContent> - Class in org.elasticsearch.rest.action
-
NodesResponseRestBuilderListener
automatically translates anyBaseNodesResponse
(multi-node) response that isToXContent
-compatible into aRestResponse
with the necessary header info (e.g., "cluster_name"). - RestAliasAction - Class in org.elasticsearch.rest.action.cat
- RestAliasAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestAliasAction
- RestAllocationAction - Class in org.elasticsearch.rest.action.cat
- RestAllocationAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestAllocationAction
- RestAnalyzeAction - Class in org.elasticsearch.rest.action.admin.indices
- RestAnalyzeAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction
- RestAnalyzeAction.Fields - Class in org.elasticsearch.rest.action.admin.indices
- restart(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- RestBuilderListener<Response> - Class in org.elasticsearch.rest.action
-
A REST action listener that builds an
XContentBuilder
based response. - RestBuilderListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestBuilderListener
- RestBulkAction - Class in org.elasticsearch.rest.action.document
-
{ "index" : { "_index" : "test", "_type" : "type1", "_id" : "1" } { "type1" : { "field1" : "value1" } } { "delete" : { "_index" : "test", "_type" : "type1", "_id" : "2" } } { "create" : { "_index" : "test", "_type" : "type1", "_id" : "1" } { "type1" : { "field1" : "value1" } }
- RestBulkAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestBulkAction
- RestCancelTasksAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestCancelTasksAction(Settings, RestController, Supplier<DiscoveryNodes>) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestCancelTasksAction
- RestCatAction - Class in org.elasticsearch.rest.action.cat
- RestCatAction(Settings, RestController, List<AbstractCatAction>) - Constructor for class org.elasticsearch.rest.action.cat.RestCatAction
- RestChannel - Interface in org.elasticsearch.rest
-
A channel used to construct bytes / builder based outputs, and send responses.
- RestClearIndicesCacheAction - Class in org.elasticsearch.rest.action.admin.indices
- RestClearIndicesCacheAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- RestClearIndicesCacheAction.Fields - Class in org.elasticsearch.rest.action.admin.indices
- RestClearScrollAction - Class in org.elasticsearch.rest.action.search
- RestClearScrollAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.search.RestClearScrollAction
- RestCloseIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestCloseIndexAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestCloseIndexAction
- RestClusterAllocationExplainAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Class handling cluster allocation explanation at the REST level
- RestClusterAllocationExplainAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- RestClusterGetSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterGetSettingsAction(Settings, RestController, ClusterSettings, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- RestClusterHealthAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterHealthAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- RestClusterRerouteAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterRerouteAction(Settings, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- RestClusterSearchShardsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterSearchShardsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterSearchShardsAction
- RestClusterStateAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterStateAction(Settings, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- RestClusterStatsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterStatsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterStatsAction
- RestClusterUpdateSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterUpdateSettingsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- RestController - Class in org.elasticsearch.rest
- RestController(Set<String>, UnaryOperator<RestHandler>, NodeClient, CircuitBreakerService, UsageService) - Constructor for class org.elasticsearch.rest.RestController
- RestCountAction - Class in org.elasticsearch.rest.action.cat
- RestCountAction - Class in org.elasticsearch.rest.action.document
- RestCountAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestCountAction
- RestCountAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestCountAction
- RestCreateIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestCreateIndexAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestCreateIndexAction
- RestCreateSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Creates a new snapshot
- RestCreateSnapshotAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestCreateSnapshotAction
- RestDeleteAction - Class in org.elasticsearch.rest.action.document
- RestDeleteAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestDeleteAction
- RestDeleteIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestDeleteIndexAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexAction
- RestDeleteIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestDeleteIndexTemplateAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexTemplateAction
- RestDeletePipelineAction - Class in org.elasticsearch.rest.action.ingest
- RestDeletePipelineAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.ingest.RestDeletePipelineAction
- RestDeleteRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Unregisters a repository
- RestDeleteRepositoryAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestDeleteRepositoryAction
- RestDeleteSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Deletes a snapshot
- RestDeleteSnapshotAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestDeleteSnapshotAction
- RestDeleteStoredScriptAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestDeleteStoredScriptAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestDeleteStoredScriptAction
- RestExplainAction - Class in org.elasticsearch.rest.action.search
-
Rest action for computing a score explanation for specific documents.
- RestExplainAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.search.RestExplainAction
- RestFieldCapabilitiesAction - Class in org.elasticsearch.rest.action
- RestFieldCapabilitiesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.RestFieldCapabilitiesAction
- RestFielddataAction - Class in org.elasticsearch.rest.action.cat
-
Cat API class to display information about the size of fielddata fields per node
- RestFielddataAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestFielddataAction
- RestFlushAction - Class in org.elasticsearch.rest.action.admin.indices
- RestFlushAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestFlushAction
- RestForceMergeAction - Class in org.elasticsearch.rest.action.admin.indices
- RestForceMergeAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestForceMergeAction
- RestGetAction - Class in org.elasticsearch.rest.action.document
- RestGetAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestGetAction
- RestGetAliasesAction - Class in org.elasticsearch.rest.action.admin.indices
-
The REST handler for get alias and head alias APIs.
- RestGetAliasesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetAliasesAction
- RestGetAllAliasesAction - Class in org.elasticsearch.rest.action.admin.indices
-
The REST handler for retrieving all aliases
- RestGetAllAliasesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetAllAliasesAction
- RestGetFieldMappingAction - Class in org.elasticsearch.rest.action.admin.indices
- RestGetFieldMappingAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetFieldMappingAction
- RestGetIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
-
The REST handler for get template and head template APIs.
- RestGetIndexTemplateAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- RestGetIndicesAction - Class in org.elasticsearch.rest.action.admin.indices
-
The REST handler for get index and head index APIs.
- RestGetIndicesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
- RestGetMappingAction - Class in org.elasticsearch.rest.action.admin.indices
- RestGetMappingAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetMappingAction
- RestGetPipelineAction - Class in org.elasticsearch.rest.action.ingest
- RestGetPipelineAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.ingest.RestGetPipelineAction
- RestGetRepositoriesAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Returns repository information
- RestGetRepositoriesAction(Settings, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- RestGetSettingsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestGetSettingsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetSettingsAction
- RestGetSnapshotsAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Returns information about snapshot
- RestGetSnapshotsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetSnapshotsAction
- RestGetSourceAction - Class in org.elasticsearch.rest.action.document
-
The REST handler for get source and head source APIs.
- RestGetSourceAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestGetSourceAction
- RestGetStoredScriptAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestGetStoredScriptAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetStoredScriptAction
- RestGetTaskAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestGetTaskAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetTaskAction
- RestHandler - Interface in org.elasticsearch.rest
-
Handler for REST requests
- RestHealthAction - Class in org.elasticsearch.rest.action.cat
- RestHealthAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestHealthAction
- RestIndexAction - Class in org.elasticsearch.rest.action.document
- RestIndexAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestIndexAction
- RestIndexDeleteAliasesAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndexDeleteAliasesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndexDeleteAliasesAction
- RestIndexPutAliasAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndexPutAliasAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndexPutAliasAction
- RestIndicesAction - Class in org.elasticsearch.rest.action.cat
- RestIndicesAction(Settings, RestController, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.rest.action.cat.RestIndicesAction
- RestIndicesAliasesAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndicesAliasesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndicesAliasesAction
- RestIndicesSegmentsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndicesSegmentsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndicesSegmentsAction
- RestIndicesShardStoresAction - Class in org.elasticsearch.rest.action.admin.indices
-
Rest action for
IndicesShardStoresAction
- RestIndicesShardStoresAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndicesShardStoresAction
- RestIndicesStatsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndicesStatsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- RestListTasksAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestListTasksAction(Settings, RestController, Supplier<DiscoveryNodes>) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- RestMainAction - Class in org.elasticsearch.rest.action
- RestMainAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.RestMainAction
- RestMasterAction - Class in org.elasticsearch.rest.action.cat
- RestMasterAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestMasterAction
- RestMultiGetAction - Class in org.elasticsearch.rest.action.document
- RestMultiGetAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestMultiGetAction
- RestMultiSearchAction - Class in org.elasticsearch.rest.action.search
- RestMultiSearchAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.search.RestMultiSearchAction
- RestMultiTermVectorsAction - Class in org.elasticsearch.rest.action.document
- RestMultiTermVectorsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestMultiTermVectorsAction
- RestNodeAttrsAction - Class in org.elasticsearch.rest.action.cat
- RestNodeAttrsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- RestNodesAction - Class in org.elasticsearch.rest.action.cat
- RestNodesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestNodesAction
- RestNodesHotThreadsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestNodesHotThreadsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- RestNodesInfoAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestNodesInfoAction(Settings, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- RestNodesStatsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestNodesStatsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- RestNodesUsageAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestNodesUsageAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestNodesUsageAction
- RestOpenIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestOpenIndexAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestOpenIndexAction
- restorable() - Method in enum org.elasticsearch.snapshots.SnapshotState
-
Returns true if snapshot can be restored (at least partially)
- restore() - Method in interface org.elasticsearch.common.util.concurrent.ThreadContext.StoredContext
- restore(SnapshotFiles) - Method in class org.elasticsearch.repositories.blobstore.FileRestoreContext
-
Performs restore operation
- RestoreClusterStateListener - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
- restoreFiles(List<BlobStoreIndexShardSnapshot.FileInfo>, Store) - Method in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- restoreFromRepository(Repository) - Method in class org.elasticsearch.index.shard.IndexShard
- RestoreInfo - Class in org.elasticsearch.snapshots
-
Information about successfully completed restore operation.
- RestoreInfo(String, List<String>, int, int) - Constructor for class org.elasticsearch.snapshots.RestoreInfo
- restoreInProgress(ClusterState, String) - Static method in class org.elasticsearch.snapshots.RestoreService
- RestoreInProgress - Class in org.elasticsearch.cluster
-
Meta data about restore processes that are currently executing
- RestoreInProgress(StreamInput) - Constructor for class org.elasticsearch.cluster.RestoreInProgress
- RestoreInProgress.Builder - Class in org.elasticsearch.cluster
- RestoreInProgress.Entry - Class in org.elasticsearch.cluster
-
Restore metadata
- RestoreInProgress.ShardRestoreStatus - Class in org.elasticsearch.cluster
-
Represents status of a restored shard
- RestoreInProgress.State - Enum in org.elasticsearch.cluster
-
Shard restore process state
- RestoreInProgressAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
prevents shards that have failed to be restored from a snapshot to be allocated. - RestoreInProgressAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.RestoreInProgressAllocationDecider
- RestoreInProgressUpdater() - Constructor for class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- restoreLocalHistoryFromTranslog(Engine.TranslogRecoveryRunner) - Method in class org.elasticsearch.index.engine.Engine
-
This method replays translog to restore the Lucene index which might be reverted previously.
- restoreLocalHistoryFromTranslog(Engine.TranslogRecoveryRunner) - Method in class org.elasticsearch.index.engine.InternalEngine
- restoreLocalHistoryFromTranslog(Engine.TranslogRecoveryRunner) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- RestoreService - Class in org.elasticsearch.snapshots
-
Service responsible for restoring snapshots
- RestoreService(ClusterService, RepositoriesService, AllocationService, MetaDataCreateIndexService, MetaDataIndexUpgradeService, ClusterSettings) - Constructor for class org.elasticsearch.snapshots.RestoreService
- RestoreService.RestoreCompletionResponse - Class in org.elasticsearch.snapshots
- RestoreService.RestoreInProgressUpdater - Class in org.elasticsearch.snapshots
- restoreShard(IndexShard, SnapshotId, Version, IndexId, ShardId, RecoveryState) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- restoreShard(IndexShard, SnapshotId, Version, IndexId, ShardId, RecoveryState) - Method in class org.elasticsearch.repositories.FilterRepository
- restoreShard(IndexShard, SnapshotId, Version, IndexId, ShardId, RecoveryState) - Method in interface org.elasticsearch.repositories.Repository
-
Restores snapshot of the shard.
- restoreSnapshot(RestoreSnapshotRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restores a snapshot.
- restoreSnapshot(RestoreSnapshotRequest, ActionListener<RestoreSnapshotResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restores a snapshot.
- restoreSnapshot(RestoreSnapshotRequest, ActionListener<RestoreService.RestoreCompletionResponse>) - Method in class org.elasticsearch.snapshots.RestoreService
-
Restores snapshot specified in the restore request.
- RestoreSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Restore snapshot action
- restoreSnapshotRequest(String, String) - Static method in class org.elasticsearch.client.Requests
-
Restores new snapshot
- RestoreSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Restore snapshot request
- RestoreSnapshotRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- RestoreSnapshotRequest(String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Constructs a new put repository request with the provided repository and snapshot names.
- RestoreSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Restore snapshot request builder
- RestoreSnapshotRequestBuilder(ElasticsearchClient, RestoreSnapshotAction) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Constructs new restore snapshot request builder
- RestoreSnapshotRequestBuilder(ElasticsearchClient, RestoreSnapshotAction, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Constructs new restore snapshot request builder with specified repository and snapshot names
- RestoreSnapshotResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Contains information about restores snapshot
- restoreUUID() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- RestPendingClusterTasksAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestPendingClusterTasksAction - Class in org.elasticsearch.rest.action.cat
- RestPendingClusterTasksAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestPendingClusterTasksAction
- RestPendingClusterTasksAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- RestPluginsAction - Class in org.elasticsearch.rest.action.cat
- RestPluginsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestPluginsAction
- RestPutIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestPutIndexTemplateAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- RestPutMappingAction - Class in org.elasticsearch.rest.action.admin.indices
- RestPutMappingAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- RestPutPipelineAction - Class in org.elasticsearch.rest.action.ingest
- RestPutPipelineAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.ingest.RestPutPipelineAction
- RestPutRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Registers repositories
- RestPutRepositoryAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestPutRepositoryAction
- RestPutStoredScriptAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestPutStoredScriptAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestPutStoredScriptAction
- RestRecoveryAction - Class in org.elasticsearch.rest.action.admin.indices
-
REST handler to report on index recoveries.
- RestRecoveryAction - Class in org.elasticsearch.rest.action.cat
-
RestRecoveryAction provides information about the status of replica recovery in a string format, designed to be used at the command line.
- RestRecoveryAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestRecoveryAction
- RestRecoveryAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestRecoveryAction
- RestRefreshAction - Class in org.elasticsearch.rest.action.admin.indices
- RestRefreshAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestRefreshAction
- RestReloadSecureSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestReloadSecureSettingsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- RestRemoteClusterInfoAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestRemoteClusterInfoAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestRemoteClusterInfoAction
- RestRepositoriesAction - Class in org.elasticsearch.rest.action.cat
-
Cat API class to display information about snapshot repositories
- RestRepositoriesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- RestRequest - Class in org.elasticsearch.rest
- RestRequest(NamedXContentRegistry, String, Map<String, List<String>>) - Constructor for class org.elasticsearch.rest.RestRequest
-
Creates a new REST request.
- RestRequest(NamedXContentRegistry, Map<String, String>, String, Map<String, List<String>>) - Constructor for class org.elasticsearch.rest.RestRequest
-
Creates a new REST request.
- RestRequest.BadParameterException - Exception in org.elasticsearch.rest
- RestRequest.ContentTypeHeaderException - Exception in org.elasticsearch.rest
- RestRequest.Method - Enum in org.elasticsearch.rest
- RestResizeHandler - Class in org.elasticsearch.rest.action.admin.indices
- RestResizeHandler.RestShrinkIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestResizeHandler.RestSplitIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestResponse - Class in org.elasticsearch.rest
- RestResponse() - Constructor for class org.elasticsearch.rest.RestResponse
- RestResponseListener<Response> - Class in org.elasticsearch.rest.action
-
A REST enabled action listener that has a basic onFailure implementation, and requires sub classes to only implement
RestResponseListener.buildResponse(Object)
. - RestResponseListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestResponseListener
- RestRestoreSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Restores a snapshot
- RestRestoreSnapshotAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestRestoreSnapshotAction
- RestRolloverIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestRolloverIndexAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestRolloverIndexAction
- RestSearchAction - Class in org.elasticsearch.rest.action.search
- RestSearchAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.search.RestSearchAction
- RestSearchScrollAction - Class in org.elasticsearch.rest.action.search
- RestSearchScrollAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.search.RestSearchScrollAction
- RestSegmentsAction - Class in org.elasticsearch.rest.action.cat
- RestSegmentsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestSegmentsAction
- RestShardsAction - Class in org.elasticsearch.rest.action.cat
- RestShardsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestShardsAction
- RestShrinkIndexAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestShrinkIndexAction
- RestSimulatePipelineAction - Class in org.elasticsearch.rest.action.ingest
- RestSimulatePipelineAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.ingest.RestSimulatePipelineAction
- RestSnapshotAction - Class in org.elasticsearch.rest.action.cat
-
Cat API class to display information about snapshots
- RestSnapshotAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestSnapshotAction
- RestSnapshotsStatusAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Returns status of currently running snapshot
- RestSnapshotsStatusAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestSnapshotsStatusAction
- RestSplitIndexAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestSplitIndexAction
- restStatus() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- RestStatus - Enum in org.elasticsearch.rest
- RestStatusToXContentListener<Response extends StatusToXContentObject> - Class in org.elasticsearch.rest.action
-
Content listener that extracts that
RestStatus
from the response. - RestStatusToXContentListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestStatusToXContentListener
-
Build an instance that doesn't support responses with the status
201 CREATED
. - RestStatusToXContentListener(RestChannel, Function<Response, String>) - Constructor for class org.elasticsearch.rest.action.RestStatusToXContentListener
-
Build an instance that does support responses with the status
201 CREATED
. - RestSyncedFlushAction - Class in org.elasticsearch.rest.action.admin.indices
- RestSyncedFlushAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestSyncedFlushAction
- RestTable - Class in org.elasticsearch.rest.action.cat
- RestTable() - Constructor for class org.elasticsearch.rest.action.cat.RestTable
- RestTasksAction - Class in org.elasticsearch.rest.action.cat
- RestTasksAction(Settings, RestController, Supplier<DiscoveryNodes>) - Constructor for class org.elasticsearch.rest.action.cat.RestTasksAction
- RestTemplatesAction - Class in org.elasticsearch.rest.action.cat
- RestTemplatesAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestTemplatesAction
- RestTermVectorsAction - Class in org.elasticsearch.rest.action.document
-
This class parses the json request and translates it into a TermVectorsRequest.
- RestTermVectorsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestTermVectorsAction
- RestThreadPoolAction - Class in org.elasticsearch.rest.action.cat
- RestThreadPoolAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- RestToXContentListener<Response extends ToXContentObject> - Class in org.elasticsearch.rest.action
-
A REST based action listener that assumes the response is of type
ToXContent
and automatically builds an XContent based response (wrapping the toXContent in startObject/endObject). - RestToXContentListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestToXContentListener
- RestUpdateAction - Class in org.elasticsearch.rest.action.document
- RestUpdateAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.document.RestUpdateAction
- RestUpdateSettingsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestUpdateSettingsAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- RestUpgradeAction - Class in org.elasticsearch.rest.action.admin.indices
- RestUpgradeAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestUpgradeAction
- RestUpgradeStatusAction - Class in org.elasticsearch.rest.action.admin.indices
- RestUpgradeStatusAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestUpgradeStatusAction
- RestUtils - Class in org.elasticsearch.rest
- RestUtils() - Constructor for class org.elasticsearch.rest.RestUtils
- RestValidateQueryAction - Class in org.elasticsearch.rest.action.admin.indices
- RestValidateQueryAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestValidateQueryAction
- RestVerifyRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestVerifyRepositoryAction(Settings, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestVerifyRepositoryAction
- result - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- result - Variable in class org.elasticsearch.action.DocWriteResponse
- result() - Method in class org.elasticsearch.action.StepListener
-
Gets the result of this step.
- result() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- result(DiscoveryNode, Exception) - Method in class org.elasticsearch.tasks.Task
- result(DiscoveryNode, ActionResponse) - Method in class org.elasticsearch.tasks.Task
- Result(Condition, boolean) - Constructor for class org.elasticsearch.action.admin.indices.rollover.Condition.Result
- Result(Streamable, DocWriteResponse.Result, Map<String, Object>, XContentType) - Constructor for class org.elasticsearch.action.update.UpdateHelper.Result
- Result(Engine.Operation.TYPE, long, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.Result
- Result(Engine.Operation.TYPE, Exception, long, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.Result
- Result(Engine.Operation.TYPE, Mapping) - Constructor for class org.elasticsearch.index.engine.Engine.Result
- Result(Correction[], double) - Constructor for class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker.Result
- resultingState - Variable in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult
- resultListener - Variable in class org.elasticsearch.action.support.replication.ReplicationOperation
- resume() - Method in class org.elasticsearch.watcher.WatcherHandle
- resync(IndexShard, ActionListener<PrimaryReplicaSyncer.ResyncTask>) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer
- ResyncReplicationRequest - Class in org.elasticsearch.action.resync
-
Represents a batch of operations sent from the primary to its replicas during the primary-replica resync.
- ResyncReplicationRequest(ShardId, long, long, Translog.Operation[]) - Constructor for class org.elasticsearch.action.resync.ResyncReplicationRequest
- ResyncReplicationResponse - Class in org.elasticsearch.action.resync
- ResyncReplicationResponse() - Constructor for class org.elasticsearch.action.resync.ResyncReplicationResponse
- ResyncRequest(ShardId, String) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncRequest
- ResyncTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- RETAIN_ALL - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions
- retainAll(Collection<?>) - Method in class org.elasticsearch.common.collect.EvictingQueue
- retainingSequenceNumber() - Method in class org.elasticsearch.index.seqno.RetentionLease
-
The retaining sequence number of this retention lease.
- RETENTION_LEASE_SYNC_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.IndexService
- RetentionLease - Class in org.elasticsearch.index.seqno
-
A "shard history retention lease" (or "retention lease" for short) is conceptually a marker containing a retaining sequence number such that all operations with sequence number at least that retaining sequence number will be retained during merge operations (which could otherwise merge away operations that have been soft deleted).
- RetentionLease(String, long, long, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLease
-
Constructs a new retention lease.
- RetentionLease(StreamInput) - Constructor for class org.elasticsearch.index.seqno.RetentionLease
-
Constructs a new retention lease from a stream.
- RetentionLeaseActions - Class in org.elasticsearch.index.seqno
-
This class holds all actions related to retention leases.
- RetentionLeaseActions() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions
- RetentionLeaseActions.Add - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Add.TransportAction - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.AddRequest - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Remove - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Remove.TransportAction - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.RemoveRequest - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Renew - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Renew.TransportAction - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.RenewRequest - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Response - Class in org.elasticsearch.index.seqno
- RetentionLeaseAlreadyExistsException - Exception in org.elasticsearch.index.seqno
- RetentionLeaseAlreadyExistsException(String) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseAlreadyExistsException
- RetentionLeaseAlreadyExistsException(StreamInput) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseAlreadyExistsException
- RetentionLeaseBackgroundSyncAction - Class in org.elasticsearch.index.seqno
-
Replication action responsible for background syncing retention leases to replicas.
- RetentionLeaseBackgroundSyncAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- RetentionLeaseBackgroundSyncAction.Request - Class in org.elasticsearch.index.seqno
- RetentionLeaseNotFoundException - Exception in org.elasticsearch.index.seqno
- RetentionLeaseNotFoundException(String) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseNotFoundException
- RetentionLeaseNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseNotFoundException
- retentionLeases() - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
-
The underlying retention lease collection backing this stats object.
- retentionLeases() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- RetentionLeases - Class in org.elasticsearch.index.seqno
-
Represents a versioned collection of retention leases.
- RetentionLeases(long, long, Collection<RetentionLease>) - Constructor for class org.elasticsearch.index.seqno.RetentionLeases
-
Constructs a new retention lease collection with the specified version and underlying collection of retention leases.
- RetentionLeases(StreamInput) - Constructor for class org.elasticsearch.index.seqno.RetentionLeases
-
Constructs a new retention lease collection from a stream.
- retentionLeasesSupplier() - Method in class org.elasticsearch.index.engine.EngineConfig
-
A supplier of the outstanding retention leases.
- RetentionLeaseStats - Class in org.elasticsearch.index.seqno
-
Represents retention lease stats.
- RetentionLeaseStats(StreamInput) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseStats
-
Constructs a new retention lease stats object from a stream.
- RetentionLeaseStats(RetentionLeases) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseStats
-
Constructs a new retention lease stats object from the specified retention lease collection.
- RetentionLeaseSyncAction - Class in org.elasticsearch.index.seqno
-
Write action responsible for syncing retention leases to replicas.
- RetentionLeaseSyncAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- RetentionLeaseSyncAction.Request - Class in org.elasticsearch.index.seqno
- RetentionLeaseSyncAction.Response - Class in org.elasticsearch.index.seqno
- RetentionLeaseSyncer - Interface in org.elasticsearch.index.seqno
-
A functional interface that represents a method for syncing retention leases to replica shards after a new retention lease is added on the primary.
- rethrottle(float) - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
-
Apply
newRequestsPerSecond
as the new rate limit for this task's search requests - rethrowAndSuppress(List<T>) - Static method in class org.elasticsearch.ExceptionsHelper
-
Rethrows the first exception in the list and adds all remaining to the suppressed list.
- rethrowErrors(Runnable) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Checks if the runnable arose from asynchronous submission of a task to an executor.
- rethrowFailures(String) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
-
Rethrow task failures if there are any.
- reThrowIfNotNull(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
Throws the specified exception.
- RETRIES_BULK_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- RETRIES_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- RETRIES_SEARCH_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- retrieve(String) - Method in class org.elasticsearch.common.path.PathTrie
- retrieve(String[], int, Map<String, String>, PathTrie.TrieMatchingMode) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
- retrieve(String, Map<String, String>) - Method in class org.elasticsearch.common.path.PathTrie
- retrieve(String, Map<String, String>, PathTrie.TrieMatchingMode) - Method in class org.elasticsearch.common.path.PathTrie
- retrieveAll(String, Supplier<Map<String, String>>) - Method in class org.elasticsearch.common.path.PathTrie
-
Returns an iterator of the objects stored in the
PathTrie
, using all possibleTrieMatchingMode
modes. - retrieveInterestingTerms(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- retrieveInterestingTerms(Reader, String) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Convenience routine to make it easy to return the most interesting words in a document.
- Retry - Class in org.elasticsearch.action.bulk
-
Encapsulates synchronous and asynchronous retry logic.
- Retry(BackoffPolicy, Scheduler) - Constructor for class org.elasticsearch.action.bulk.Retry
- retryable() - Method in class org.elasticsearch.cluster.block.ClusterBlock
-
Should operations get into retry state if this block is present.
- retryable() - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- retryCopy() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
Returns a fresh recovery target to retry recovery from the same source node onto the same shard and using the same listener.
- retryDelayNetwork() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- retryDelayStateSync() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- retryOnConflict() - Method in class org.elasticsearch.action.update.UpdateRequest
- retryOnConflict(int) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the number of retries of a version conflict occurs because the document was updated between getting it and updating it.
- retryOnFailure(Exception) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- retryOnFailure(Exception) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- RetryOnPrimaryException(StreamInput) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationOperation.RetryOnPrimaryException
- RetryOnPrimaryException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationOperation.RetryOnPrimaryException
- RetryOnPrimaryException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationOperation.RetryOnPrimaryException
- RetryOnReplicaException(StreamInput) - Constructor for exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException
- RetryOnReplicaException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException
- retryPrimaryException(Throwable) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- retryRecovery(long, String, TimeValue, TimeValue) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- retryRecovery(long, Throwable, TimeValue, TimeValue) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- returns(Matcher<? super Class<?>>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches methods with matching return types.
- reuseAddress - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- reused() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
-
returns true if the file is reused from a local copy
- reusedBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- reusedFileCount() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- reverseNested(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
ReverseNested
aggregation with the given name. - ReverseNested - Interface in org.elasticsearch.search.aggregations.bucket.nested
-
A
reverse nested
aggregation. - ReverseNestedAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.nested
- ReverseNestedAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- ReverseNestedAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
-
Read from a stream.
- ReverseNestedAggregationBuilder(ReverseNestedAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- ReverseNestedAggregator - Class in org.elasticsearch.search.aggregations.bucket.nested
- ReverseNestedAggregator(String, AggregatorFactories, ObjectMapper, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
- ReverseNestedAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.nested
- ReverseNestedAggregatorFactory(String, boolean, ObjectMapper, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregatorFactory
- revision - Variable in class org.elasticsearch.Version
- rewrite() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- rewrite() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be rewritten into primitive queries
- rewrite() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- rewrite() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- rewrite() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- rewrite() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- rewrite() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- rewrite(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be rewritten into primitive queries
- rewrite(String) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- rewrite(String) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- rewrite(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- rewrite(String) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- rewrite(String) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- rewrite(List<T>, QueryRewriteContext) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites each element of the list until it doesn't change and returns a new list iff there is at least one element of the list that changed during it's rewrite.
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.BlendedTermQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.MinDocQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypesQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- rewrite(IndexReader, MultiTermQuery) - Method in class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- rewrite(Query) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- rewrite(QueryRewriteContext) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Rewrites this query builder into its primitive form.
- rewrite(QueryRewriteContext) - Method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites this instance based on the provided context.
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
Rewrites the underlying aggregation builders into their primitive form.
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Rewrites this search source builder into its primitive form.
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.internal.AliasFilter
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- rewrite(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- rewrite(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristic
-
Provides a hook for subclasses to provide a version of the heuristic prepared for execution on data on the coordinating node.
- rewrite(SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- rewrite(SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristic
-
Provides a hook for subclasses to provide a version of the heuristic prepared for execution on data on a shard.
- rewrite(T, QueryRewriteContext) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites the given
Rewriteable
into its primitive form. - rewrite(T, QueryRewriteContext, boolean) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites the given
Rewriteable
into its primitive form. - REWRITE_TIME - Static variable in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- Rewriteable<T> - Interface in org.elasticsearch.index.query
-
A basic interface for rewriteable classes.
- rewriteAndFetch(T, QueryRewriteContext, ActionListener<T>) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites the given rewriteable and fetches pending async tasks for each round before rewriting again.
- rewriteAndFetch(T, QueryRewriteContext, ActionListener<T>, int) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites the given rewriteable and fetches pending async tasks for each round before rewriting again.
- RIGHT - org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
- rollGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Roll the current translog generation into a new generation.
- RolloverAction - Class in org.elasticsearch.action.admin.indices.rollover
- rolloverIndex(RolloverRequest, ActionListener<RolloverResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Swaps the index pointed to by an alias given all provided conditions are satisfied
- RolloverInfo - Class in org.elasticsearch.action.admin.indices.rollover
-
Class for holding Rollover related information within an index
- RolloverInfo(String, List<Condition>, long) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- RolloverInfo(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- RolloverRequest - Class in org.elasticsearch.action.admin.indices.rollover
-
Request class to swap index under an alias upon satisfying conditions Note: there is a new class with the same name for the Java HLRC that uses a typeless format.
- RolloverRequest(String, String) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- RolloverRequestBuilder - Class in org.elasticsearch.action.admin.indices.rollover
- RolloverRequestBuilder(ElasticsearchClient, RolloverAction) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- RolloverResponse - Class in org.elasticsearch.action.admin.indices.rollover
-
Response object for
RolloverRequest
API Note: there is a new class with the same name for the Java HLRC that uses a typeless format. - RolloverResponse(String, String, Map<String, Boolean>, boolean, boolean, boolean, boolean) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- rolloversIndex(RolloverRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Swaps the index pointed to by an alias given all provided conditions are satisfied
- rollTranslogGeneration() - Method in class org.elasticsearch.index.engine.Engine
-
Rolls the translog generation and cleans unneeded.
- rollTranslogGeneration() - Method in class org.elasticsearch.index.engine.InternalEngine
- rollTranslogGeneration() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- root() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- root() - Method in class org.elasticsearch.index.mapper.Mapping
-
Return the root object mapper.
- root() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- root() - Method in class org.elasticsearch.index.mapper.ParseContext
- rootDoc() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- rootDoc() - Method in class org.elasticsearch.index.mapper.ParseContext
- rootDoc() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- rootDocs(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
-
Get a
BitDocIdSet
that matches the root documents. - RootObjectMapper - Class in org.elasticsearch.index.mapper
- RootObjectMapper.Builder - Class in org.elasticsearch.index.mapper
- RootObjectMapper.Defaults - Class in org.elasticsearch.index.mapper
- RootObjectMapper.TypeParser - Class in org.elasticsearch.index.mapper
- roots - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
A list of top-level "roots".
- rotate(List<T>, int) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Return a rotated view of the given list with the given distance.
- RotationShardShuffler - Class in org.elasticsearch.cluster.routing
-
Basic
ShardShuffler
implementation that uses anAtomicInteger
to generate seeds and uses a rotation to permute shards. - RotationShardShuffler(int) - Constructor for class org.elasticsearch.cluster.routing.RotationShardShuffler
- round(long) - Method in class org.elasticsearch.common.rounding.Rounding
-
Rounds the given value.
- Rounding - Class in org.elasticsearch.common.rounding
-
A strategy for rounding long values.
- Rounding() - Constructor for class org.elasticsearch.common.rounding.Rounding
- Rounding.Builder - Class in org.elasticsearch.common.rounding
- Rounding.Streams - Class in org.elasticsearch.common.rounding
- RoundingInfo(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- RoundingInfo(Rounding, long, String, int...) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- routing - Variable in class org.elasticsearch.index.shard.IndexShard.ShardFailure
- routing - Variable in class org.elasticsearch.index.translog.Translog.Source
- routing() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- routing() - Method in class org.elasticsearch.action.bulk.BulkRequest
- routing() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Controls the shard routing of the delete request.
- routing() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the routing for this request
- routing() - Method in class org.elasticsearch.action.explain.ExplainRequest
- routing() - Method in class org.elasticsearch.action.get.GetRequest
- routing() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- routing() - Method in class org.elasticsearch.action.index.IndexRequest
-
Controls the shard routing of the request.
- routing() - Method in class org.elasticsearch.action.search.SearchRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- routing() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- routing() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Controls the shard routing of the request.
- routing() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
- routing() - Method in class org.elasticsearch.index.engine.Engine.Index
- routing() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- routing() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- routing() - Method in class org.elasticsearch.index.mapper.SourceToParse
- routing() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- routing() - Method in class org.elasticsearch.index.translog.Translog.Index
- routing() - Method in class org.elasticsearch.indices.TermsLookup
- routing(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- routing(String) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates a routing value to the alias
- routing(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Set the default routing.
- routing(String) - Method in class org.elasticsearch.action.bulk.BulkRequest
- routing(String) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
- routing(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Controls the shard routing of the request.
- routing(String) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Set the routing for this request
- routing(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
- routing(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Controls the shard routing of the request.
- routing(String) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
The routing associated with this document.
- routing(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Controls the shard routing of the request.
- routing(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- routing(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- routing(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Controls the shard routing of the request.
- routing(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- routing(String) - Method in class org.elasticsearch.index.mapper.SourceToParse
- routing(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- routing(String) - Method in class org.elasticsearch.indices.TermsLookup
- routing(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
The routing values to control the shards that the search will be executed on.
- routing(String...) - Method in class org.elasticsearch.action.search.SearchRequest
-
The routing values to control the shards that the search will be executed on.
- Routing(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
- ROUTING - org.elasticsearch.ingest.IngestDocument.MetaData
- ROUTING - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- ROUTING_NODES - org.elasticsearch.cluster.ClusterState.Metric
- ROUTING_TABLE - org.elasticsearch.cluster.ClusterState.Metric
- RoutingAllocation - Class in org.elasticsearch.cluster.routing.allocation
-
The
RoutingAllocation
keep the state of the current allocation of shards and holds theAllocationDeciders
which are responsible for the current routing state. - RoutingAllocation(AllocationDeciders, RoutingNodes, ClusterState, ClusterInfo, long) - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Creates a new
RoutingAllocation
- RoutingAllocation.DebugMode - Enum in org.elasticsearch.cluster.routing.allocation
- RoutingChangesObserver - Interface in org.elasticsearch.cluster.routing
-
Records changes made to
RoutingNodes
during an allocation round. - RoutingChangesObserver.AbstractRoutingChangesObserver - Class in org.elasticsearch.cluster.routing
-
Abstract implementation of
RoutingChangesObserver
that does not take any action. - RoutingChangesObserver.DelegatingRoutingChangesObserver - Class in org.elasticsearch.cluster.routing
- routingEntry() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
routing entry for this primary
- routingEntry() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the latest cluster routing entry received with this shard.
- routingEntry() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Returns the latest cluster routing entry received with this shard.
- RoutingException - Exception in org.elasticsearch.cluster.routing
-
A base
Exception
s for all exceptions thrown by routing related operations. - RoutingException(String) - Constructor for exception org.elasticsearch.cluster.routing.RoutingException
- RoutingException(String, Throwable) - Constructor for exception org.elasticsearch.cluster.routing.RoutingException
- RoutingException(StreamInput) - Constructor for exception org.elasticsearch.cluster.routing.RoutingException
- RoutingExplanations - Class in org.elasticsearch.cluster.routing.allocation
-
Class used to encapsulate a number of
RerouteExplanation
explanations. - RoutingExplanations() - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
- routingFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- RoutingFieldMapper - Class in org.elasticsearch.index.mapper
- RoutingFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- RoutingFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- RoutingFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- RoutingMissingException - Exception in org.elasticsearch.action
- RoutingMissingException(String, String, String) - Constructor for exception org.elasticsearch.action.RoutingMissingException
- RoutingMissingException(StreamInput) - Constructor for exception org.elasticsearch.action.RoutingMissingException
- RoutingNode - Class in org.elasticsearch.cluster.routing
-
A
RoutingNode
represents a cluster node associated with a singleDiscoveryNode
including all shards that are hosted on that nodes. - RoutingNode(String, DiscoveryNode, ShardRouting...) - Constructor for class org.elasticsearch.cluster.routing.RoutingNode
- routingNodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get current routing nodes
- RoutingNodes - Class in org.elasticsearch.cluster.routing
-
RoutingNodes
represents a copy the routing information contained in thecluster state
. - RoutingNodes(ClusterState) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
- RoutingNodes(ClusterState, boolean) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
- RoutingNodes.UnassignedShards - Class in org.elasticsearch.cluster.routing
- RoutingNodes.UnassignedShards.UnassignedIterator - Class in org.elasticsearch.cluster.routing
- routingNodesChanged() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns true iff changes were made to the routing nodes
- RoutingNodesChangedObserver - Class in org.elasticsearch.cluster.routing.allocation
-
Records if changes were made to
RoutingNodes
during an allocation round. - RoutingNodesChangedObserver() - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- routingPartitionSize() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
Returns the routing partition size.
- routingPartitionSize(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- routingRequired(String, String) - Method in class org.elasticsearch.cluster.metadata.MetaData
- RoutingService - Class in org.elasticsearch.cluster.routing
-
A
RoutingService
listens to clusters state. - RoutingService(ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.routing.RoutingService
- routingTable() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- routingTable() - Method in class org.elasticsearch.cluster.ClusterState
- routingTable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get routing table of current nodes
- routingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- routingTable(RoutingTable) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- RoutingTable - Class in org.elasticsearch.cluster.routing
-
Represents a global cluster-wide routing table for all indices including the version of the current routing state.
- RoutingTable.Builder - Class in org.elasticsearch.cluster.routing
-
Builder for the routing table.
- routingTableChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the routing tables (for all indices) have changed between the previous cluster state and the current cluster state. - RPAREN - Static variable in class org.elasticsearch.common.geo.parsers.GeoWKTParser
- RPM - org.elasticsearch.Build.Type
- run() - Method in class org.elasticsearch.cluster.InternalClusterInfoService.SubmitReschedulingClusterInfoUpdatedJob
- run() - Method in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- run() - Method in interface org.elasticsearch.common.CheckedRunnable
- run() - Method in interface org.elasticsearch.common.util.CancellableThreads.Interruptible
- run() - Method in interface org.elasticsearch.common.util.CancellableThreads.IOInterruptible
- run() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- run() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
- run() - Method in class org.elasticsearch.common.util.concurrent.RunOnce
- run() - Method in class org.elasticsearch.script.SearchScript
- run(Object, List<? extends TaskBatcher.BatchedTask>, String) - Method in class org.elasticsearch.cluster.service.TaskBatcher
-
Action to be implemented by the specific batching implementation All tasks have the given batching key.
- run(Engine, Translog.Snapshot) - Method in interface org.elasticsearch.index.engine.Engine.TranslogRecoveryRunner
- runAfter(ActionListener<Response>, Runnable) - Static method in interface org.elasticsearch.action.ActionListener
-
Wraps a given listener and returns a new listener which executes the provided
runAfter
callback when the listener is notified via either#onResponse
or#onFailure
. - runAsDouble() - Method in class org.elasticsearch.script.SearchScript
-
Return the result as a double.
- runAsLong() - Method in class org.elasticsearch.script.SearchScript
-
Return the result as a long.
- runAsLong() - Method in class org.elasticsearch.script.TermsSetQueryScript
-
Return the result as a long.
- runDeferredCollections(long...) - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- runInternal() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- runningSliceSubTasks() - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
The number of sliced subtasks that are still running
- runOnApplierThread(String, Consumer<ClusterState>, ClusterApplier.ClusterApplyListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- runOnApplierThread(String, Consumer<ClusterState>, ClusterApplier.ClusterApplyListener, Priority) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- RunOnce - Class in org.elasticsearch.common.util.concurrent
-
Runnable that can only be run one time.
- RunOnce(Runnable) - Constructor for class org.elasticsearch.common.util.concurrent.RunOnce
- runOnlyOnMaster() - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor
-
indicates whether this executor should only run if the current node is master
- runOnlyOnMaster() - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
Marked as final as cluster state update tasks should only run on master.
- runOnlyOnMaster() - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- runOnlyOnMaster() - Method in class org.elasticsearch.discovery.zen.NodeJoinController.JoinTaskExecutor
- runOnlyWhenMaster() - Method in class org.elasticsearch.cluster.service.MasterService.TaskInputs
- runTask(ClusterApplierService.UpdateTask) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- runTasks(MasterService.TaskInputs) - Method in class org.elasticsearch.cluster.service.MasterService
- runUnderPrimaryPermit(Runnable, Consumer<Exception>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Runs the specified runnable under a permit and otherwise calling back the specified failure callback.
- RWE_LIKELIHOOD_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- rwl - Variable in class org.elasticsearch.index.engine.Engine
- rxCount() - Method in class org.elasticsearch.transport.TransportStats
- rxSize() - Method in class org.elasticsearch.transport.TransportStats
S
- SafeScheduledThreadPoolExecutor(int) - Constructor for class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- SafeScheduledThreadPoolExecutor(int, ThreadFactory) - Constructor for class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- SafeScheduledThreadPoolExecutor(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- same(Settings, Settings) - Static method in class org.elasticsearch.index.IndexSettings
-
Compare the specified settings for equality.
- SAME - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- sameOrAfter(Priority) - Method in enum org.elasticsearch.common.Priority
- SameShardAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that prevents multiple instances of the same shard to be allocated on the same
node
. - SameShardAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
- sampler(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Sampler
aggregation with the given name. - Sampler - Interface in org.elasticsearch.search.aggregations.bucket.sampler
-
A
filter
aggregation that defines a single bucket to hold a sample of top-matching documents. - SamplerAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.sampler
- SamplerAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- SamplerAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
-
Read from a stream.
- SamplerAggregationBuilder(SamplerAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- SamplerAggregator - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
Aggregate on only the top-scoring docs on a shard.
- SamplerAggregator.ExecutionMode - Enum in org.elasticsearch.search.aggregations.bucket.sampler
- SamplerAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.sampler
- save(Path, char[]) - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Write the keystore to the given config directory.
- SCALE - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- SCALING - org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- ScalingExecutorBuilder - Class in org.elasticsearch.threadpool
-
A builder for scaling executors.
- ScalingExecutorBuilder(String, int, int, TimeValue) - Constructor for class org.elasticsearch.threadpool.ScalingExecutorBuilder
-
Construct a scaling executor builder; the settings will have the key prefix "thread_pool." followed by the executor name.
- ScalingExecutorBuilder(String, int, int, TimeValue, String) - Constructor for class org.elasticsearch.threadpool.ScalingExecutorBuilder
-
Construct a scaling executor builder; the settings will have the specified key prefix.
- scanSeqNosInReader(DirectoryReader, long, long, LongConsumer) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Scans sequence numbers (i.e.,
SeqNoFieldMapper.NAME
) betweenfromSeqNo
(inclusive) andtoSeqNo
(inclusive) in the provided directory reader. - schedule(Runnable, TimeValue, String) - Method in interface org.elasticsearch.threadpool.Scheduler
-
Schedules a one-shot command to be run after a given delay.
- schedule(Runnable, TimeValue, String) - Method in class org.elasticsearch.threadpool.ThreadPool
-
Schedules a one-shot command to run after a given delay.
- schedule(TimeValue, String, Runnable) - Method in interface org.elasticsearch.threadpool.Scheduler
-
Deprecated.use
Scheduler.schedule(Runnable, TimeValue, String)
instead - scheduleDeprecated(TimeValue, String, Runnable) - Method in class org.elasticsearch.threadpool.ThreadPool
-
Deprecated.
- scheduler - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provides scheduler support
- scheduler() - Method in class org.elasticsearch.threadpool.ThreadPool
- Scheduler - Interface in org.elasticsearch.threadpool
-
Scheduler that allows to schedule one-shot and periodic commands.
- Scheduler.Cancellable - Interface in org.elasticsearch.threadpool
-
This interface represents an object whose execution may be cancelled during runtime.
- Scheduler.ReschedulingRunnable - Class in org.elasticsearch.threadpool
-
This class encapsulates the scheduling of a
Runnable
that needs to be repeated on a interval. - Scheduler.SafeScheduledThreadPoolExecutor - Class in org.elasticsearch.threadpool
-
This subclass ensures to properly bubble up Throwable instances of both type Error and Exception thrown in submitted/scheduled tasks to the uncaught exception handler
- Scheduler.ScheduledCancellable - Interface in org.elasticsearch.threadpool
-
A scheduled cancellable allow cancelling and reading the remaining delay of a scheduled task.
- scheduleTask(ThreadPool) - Method in class org.elasticsearch.indices.IndexingMemoryController
- scheduleWithFixedDelay(Runnable, TimeValue, String) - Method in interface org.elasticsearch.threadpool.Scheduler
-
Schedules a periodic action that runs on scheduler thread.
- scheduleWithFixedDelay(Runnable, TimeValue, String) - Method in class org.elasticsearch.threadpool.ThreadPool
- scope() - Method in class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
- scope() - Method in interface org.elasticsearch.index.analysis.AnalyzerProvider
- scope() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
The scope of the analyzer.
- scope() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
- scope(Key<T>, Provider<T>) - Method in interface org.elasticsearch.common.inject.Scope
-
Scopes a provider.
- Scope - Interface in org.elasticsearch.common.inject
-
A scope is a level of visibility that instances provided by Guice may have.
- SCOPE_ALREADY_SET - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- ScopeAnnotation - Annotation Type in org.elasticsearch.common.inject
-
Annotates annotations which are used for scoping.
- scopeAnnotationOnAbstractType(Class<? extends Annotation>, Class<?>, Object) - Method in class org.elasticsearch.common.inject.internal.Errors
- ScopeBinding - Class in org.elasticsearch.common.inject.spi
-
Registration of a scope annotation with the scope that implements it.
- ScopedBindingBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - scopeNotFound(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.Errors
- Scopes - Class in org.elasticsearch.common.inject
-
Built-in scope implementations.
- Scoping - Class in org.elasticsearch.common.inject.internal
-
References a scope, either directly (as a scope instance), or indirectly (as a scope annotation).
- score - Variable in class org.elasticsearch.action.termvectors.TermVectorsFilter.ScoreTerm
- score - Variable in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- score - Variable in class org.elasticsearch.search.suggest.phrase.Correction
- score - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- score(float) - Method in class org.elasticsearch.search.SearchHit
- score(int, float) - Method in class org.elasticsearch.common.lucene.search.function.LeafScoreFunction
- score(DirectCandidateGenerator.Candidate[], DirectCandidateGenerator.CandidateSet[], int, int) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- Score() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Score
- SCORE - org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- SCORE - org.elasticsearch.search.profile.query.QueryTimingType
- SCORE - org.elasticsearch.search.suggest.SortBy
-
Sort should first be based on score, then document frequency and then the term itself.
- SCORE - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- SCORE - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- SCORE - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion
- SCORE_ERROR_MESSAGE - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- SCORE_MODE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- ScoreAccessor - Class in org.elasticsearch.script
-
A float encapsulation that dynamically accesses the score of a document.
- ScoreAccessor(Scorer) - Constructor for class org.elasticsearch.script.ScoreAccessor
- scoreBigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolatingScorer
- scoreBigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- ScoreFunction - Class in org.elasticsearch.common.lucene.search.function
- ScoreFunction(CombineFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.ScoreFunction
- ScoreFunctionBuilder<FB extends ScoreFunctionBuilder<FB>> - Class in org.elasticsearch.index.query.functionscore
- ScoreFunctionBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Standard empty constructor.
- ScoreFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Read from a stream.
- ScoreFunctionBuilders - Class in org.elasticsearch.index.query.functionscore
-
Static method aliases for constructors of known
ScoreFunctionBuilder
s. - ScoreFunctionBuilders() - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- ScoreFunctionParser<FB extends ScoreFunctionBuilder<FB>> - Interface in org.elasticsearch.index.query.functionscore
-
Parses XContent into a
ScoreFunctionBuilder
. - ScoreFunctionSpec(String, Writeable.Reader<T>, ScoreFunctionParser<T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.ScoreFunctionSpec
- ScoreFunctionSpec(ParseField, Writeable.Reader<T>, ScoreFunctionParser<T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.ScoreFunctionSpec
- scoreMode() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the score mode, meaning how results of individual score functions will be aggregated.
- scoreMode() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Returns how the scores from the matching child documents are mapped into the nested parent document.
- scoreMode() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- scoreMode(FunctionScoreQuery.ScoreMode) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Score mode defines how results of individual score functions will be aggregated.
- scoreModeAsString(ScoreMode) - Static method in class org.elasticsearch.index.query.NestedQueryBuilder
- scoreOrdered() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- scorer - Variable in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
- scorer(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- ScorerAware - Interface in org.elasticsearch.common.lucene
- scorerSupplier(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- ScoreScript - Class in org.elasticsearch.script
-
A script used for adjusting the score on a per document basis.
- ScoreScript(Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.ScoreScript
- ScoreScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
ScoreScript
factories for a specific index. - ScoreScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
ScoreScript
instances. - scoreSort() - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a new score sort.
- ScoreSortBuilder - Class in org.elasticsearch.search.sort
-
A sort builder allowing to sort by score.
- ScoreSortBuilder() - Constructor for class org.elasticsearch.search.sort.ScoreSortBuilder
-
Build a ScoreSortBuilder default to descending sort order.
- ScoreSortBuilder(StreamInput) - Constructor for class org.elasticsearch.search.sort.ScoreSortBuilder
-
Read from a stream.
- scoreTrigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolatingScorer
- scoreTrigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- scoreUnigram(DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- SCORING_BOOLEAN - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- script() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- script() - Method in class org.elasticsearch.action.update.UpdateRequest
- script() - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- script() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the script to use for this source
- script() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the script to use for this aggregation.
- script() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- script() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- script() - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext.ScriptField
- script() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Get the script used in this sort.
- script(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- script(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - script(String, String, ScriptType, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - script(String, ScriptType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - script(String, ScriptType, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - script(Script) - Method in class org.elasticsearch.action.update.UpdateRequest
-
The script to execute.
- script(Script) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequestBuilder
-
Script to modify the documents before they are processed.
- script(Script) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the script to use for this source
- script(Script) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- script(Script) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the script to use for this aggregation.
- script(SearchScript.LeafFactory) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- Script - Class in org.elasticsearch.script
-
Script
represents used-defined input that can be used to compile and execute a script from theScriptService
based on theScriptType
. - Script(String) - Constructor for class org.elasticsearch.script.Script
-
Constructor for simple script using the default language and default type.
- Script(StreamInput) - Constructor for class org.elasticsearch.script.Script
-
Creates a
Script
read from an input stream. - Script(ScriptType, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.script.Script
-
Constructor for a script that does not need to use compiler options.
- Script(ScriptType, String, String, Map<String, String>, Map<String, Object>) - Constructor for class org.elasticsearch.script.Script
-
Constructor for a script that requires the use of compiler options.
- Script(SearchScript.LeafFactory) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
- Script(SearchScript.LeafFactory, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- SCRIPT - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- SCRIPT_CACHE_EXPIRE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_CACHE_SIZE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SCRIPT_FIELD - Static variable in class org.elasticsearch.search.sort.ScriptSortBuilder
- SCRIPT_FIELDS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SCRIPT_MAX_COMPILATIONS_RATE - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_MAX_SIZE_IN_BYTES - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for outer level of script queries. - SCRIPT_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for outer level of stored script source. - SCRIPT_SORT_CONTEXT - Static variable in class org.elasticsearch.script.SearchScript
- ScriptBytesValues - Class in org.elasticsearch.search.aggregations.support.values
-
SortedBinaryDocValues
implementation that reads values from a script. - ScriptBytesValues(SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
- ScriptContext<FactoryType> - Class in org.elasticsearch.script
-
The information necessary to compile and run a script.
- ScriptContext(String, Class<FactoryType>) - Constructor for class org.elasticsearch.script.ScriptContext
-
Construct a context with the related instance and compiled classes.
- ScriptDocValues<T> - Class in org.elasticsearch.index.fielddata
-
Script level doc values, the assumption is that any implementation will implement a
getValue
and agetValues
that return the relevant type that then can be used in scripts. - ScriptDocValues() - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues
- ScriptDocValues.Booleans - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.BytesRefs - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Dates - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Doubles - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.GeoPoints - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Longs - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Strings - Class in org.elasticsearch.index.fielddata
- ScriptDoubleValues - Class in org.elasticsearch.search.aggregations.support.values
-
SortingNumericDoubleValues
implementation which is based on a script - ScriptDoubleValues(SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
- scriptedMetric(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
ScriptedMetric
aggregation with the given name. - ScriptedMetric - Interface in org.elasticsearch.search.aggregations.metrics.scripted
-
A metric aggregation that computes both its final and intermediate states using scripts.
- ScriptedMetricAggContexts - Class in org.elasticsearch.script
- ScriptedMetricAggContexts() - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts
- ScriptedMetricAggContexts.CombineScript - Class in org.elasticsearch.script
- ScriptedMetricAggContexts.CombineScript.Factory - Interface in org.elasticsearch.script
- ScriptedMetricAggContexts.InitScript - Class in org.elasticsearch.script
- ScriptedMetricAggContexts.InitScript.Factory - Interface in org.elasticsearch.script
- ScriptedMetricAggContexts.MapScript - Class in org.elasticsearch.script
- ScriptedMetricAggContexts.MapScript.Factory - Interface in org.elasticsearch.script
- ScriptedMetricAggContexts.MapScript.LeafFactory - Interface in org.elasticsearch.script
- ScriptedMetricAggContexts.ReduceScript - Class in org.elasticsearch.script
- ScriptedMetricAggContexts.ReduceScript.Factory - Interface in org.elasticsearch.script
- ScriptedMetricAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.scripted
- ScriptedMetricAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- ScriptedMetricAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
-
Read from a stream.
- ScriptedMetricAggregationBuilder(ScriptedMetricAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- ScriptedMetricAggregator - Class in org.elasticsearch.search.aggregations.metrics.scripted
- ScriptedMetricAggregator(String, ScriptedMetricAggContexts.MapScript.LeafFactory, ScriptedMetricAggContexts.CombineScript, Script, Object, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
- ScriptedMetricAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.scripted
- ScriptedMetricAggregatorFactory(String, ScriptedMetricAggContexts.MapScript.Factory, Map<String, Object>, ScriptedMetricAggContexts.InitScript.Factory, Map<String, Object>, ScriptedMetricAggContexts.CombineScript.Factory, Map<String, Object>, Script, Map<String, Object>, SearchLookup, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregatorFactory
- ScriptedSimilarity - Class in org.elasticsearch.index.similarity
-
A
Similarity
implementation that allows scores to be scripted. - ScriptedSimilarity(String, SimilarityWeightScript.Factory, String, SimilarityScript.Factory, boolean) - Constructor for class org.elasticsearch.index.similarity.ScriptedSimilarity
-
Sole constructor.
- ScriptedSimilarity.Doc - Class in org.elasticsearch.index.similarity
-
Statistics that are specific to a document.
- ScriptedSimilarity.Field - Class in org.elasticsearch.index.similarity
-
Statistics that are specific to a given field.
- ScriptedSimilarity.Query - Class in org.elasticsearch.index.similarity
-
Scoring factors that come from the query.
- ScriptedSimilarity.Term - Class in org.elasticsearch.index.similarity
-
Statistics that are specific to a given term.
- scriptedUpsert() - Method in class org.elasticsearch.action.update.UpdateRequest
- scriptedUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
- ScriptEngine - Interface in org.elasticsearch.script
-
A script language implementation.
- ScriptException - Exception in org.elasticsearch.script
-
Exception from a scripting engine.
- ScriptException(String, Throwable, List<String>, String, String) - Constructor for exception org.elasticsearch.script.ScriptException
-
Create a new ScriptException.
- ScriptException(StreamInput) - Constructor for exception org.elasticsearch.script.ScriptException
-
Deserializes a ScriptException from a
StreamInput
- scriptField(String, Script) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Adds a script field under the given name with the provided script.
- scriptField(String, Script) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a script field under the given name with the provided script.
- scriptField(String, Script, boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Adds a script field under the given name with the provided script.
- scriptField(String, Script, boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a script field under the given name with the provided script.
- ScriptField(String, Script, boolean) - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- ScriptField(String, SearchScript.LeafFactory, boolean) - Constructor for class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext.ScriptField
- ScriptField(StreamInput) - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
-
Read from a stream.
- ScriptField(XContentParser) - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- scriptFields() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Gets the script fields.
- scriptFields() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the script fields.
- scriptFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- scriptFields() - Method in class org.elasticsearch.search.internal.SearchContext
- scriptFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
- scriptFields(List<SearchSourceBuilder.ScriptField>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- ScriptFieldsContext - Class in org.elasticsearch.search.fetch.subphase
- ScriptFieldsContext() - Constructor for class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext
- ScriptFieldsContext.ScriptField - Class in org.elasticsearch.search.fetch.subphase
- ScriptFieldsFetchSubPhase - Class in org.elasticsearch.search.fetch.subphase
- ScriptFieldsFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.ScriptFieldsFetchSubPhase
- scriptFunction(String) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- scriptFunction(Function<SortedSetDocValues, ScriptDocValues<?>>) - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData.Builder
- scriptFunction(Script) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- ScriptHeuristic - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- ScriptHeuristic(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
-
Read from a stream.
- ScriptHeuristic(Script) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- ScriptHeuristic.LongAccessor - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- scriptLang() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script()
instead - scriptLang(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - ScriptLongValues - Class in org.elasticsearch.search.aggregations.support.values
-
LongValues
implementation which is based on a script - ScriptLongValues(SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
- ScriptMetaData - Class in org.elasticsearch.script
-
ScriptMetaData
is used to store user-defined scripts as part of theClusterState
using only an id as the key. - ScriptMetaData(StreamInput) - Constructor for class org.elasticsearch.script.ScriptMetaData
- ScriptMetaData.Builder - Class in org.elasticsearch.script
-
A builder used to modify the currently stored scripts data held within the
ClusterState
. - ScriptMetrics - Class in org.elasticsearch.script
- ScriptMetrics() - Constructor for class org.elasticsearch.script.ScriptMetrics
- ScriptModule - Class in org.elasticsearch.script
-
Manages building
ScriptService
. - ScriptModule(Settings, List<ScriptPlugin>) - Constructor for class org.elasticsearch.script.ScriptModule
- scriptParams() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script()
instead - scriptParams(Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - ScriptPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's scripting functionality. - scriptQuery(Script) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A builder for filter based on a script.
- ScriptQueryBuilder - Class in org.elasticsearch.index.query
- ScriptQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.ScriptQueryBuilder
-
Read from a stream.
- ScriptQueryBuilder(Script) - Constructor for class org.elasticsearch.index.query.ScriptQueryBuilder
- ScriptScoreFunction - Class in org.elasticsearch.common.lucene.search.function
- ScriptScoreFunction(Script, ScoreScript.LeafFactory) - Constructor for class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- ScriptScoreFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
-
A function that uses a script to compute or influence the score of documents that match with the inner query or filter.
- ScriptScoreFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
-
Read from a stream.
- ScriptScoreFunctionBuilder(Script) - Constructor for class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- scriptService - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provides processors script support.
- scriptService() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- ScriptService - Class in org.elasticsearch.script
- ScriptService(Settings, Map<String, ScriptEngine>, Map<String, ScriptContext<?>>) - Constructor for class org.elasticsearch.script.ScriptService
- scriptSort(Script, ScriptSortBuilder.ScriptSortType) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a new script based sort.
- ScriptSortBuilder - Class in org.elasticsearch.search.sort
-
Script sort builder allows to sort based on a custom script expression.
- ScriptSortBuilder(StreamInput) - Constructor for class org.elasticsearch.search.sort.ScriptSortBuilder
-
Read from a stream.
- ScriptSortBuilder(Script, ScriptSortBuilder.ScriptSortType) - Constructor for class org.elasticsearch.search.sort.ScriptSortBuilder
-
Constructs a script sort builder with the given script.
- ScriptSortBuilder.ScriptSortType - Enum in org.elasticsearch.search.sort
- ScriptStats - Class in org.elasticsearch.script
- ScriptStats(long, long) - Constructor for class org.elasticsearch.script.ScriptStats
- ScriptStats(StreamInput) - Constructor for class org.elasticsearch.script.ScriptStats
- scriptString() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script()
instead - scriptType() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script()
instead - ScriptType - Enum in org.elasticsearch.script
-
ScriptType represents the way a script is stored and retrieved from the
ScriptService
. - scriptValueType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- scriptValueType(ValueType) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- scroll - Variable in class org.elasticsearch.search.internal.ScrollContext
- scroll() - Method in class org.elasticsearch.action.search.SearchRequest
-
If set, will enable scrolling of the search request.
- scroll() - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request.
- scroll() - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- scroll() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- scroll() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- scroll() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- scroll(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- scroll(String) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- scroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- scroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- scroll(Scroll) - Method in class org.elasticsearch.action.search.SearchRequest
-
If set, will enable scrolling of the search request.
- scroll(Scroll) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request.
- scroll(Scroll) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- Scroll - Class in org.elasticsearch.search
-
A scroll enables scrolling of search request.
- Scroll(StreamInput) - Constructor for class org.elasticsearch.search.Scroll
- Scroll(TimeValue) - Constructor for class org.elasticsearch.search.Scroll
-
Constructs a new scroll of the provided keep alive.
- ScrollableHitSource - Class in org.elasticsearch.index.reindex
-
A scrollable source of results.
- ScrollableHitSource(Logger, BackoffPolicy, ThreadPool, Runnable, Consumer<Exception>) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource
- ScrollableHitSource.BasicHit - Class in org.elasticsearch.index.reindex
-
An implementation of ScrollableHitSource.Hit that uses getters and setters.
- ScrollableHitSource.Hit - Interface in org.elasticsearch.index.reindex
-
A document returned as part of the response.
- ScrollableHitSource.Response - Class in org.elasticsearch.index.reindex
-
Response from each scroll batch.
- ScrollableHitSource.SearchFailure - Class in org.elasticsearch.index.reindex
-
A failure during search.
- scrollContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- scrollContext() - Method in class org.elasticsearch.search.internal.SearchContext
- scrollContext(ScrollContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- scrollContext(ScrollContext) - Method in class org.elasticsearch.search.internal.SearchContext
- scrollContext(ScrollContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- ScrollContext - Class in org.elasticsearch.search.internal
-
Wrapper around information that needs to stay around when scrolling.
- ScrollContext() - Constructor for class org.elasticsearch.search.internal.ScrollContext
- scrollId() - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
The scroll id used to scroll the search.
- scrollId(String) - Method in class org.elasticsearch.action.search.SearchResponse
- scrollId(String) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- scrollIds() - Method in class org.elasticsearch.action.search.ClearScrollRequest
- scrollIds(List<String>) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- ScrollQueryFetchSearchResult - Class in org.elasticsearch.search.fetch
- ScrollQueryFetchSearchResult() - Constructor for class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- ScrollQueryFetchSearchResult(StreamInput) - Constructor for class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- ScrollQueryFetchSearchResult(QueryFetchSearchResult, SearchShardTarget) - Constructor for class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- ScrollQuerySearchResult - Class in org.elasticsearch.search.query
- ScrollQuerySearchResult() - Constructor for class org.elasticsearch.search.query.ScrollQuerySearchResult
- ScrollQuerySearchResult(StreamInput) - Constructor for class org.elasticsearch.search.query.ScrollQuerySearchResult
- ScrollQuerySearchResult(QuerySearchResult, SearchShardTarget) - Constructor for class org.elasticsearch.search.query.ScrollQuerySearchResult
- search - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- search - Variable in class org.elasticsearch.index.engine.Segment
- search() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- search(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- search(List<LeafReaderContext>, Weight, Collector) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- search(SearchRequest) - Method in interface org.elasticsearch.client.Client
-
Search across one or more indices and one or more types with a query.
- search(SearchRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- search(SearchRequest, ActionListener<SearchResponse>) - Method in interface org.elasticsearch.client.Client
-
Search across one or more indices and one or more types with a query.
- search(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- Search - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- SEARCH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SEARCH_AFTER - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SEARCH_AFTER - Static variable in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- SEARCH_ANALYZER - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- SEARCH_ENABLE_REMOTE_CLUSTERS - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_CLUSTER_SEEDS_UPGRADER - Static variable in class org.elasticsearch.transport.RemoteClusterAware
- SEARCH_REMOTE_CLUSTER_SKIP_UNAVAILABLE - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_CLUSTER_SKIP_UNAVAILABLE_UPGRADER - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_CLUSTERS_PROXY - Static variable in class org.elasticsearch.transport.RemoteClusterAware
- SEARCH_REMOTE_CLUSTERS_PROXY_UPGRADER - Static variable in class org.elasticsearch.transport.RemoteClusterAware
- SEARCH_REMOTE_CLUSTERS_SEEDS - Static variable in class org.elasticsearch.transport.RemoteClusterAware
- SEARCH_REMOTE_CONNECTIONS_PER_CLUSTER - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_INITIAL_CONNECTION_TIMEOUT_SETTING - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_NODE_ATTRIBUTE - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_THROTTLED - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SearchAction - Class in org.elasticsearch.action.search
- searchAfter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The sort values that indicates which docs this request should "search after".
- searchAfter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- searchAfter() - Method in class org.elasticsearch.search.internal.SearchContext
- searchAfter(Object[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Set the sort values that indicates which docs this request should "search after".
- searchAfter(Object[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Set the sort values that indicates which docs this request should "search after".
- searchAfter(FieldDoc) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- searchAfter(FieldDoc) - Method in class org.elasticsearch.search.internal.SearchContext
- SearchAfterBuilder - Class in org.elasticsearch.search.searchafter
- SearchAfterBuilder() - Constructor for class org.elasticsearch.search.searchafter.SearchAfterBuilder
- SearchAfterBuilder(StreamInput) - Constructor for class org.elasticsearch.search.searchafter.SearchAfterBuilder
-
Read from a stream.
- SearchAfterSortedDocQuery - Class in org.apache.lucene.queries
-
A
Query
that only matches documents that are greater than the providedFieldDoc
. - SearchAfterSortedDocQuery(Sort, FieldDoc) - Constructor for class org.apache.lucene.queries.SearchAfterSortedDocQuery
- searchAnalyzer() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- searchAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
-
A smart analyzer used for searching that takes into account specific analyzers configured per
FieldMapper
. - searchAnalyzer() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- searchAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService
- searchAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- SearchContext - Class in org.elasticsearch.search.internal
-
This class encapsulates the state needed to execute a search.
- SearchContext() - Constructor for class org.elasticsearch.search.internal.SearchContext
- SearchContext.Lifetime - Enum in org.elasticsearch.search.internal
-
The life time of an object that is used during search execution.
- SearchContextAggregations - Class in org.elasticsearch.search.aggregations
-
The aggregation context that is part of the search context.
- SearchContextAggregations(AggregatorFactories, MultiBucketConsumerService.MultiBucketConsumer) - Constructor for class org.elasticsearch.search.aggregations.SearchContextAggregations
-
Creates a new aggregation context with the parsed aggregator factories
- SearchContextException - Exception in org.elasticsearch.search
- SearchContextException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchContextException
- SearchContextException(SearchContext, String) - Constructor for exception org.elasticsearch.search.SearchContextException
- SearchContextException(SearchContext, String, Throwable) - Constructor for exception org.elasticsearch.search.SearchContextException
- SearchContextHighlight - Class in org.elasticsearch.search.fetch.subphase.highlight
- SearchContextHighlight(Collection<SearchContextHighlight.Field>) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight
- SearchContextHighlight.Field - Class in org.elasticsearch.search.fetch.subphase.highlight
- SearchContextHighlight.FieldOptions - Class in org.elasticsearch.search.fetch.subphase.highlight
- SearchContextMissingException - Exception in org.elasticsearch.search
- SearchContextMissingException(long) - Constructor for exception org.elasticsearch.search.SearchContextMissingException
- SearchContextMissingException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchContextMissingException
- SearchContextSourcePrinter(SearchContext) - Constructor for class org.elasticsearch.search.SearchPhase.SearchContextSourcePrinter
- searcher() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- searcher() - Method in class org.elasticsearch.index.engine.Engine.Searcher
- searcher() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- searcher() - Method in class org.elasticsearch.search.internal.SearchContext
- Searcher(String, IndexSearcher, Closeable) - Constructor for class org.elasticsearch.index.engine.Engine.Searcher
- SearchException - Exception in org.elasticsearch.search
- SearchException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchException
- SearchException(SearchShardTarget, String) - Constructor for exception org.elasticsearch.search.SearchException
- SearchException(SearchShardTarget, String, Throwable) - Constructor for exception org.elasticsearch.search.SearchException
- SearchExecutionStatsCollector - Class in org.elasticsearch.action.search
-
A wrapper of search action listeners (search results) that unwraps the query result to get the piggybacked queue size and service time EWMA, adding those values to the coordinating nodes'
ResponseCollectorService
. - SearchExtBuilder - Class in org.elasticsearch.search
-
Intermediate serializable representation of a search ext section.
- SearchExtBuilder() - Constructor for class org.elasticsearch.search.SearchExtBuilder
- SearchExtensionSpec(String, Writeable.Reader<? extends W>, P) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
Build the spec with a String.
- SearchExtensionSpec(ParseField, Writeable.Reader<? extends W>, P) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
Build the spec with a ParseField.
- SearchExtSpec(String, Writeable.Reader<? extends T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SearchExtSpec
- SearchExtSpec(ParseField, Writeable.Reader<? extends T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SearchExtSpec
- SearchFailure(Throwable) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
-
Build a search failure that doesn't have shard information available.
- SearchFailure(Throwable, String, Integer, String) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- SearchFailure(StreamInput) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
-
Read from a stream.
- SearchHit - Class in org.elasticsearch.search
-
A single search hit.
- SearchHit(int) - Constructor for class org.elasticsearch.search.SearchHit
- SearchHit(int, String, Text, Map<String, DocumentField>) - Constructor for class org.elasticsearch.search.SearchHit
- SearchHit(int, String, Text, SearchHit.NestedIdentity, Map<String, DocumentField>) - Constructor for class org.elasticsearch.search.SearchHit
- SearchHit.Fields - Class in org.elasticsearch.search
- SearchHit.NestedIdentity - Class in org.elasticsearch.search
-
Encapsulates the nested identity of a hit.
- SearchHits - Class in org.elasticsearch.search
- SearchHits(SearchHit[], long, float) - Constructor for class org.elasticsearch.search.SearchHits
- SearchHits(SearchHit[], long, float, SortField[], String, Object[]) - Constructor for class org.elasticsearch.search.SearchHits
- SearchHits.Fields - Class in org.elasticsearch.search
- SearchLookup - Class in org.elasticsearch.search.lookup
- SearchLookup(MapperService, Function<MappedFieldType, IndexFieldData<?>>, String[]) - Constructor for class org.elasticsearch.search.lookup.SearchLookup
- SearchModule - Class in org.elasticsearch.search
-
Sets up things that can be done at search time like queries, aggregations, and suggesters.
- SearchModule(Settings, boolean, List<SearchPlugin>) - Constructor for class org.elasticsearch.search.SearchModule
-
Constructs a new SearchModule object NOTE: This constructor should not be called in production unless an accurate
Settings
object is provided. - SearchOperationListener - Interface in org.elasticsearch.index.shard
-
An listener for search, fetch and context events.
- SearchOperationListener.CompositeListener - Class in org.elasticsearch.index.shard
-
A Composite listener that multiplexes calls to each of the listeners methods.
- SearchParseException - Exception in org.elasticsearch.search
- SearchParseException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchParseException
- SearchParseException(SearchContext, String, XContentLocation) - Constructor for exception org.elasticsearch.search.SearchParseException
- SearchParseException(SearchContext, String, XContentLocation, Throwable) - Constructor for exception org.elasticsearch.search.SearchParseException
- SearchPhase - Interface in org.elasticsearch.search
-
Represents a phase of a search request e.g.
- SearchPhase.SearchContextSourcePrinter - Class in org.elasticsearch.search
- SearchPhaseController - Class in org.elasticsearch.action.search
- SearchPhaseController(Function<Boolean, InternalAggregation.ReduceContext>) - Constructor for class org.elasticsearch.action.search.SearchPhaseController
-
Constructor.
- SearchPhaseController.ReducedQueryPhase - Class in org.elasticsearch.action.search
- SearchPhaseExecutionException - Exception in org.elasticsearch.action.search
- SearchPhaseExecutionException(String, String, Throwable, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
- SearchPhaseExecutionException(String, String, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
- SearchPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
- SearchPhaseResult - Class in org.elasticsearch.search
-
This class is a base class for all search related results.
- SearchPhaseResult() - Constructor for class org.elasticsearch.search.SearchPhaseResult
- SearchPlugin - Interface in org.elasticsearch.plugins
-
Plugin for extending search time behavior.
- SearchPlugin.AggregationSpec - Class in org.elasticsearch.plugins
-
Specification for an
Aggregation
. - SearchPlugin.FetchPhaseConstructionContext - Class in org.elasticsearch.plugins
-
Context available during fetch phase construction.
- SearchPlugin.PipelineAggregationSpec - Class in org.elasticsearch.plugins
-
Specification for a
PipelineAggregator
. - SearchPlugin.QuerySpec<T extends QueryBuilder> - Class in org.elasticsearch.plugins
-
Specification of custom
Query
. - SearchPlugin.RescorerSpec<T extends RescorerBuilder<T>> - Class in org.elasticsearch.plugins
- SearchPlugin.ScoreFunctionSpec<T extends ScoreFunctionBuilder<T>> - Class in org.elasticsearch.plugins
-
Specification of custom
ScoreFunction
. - SearchPlugin.SearchExtensionSpec<W extends NamedWriteable,P> - Class in org.elasticsearch.plugins
-
Specification of search time behavior extension like a custom
MovAvgModel
orScoreFunction
. - SearchPlugin.SearchExtSpec<T extends SearchExtBuilder> - Class in org.elasticsearch.plugins
-
Specification for a
SearchExtBuilder
which represents an additional section that can be parsed in a search request (within the ext element). - SearchPlugin.SuggesterSpec<T extends SuggestionBuilder<T>> - Class in org.elasticsearch.plugins
-
Specification for a
Suggester
. - SearchProfileShardResults - Class in org.elasticsearch.search.profile
-
A container class to hold all the profile results across all shards.
- SearchProfileShardResults(Map<String, ProfileShardResult>) - Constructor for class org.elasticsearch.search.profile.SearchProfileShardResults
- SearchProfileShardResults(StreamInput) - Constructor for class org.elasticsearch.search.profile.SearchProfileShardResults
- searchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
- searchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- searchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService
- searchQuoteAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- searchRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a search request against one or more indices.
- SearchRequest - Class in org.elasticsearch.action.search
-
A request to execute search against one or more indices (or all).
- SearchRequest() - Constructor for class org.elasticsearch.action.search.SearchRequest
- SearchRequest(String...) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request against the indices.
- SearchRequest(String[], SearchSourceBuilder) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request against the provided indices with the given search source.
- SearchRequest(SearchRequest) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request from the provided search request
- SearchRequestBuilder - Class in org.elasticsearch.action.search
-
A search action request builder.
- SearchRequestBuilder(ElasticsearchClient, SearchAction) - Constructor for class org.elasticsearch.action.search.SearchRequestBuilder
- SearchResponse - Class in org.elasticsearch.action.search
-
A response of a search request.
- SearchResponse() - Constructor for class org.elasticsearch.action.search.SearchResponse
- SearchResponse(SearchResponseSections, String, int, int, int, long, ShardSearchFailure[], SearchResponse.Clusters) - Constructor for class org.elasticsearch.action.search.SearchResponse
- SearchResponse.Clusters - Class in org.elasticsearch.action.search
-
Holds info about the clusters that the search was executed on: how many in total, how many of them were successful and how many of them were skipped.
- SearchResponseSections - Class in org.elasticsearch.action.search
-
Base class that holds the various sections which a search response is composed of (hits, aggs, suggestions etc.) and allows to retrieve them.
- SearchResponseSections(SearchHits, Aggregations, Suggest, boolean, Boolean, SearchProfileShardResults, int) - Constructor for class org.elasticsearch.action.search.SearchResponseSections
- searchRouting() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the search routing value associated with the alias
- searchRouting() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- searchRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- searchRouting(String) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates a search routing value to the alias
- searchRouting(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- searchRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- searchRoutingValues() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- SearchScript - Class in org.elasticsearch.script
-
A generic script used for per document use cases.
- SearchScript(Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.SearchScript
- SearchScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
SearchScript
factories for a specific index. - SearchScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
SearchScript
instances. - searchScroll(SearchScrollRequest) - Method in interface org.elasticsearch.client.Client
-
A search scroll request to continue searching a previous scrollable search request.
- searchScroll(SearchScrollRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- searchScroll(SearchScrollRequest, ActionListener<SearchResponse>) - Method in interface org.elasticsearch.client.Client
-
A search scroll request to continue searching a previous scrollable search request.
- searchScroll(SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- SearchScrollAction - Class in org.elasticsearch.action.search
- searchScrollRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a search scroll request allowing to continue searching a previous search request.
- SearchScrollRequest - Class in org.elasticsearch.action.search
- SearchScrollRequest() - Constructor for class org.elasticsearch.action.search.SearchScrollRequest
- SearchScrollRequest(String) - Constructor for class org.elasticsearch.action.search.SearchScrollRequest
- SearchScrollRequestBuilder - Class in org.elasticsearch.action.search
-
A search scroll action request builder.
- SearchScrollRequestBuilder(ElasticsearchClient, SearchScrollAction) - Constructor for class org.elasticsearch.action.search.SearchScrollRequestBuilder
- SearchScrollRequestBuilder(ElasticsearchClient, SearchScrollAction, String) - Constructor for class org.elasticsearch.action.search.SearchScrollRequestBuilder
- SearchService - Class in org.elasticsearch.search
- SearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase, ResponseCollectorService) - Constructor for class org.elasticsearch.search.SearchService
- SearchService.CanMatchResponse - Class in org.elasticsearch.search
- SearchShardIterator - Class in org.elasticsearch.action.search
-
Extension of
PlainShardIterator
used in the search api, which also holds theOriginalIndices
of the search request (useful especially with cross-cluster search, as each cluster has its own set of original indices) as well as the cluster alias. - SearchShardIterator(String, ShardId, List<ShardRouting>, OriginalIndices) - Constructor for class org.elasticsearch.action.search.SearchShardIterator
-
Creates a
PlainShardIterator
instance that iterates over a subset of the given shards this the a givenshardId
. - searchShards(ClusterSearchShardsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns list of shards the given search would be executed on.
- searchShards(ClusterSearchShardsRequest, ActionListener<ClusterSearchShardsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns list of shards the given search would be executed on.
- searchShards(ClusterState, String[], Map<String, Set<String>>, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- searchShards(ClusterState, String[], Map<String, Set<String>>, String, ResponseCollectorService, Map<String, Long>) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- SearchShardTarget - Class in org.elasticsearch.search
-
The target that the search request was executed on.
- SearchShardTarget(String, Index, int, String) - Constructor for class org.elasticsearch.search.SearchShardTarget
- SearchShardTarget(String, ShardId, String, OriginalIndices) - Constructor for class org.elasticsearch.search.SearchShardTarget
- SearchShardTarget(StreamInput) - Constructor for class org.elasticsearch.search.SearchShardTarget
- SearchSlowLog - Class in org.elasticsearch.index
- SearchSlowLog(IndexSettings) - Constructor for class org.elasticsearch.index.SearchSlowLog
- SearchSortValues - Class in org.elasticsearch.search
- SearchSortValues(Object[], DocValueFormat[]) - Constructor for class org.elasticsearch.search.SearchSortValues
- searchSource() - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
A static factory method to construct a new search source.
- SearchSourceBuilder - Class in org.elasticsearch.search.builder
-
A search source builder allowing to easily build search source.
- SearchSourceBuilder() - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder
-
Constructs a new search source builder.
- SearchSourceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder
-
Read from a stream.
- SearchSourceBuilder.IndexBoost - Class in org.elasticsearch.search.builder
- SearchSourceBuilder.ScriptField - Class in org.elasticsearch.search.builder
- SearchSourceBuilderException - Exception in org.elasticsearch.search.builder
- SearchSourceBuilderException(String) - Constructor for exception org.elasticsearch.search.builder.SearchSourceBuilderException
- SearchSourceBuilderException(String, Throwable) - Constructor for exception org.elasticsearch.search.builder.SearchSourceBuilderException
- SearchSourceBuilderException(StreamInput) - Constructor for exception org.elasticsearch.search.builder.SearchSourceBuilderException
- searchStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
- SearchStats - Class in org.elasticsearch.index.search.stats
- SearchStats() - Constructor for class org.elasticsearch.index.search.stats.SearchStats
- SearchStats(StreamInput) - Constructor for class org.elasticsearch.index.search.stats.SearchStats
- SearchStats(SearchStats.Stats, long, Map<String, SearchStats.Stats>) - Constructor for class org.elasticsearch.index.search.stats.SearchStats
- SearchStats.Stats - Class in org.elasticsearch.index.search.stats
- SearchTask - Class in org.elasticsearch.action.search
-
Task storing information about a currently running search request.
- SearchTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.action.search.SearchTask
- searchThreadPoolSize(int) - Static method in class org.elasticsearch.threadpool.ThreadPool
- searchTimedOut() - Method in class org.elasticsearch.search.query.QuerySearchResult
- searchTimedOut(boolean) - Method in class org.elasticsearch.search.query.QuerySearchResult
- searchToString(StringBuilder) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Append a short description of the search request to a StringBuilder.
- searchToString(StringBuilder) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
- SearchTransportService - Class in org.elasticsearch.action.search
-
An encapsulation of
SearchService
operations exposed through transport. - SearchTransportService(TransportService, BiFunction<Transport.Connection, SearchActionListener, ActionListener>) - Constructor for class org.elasticsearch.action.search.SearchTransportService
- SearchTransportService.SearchFreeContextResponse - Class in org.elasticsearch.action.search
- searchType() - Method in class org.elasticsearch.action.search.SearchRequest
-
The tye of search to execute.
- searchType() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- searchType() - Method in class org.elasticsearch.search.internal.SearchContext
- searchType() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- searchType() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- searchType() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- searchType(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
The a string representation search type to execute, defaults to
SearchType.DEFAULT
. - searchType(SearchType) - Method in class org.elasticsearch.action.search.SearchRequest
-
The search type to execute, defaults to
SearchType.DEFAULT
. - searchType(SearchType) - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- SearchType - Enum in org.elasticsearch.action.search
-
Search type represent the manner at which the search operation is executed.
- seasonalityType(HoltWintersModel.SeasonalityType) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
- SECOND - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- SECOND_OF_MINUTE - org.elasticsearch.common.rounding.DateTimeUnit
- seconds(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- SECRET_PROMPT_VALUE - Static variable in class org.elasticsearch.node.InternalSettingsPreparer
- secureFile(String, Setting<InputStream>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.SecureSetting
-
A setting which contains a file.
- SecureSetting<T> - Class in org.elasticsearch.common.settings
-
A secure setting.
- SecureSettings - Interface in org.elasticsearch.common.settings
-
An accessor for settings which are securely stored.
- secureString(String, Setting<SecureString>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.SecureSetting
-
A setting which contains a sensitive string.
- SecureString - Class in org.elasticsearch.common.settings
-
A String implementations which allows clearing the underlying char array.
- SecureString(char[]) - Constructor for class org.elasticsearch.common.settings.SecureString
-
Constructs a new SecureString which controls the passed in char array.
- SecureString(String) - Constructor for class org.elasticsearch.common.settings.SecureString
-
Deprecated.Only use for compatibility between deprecated string settings and new secure strings
- SECURITY_FILTER_BAD_DEFAULTS_SETTING - Static variable in class org.elasticsearch.bootstrap.BootstrapSettings
- SEE_OTHER - org.elasticsearch.rest.RestStatus
-
The response to the request can be found under a different URI and SHOULD be retrieved using a GET method on that resource.
- seed(int) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
Sets the seed based on which the random number will be generated.
- seed(long) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
seed variant taking a long value.
- seed(String) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
seed variant taking a String value.
- SEED - Static variable in class org.elasticsearch.search.slice.TermsSliceQuery
- SEED_SETTING - Static variable in class org.elasticsearch.common.settings.KeyStoreWrapper
- seek(long) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- seek(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- seek(long) - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- seekCeil(BytesRef) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- seekExact(long) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- seekExact(BytesRef) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- seekExact(BytesRef) - Method in class org.elasticsearch.common.lucene.index.FreqTermsEnum
- Segment - Class in org.elasticsearch.index.engine
- Segment(String) - Constructor for class org.elasticsearch.index.engine.Segment
- segmentReader(LeafReader) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Tries to extract a segment reader from the given index reader.
- segments - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- segments() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- segments(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- segments(boolean) - Method in class org.elasticsearch.index.engine.Engine
-
The list of segments in the engine.
- segments(boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- segments(boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- segments(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- segments(IndicesSegmentsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The segments of one or more indices.
- segments(IndicesSegmentsRequest, ActionListener<IndicesSegmentResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The segments of one or more indices.
- Segments - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- segmentSort - Variable in class org.elasticsearch.index.engine.Segment
- segmentsStats(boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Global stats on segments.
- SegmentsStats - Class in org.elasticsearch.index.engine
- SegmentsStats() - Constructor for class org.elasticsearch.index.engine.SegmentsStats
- segmentStats(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- select(SortedNumericDocValues) - Method in enum org.elasticsearch.search.MultiValueMode
-
Return a
NumericDocValues
instance that can be used to sort documents with this mode and the provided values. - select(SortedNumericDocValues, long, BitSet, DocIdSetIterator, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
Return a
NumericDocValues
instance that can be used to sort root documents with this mode, the provided values and filters for root/inner documents. - select(SortedSetDocValues) - Method in enum org.elasticsearch.search.MultiValueMode
-
Return a
SortedDocValues
instance that can be used to sort documents with this mode and the provided values. - select(SortedSetDocValues, BitSet, DocIdSetIterator, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
Return a
SortedDocValues
instance that can be used to sort root documents with this mode, the provided values and filters for root/inner documents. - select(SortedBinaryDocValues, BytesRef) - Method in enum org.elasticsearch.search.MultiValueMode
-
Return a
BinaryDocValues
instance that can be used to sort documents with this mode and the provided values. - select(SortedBinaryDocValues, BytesRef, BitSet, DocIdSetIterator, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
Return a
BinaryDocValues
instance that can be used to sort root documents with this mode, the provided values and filters for root/inner documents. - select(SortedNumericDoubleValues) - Method in enum org.elasticsearch.search.MultiValueMode
-
Return a
NumericDoubleValues
instance that can be used to sort documents with this mode and the provided values. - select(SortedNumericDoubleValues, double, BitSet, DocIdSetIterator, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
Return a
NumericDoubleValues
instance that can be used to sort root documents with this mode, the provided values and filters for root/inner documents. - selectBestTerms() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- selectedFields() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return only term vectors for special selected fields.
- selectedFields(String...) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return only term vectors for special selected fields.
- selectLeastLoadedNode(ClusterState, Predicate<DiscoveryNode>) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Finds the least loaded node that satisfies the selector criteria
- selectNewPathForShard(NodeEnvironment, ShardId, IndexSettings, long, Map<Path, Integer>) - Static method in class org.elasticsearch.index.shard.ShardPath
- selectRecoverFromShards(int, IndexMetaData, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Selects the source shards for a local shard recovery.
- selectShrinkShards(int, IndexMetaData, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Returns the source shard ids to shrink into the given shard id.
- selectSplitShard(int, IndexMetaData, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Returns the source shard ID to split the given target shard off
- self() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
`this` cast to Self.
- self() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
- self() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- self() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- self() - Method in class org.elasticsearch.index.reindex.ReindexRequest
- self() - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
- self() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- self() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- SEND_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- SEND_LEAVE_REQUEST_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- sendBufferSize - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- sendCanMatch(Transport.Connection, ShardSearchTransportRequest, SearchTask, ActionListener<SearchService.CanMatchResponse>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendChildRequest(DiscoveryNode, String, TransportRequest, Task, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendChildRequest(Transport.Connection, String, TransportRequest, Task, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendChildRequest(Transport.Connection, String, TransportRequest, Task, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendClearAllScrollContexts(Transport.Connection, ActionListener<TransportResponse>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendCompletionRequest(String, long, Exception, ActionListener<PersistentTasksCustomMetaData.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Notifies the master node about the completion of a persistent task.
- sendErrorResponse(Version, Set<String>, TcpChannel, Exception, long, String) - Method in class org.elasticsearch.transport.TcpTransport
-
Sends back an error response to the caller via the given channel
- sendExecuteDfs(Transport.Connection, ShardSearchTransportRequest, SearchTask, SearchActionListener<DfsSearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteFetch(Transport.Connection, ShardFetchSearchRequest, SearchTask, SearchActionListener<FetchSearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteFetchScroll(Transport.Connection, ShardFetchRequest, SearchTask, SearchActionListener<FetchSearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteQuery(Transport.Connection, ShardSearchTransportRequest, SearchTask, SearchActionListener<SearchPhaseResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteQuery(Transport.Connection, QuerySearchRequest, SearchTask, SearchActionListener<QuerySearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteScrollFetch(Transport.Connection, InternalScrollSearchRequest, SearchTask, SearchActionListener<ScrollQueryFetchSearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteScrollQuery(Transport.Connection, InternalScrollSearchRequest, SearchTask, SearchActionListener<ScrollQuerySearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendFreeContext(Transport.Connection, long, ActionListener<SearchTransportService.SearchFreeContextResponse>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendFreeContext(Transport.Connection, long, OriginalIndices) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendJoinRequestBlocking(DiscoveryNode, DiscoveryNode, TimeValue) - Method in class org.elasticsearch.discovery.zen.MembershipAction
- sendLeaveRequest(DiscoveryNode, DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.MembershipAction
- sendLeaveRequestBlocking(DiscoveryNode, DiscoveryNode, TimeValue) - Method in class org.elasticsearch.discovery.zen.MembershipAction
- sendMessage(BytesReference, ActionListener<Void>) - Method in interface org.elasticsearch.transport.TcpChannel
-
Sends a tcp message to the channel.
- sendPings(TimeValue, UnicastZenPing.PingingRound) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- sendRemoveRequest(String, ActionListener<PersistentTasksCustomMetaData.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Notifies the master node to remove a persistent task from the cluster state
- sendReplicaRequest(TransportReplicationAction.ConcreteReplicaRequest<ResyncReplicationRequest>, DiscoveryNode, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- sendReplicaRequest(TransportReplicationAction.ConcreteReplicaRequest<GlobalCheckpointSyncAction.Request>, DiscoveryNode, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- sendReplicaRequest(TransportReplicationAction.ConcreteReplicaRequest<RetentionLeaseBackgroundSyncAction.Request>, DiscoveryNode, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- sendReplicaRequest(TransportReplicationAction.ConcreteReplicaRequest<RetentionLeaseSyncAction.Request>, DiscoveryNode, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- sendReplicaRequest(TransportReplicationAction.ConcreteReplicaRequest<ReplicaRequest>, DiscoveryNode, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Sends the specified replica request to the specified node.
- sendRequest(long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- sendRequest(long, String, TransportRequest, TransportRequestOptions) - Method in interface org.elasticsearch.transport.Transport.Connection
-
Sends the request to the node this connection is associated with
- sendRequest(DiscoveryNode, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendRequest(DiscoveryNode, String, TransportRequest, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendRequest(Transport.Connection, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in interface org.elasticsearch.transport.TransportInterceptor.AsyncSender
- sendRequest(Transport.Connection, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- SendRequestTransportException - Exception in org.elasticsearch.transport
- SendRequestTransportException(DiscoveryNode, String, Throwable) - Constructor for exception org.elasticsearch.transport.SendRequestTransportException
- SendRequestTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.SendRequestTransportException
- sendResponse(Exception) - Method in class org.elasticsearch.transport.TaskTransportChannel
- sendResponse(Exception) - Method in class org.elasticsearch.transport.TcpTransportChannel
- sendResponse(Exception) - Method in interface org.elasticsearch.transport.TransportChannel
- sendResponse(RestResponse) - Method in interface org.elasticsearch.rest.RestChannel
- sendResponse(TransportResponse) - Method in class org.elasticsearch.transport.TaskTransportChannel
- sendResponse(TransportResponse) - Method in class org.elasticsearch.transport.TcpTransportChannel
- sendResponse(TransportResponse) - Method in interface org.elasticsearch.transport.TransportChannel
- sendResponse(Version, Set<String>, TcpChannel, TransportResponse, long, String, boolean) - Method in class org.elasticsearch.transport.TcpTransport
-
Sends the response to the given channel.
- sendStartRequest(String, String, Params, ActionListener<PersistentTasksCustomMetaData.PersistentTask<Params>>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Notifies the master node to create new persistent task and to assign it to a node.
- sendValidateJoinRequestBlocking(DiscoveryNode, ClusterState, TimeValue) - Method in class org.elasticsearch.discovery.zen.MembershipAction
-
Validates the join request, throwing a failure if it failed.
- SENTENCE - org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- SEP_LABEL - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Represents the separation between tokens, if PRESERVE_SEP was specified
- separator - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- separator() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Get the separator used to join pairs of bucket keys
- separator() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the separator that is used to separate terms in the bigram field.
- separator(String) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Set the separator used to join pairs of bucket keys
- separator(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the separator that is used to separate terms in the bigram field.
- SEPARATOR_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- SEQ_NO_PRIMARY_TERM_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- seqID() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- seqID() - Method in class org.elasticsearch.index.mapper.ParseContext
- seqID(SeqNoFieldMapper.SequenceIDFields) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- seqID(SeqNoFieldMapper.SequenceIDFields) - Method in class org.elasticsearch.index.mapper.ParseContext
- seqNo - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- seqNo - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndSeqNo
- seqNo - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- seqNo - Variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- seqNo() - Method in class org.elasticsearch.index.engine.Engine.Operation
- seqNo() - Method in class org.elasticsearch.index.translog.Translog.Delete
- seqNo() - Method in class org.elasticsearch.index.translog.Translog.Index
- seqNo() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- seqNo() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Indicates whether
SearchHit
s should be returned with the sequence number and primary term of the last modification of the document. - seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates whether
SearchHit
s should be returned with the sequence number and primary term of the last modification of the document. - seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.internal.SearchContext
-
indicates whether the sequence number and primary term of the last modification to each hit should be returned
- seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.internal.SubSearchContext
- seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should each
SearchHit
be returned with the sequence number and primary term of the last modification of the document. - seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
-
controls whether the sequence number and primary term of the last modification to each hit should be returned
- seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
- seqNoAndPrimaryTerm(Boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Should each
SearchHit
be returned with the sequence number and primary term of the last modification of the document. - seqNoAndPrimaryTerm(Boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should each
SearchHit
be returned with the sequence number and primary term of the last modification of the document. - SeqNoDefaults() - Constructor for class org.elasticsearch.index.mapper.SeqNoFieldMapper.SeqNoDefaults
- seqNoDocValue - Variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- SeqNoFieldMapper - Class in org.elasticsearch.index.mapper
-
Mapper for the
_seq_no
field. - SeqNoFieldMapper(Settings) - Constructor for class org.elasticsearch.index.mapper.SeqNoFieldMapper
- SeqNoFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- SeqNoFieldMapper.SeqNoDefaults - Class in org.elasticsearch.index.mapper
- SeqNoFieldMapper.SequenceIDFields - Class in org.elasticsearch.index.mapper
-
A sequence ID, which is made up of a sequence number (both the searchable and doc_value version of the field) and the primary term.
- SeqNoFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- SeqNoPrimaryTermFetchSubPhase - Class in org.elasticsearch.search.fetch.subphase
- SeqNoPrimaryTermFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.SeqNoPrimaryTermFetchSubPhase
- seqNoStats() - Method in class org.elasticsearch.index.shard.IndexShard
- SeqNoStats - Class in org.elasticsearch.index.seqno
- SeqNoStats(long, long, long) - Constructor for class org.elasticsearch.index.seqno.SeqNoStats
- SeqNoStats(StreamInput) - Constructor for class org.elasticsearch.index.seqno.SeqNoStats
- SequenceIDFields(Field, Field, Field, Field) - Constructor for class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- SequenceNumbers - Class in org.elasticsearch.index.seqno
-
A utility class for handling sequence numbers.
- SequenceNumbers() - Constructor for class org.elasticsearch.index.seqno.SequenceNumbers
- SequenceNumbers.CommitInfo - Class in org.elasticsearch.index.seqno
- SerialDiffPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.serialdiff
- SerialDiffPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
- SerialDiffPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregationBuilder
-
Read from a stream.
- SerialDiffPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.serialdiff
- SerialDiffPipelineAggregator(String, String[], DocValueFormat, BucketHelpers.GapPolicy, int, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
- SerialDiffPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
-
Read from a stream.
- SERIALIZATION_FORMAT - Static variable in class org.elasticsearch.index.translog.Translog.Delete
- SERIALIZATION_FORMAT - Static variable in class org.elasticsearch.index.translog.Translog.Index
- serializeDiffClusterState(Diff, Version) - Static method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- serializeFullClusterState(ClusterState, Version) - Static method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- serializeTargetValueType() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- serializeTargetValueType() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- serializeTargetValueType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- serializeTargetValueType() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- serializeTargetValueType() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- serializeTargetValueType() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Should this builder serialize its targetValueType? Defaults to false.
- serializeTargetValueType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Should this builder serialize its targetValueType? Defaults to false.
- serverAcceptedChannel(TcpChannel) - Method in class org.elasticsearch.transport.TcpTransport
- serverOpen() - Method in class org.elasticsearch.transport.TransportStats
- SERVICE_UNAVAILABLE - org.elasticsearch.rest.RestStatus
-
The server is currently unable to handle the request due to a temporary overloading or maintenance of the server.
- serviceTime - Variable in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- serviceTimeEWMA() - Method in class org.elasticsearch.search.query.QuerySearchResult
- serviceTimeEWMA(long) - Method in class org.elasticsearch.search.query.QuerySearchResult
- set(int) - Method in class org.elasticsearch.common.util.BitArray
- set(int) - Method in class org.elasticsearch.index.seqno.CountedBitSet
- set(int, E) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Sets the element at position
i
to the given value. - set(int, T) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- set(long, byte) - Method in interface org.elasticsearch.common.util.ByteArray
-
Set a value at the given index and return the previous value.
- set(long, byte[], int, int) - Method in interface org.elasticsearch.common.util.ByteArray
-
Bulk set.
- set(long, double) - Method in interface org.elasticsearch.common.util.DoubleArray
-
Set a value at the given index and return the previous value.
- set(long, float) - Method in interface org.elasticsearch.common.util.FloatArray
-
Set a value at the given index and return the previous value.
- set(long, int) - Method in interface org.elasticsearch.common.util.IntArray
-
Set a value at the given index and return the previous value.
- set(long, long) - Method in interface org.elasticsearch.common.util.LongArray
-
Set a value at the given index and return the previous value.
- set(long, T) - Method in interface org.elasticsearch.common.util.ObjectArray
-
Set a value at the given index and return the previous value.
- set(CommonStatsFlags.Flag, boolean) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- set(V) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Subclasses should invoke this method to set the result of the computation to
value
. - setAbortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set whether or not version conflicts cause the action to abort.
- setAcceptDataLoss(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand.Builder
- setAction(String) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.RequestBuilder
- setActions(String...) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
Sets the list of action masks for the actions that should be returned
- setActions(String...) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
- setActiveOnly(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequestBuilder
- setActivityTimeout(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setAdaptiveSelection(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
- setAggregatedDfs(AggregatedDfs) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- setAggregations(Aggregations) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- setAlias(String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Sets the alias to rollover to another index
- setAlias(String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- setAliases(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- setAliases(Map) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(Map) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(BytesReference) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(BytesReference) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliasFilter(AliasFilter) - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- setAliasFilter(AliasFilter) - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- setAliasFilter(AliasFilter) - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- setAllocationId(long) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- setAllowPartialSearchResults(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets if this request should allow partial results.
- setAllowUnmappedFields(boolean) - Method in class org.elasticsearch.index.query.QueryShardContext
- setAllShards(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
Indicates whether the query should be validated on all shards
- setAnalyzer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets the analyzer name to use in order to analyze the text.
- setAnalyzer(String) - Method in class org.elasticsearch.index.search.MatchQuery
- setAnalyzer(Analyzer) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setAnalyzer(Analyzer) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the analyzer to use.
- setAnalyzer(Analyzer) - Method in class org.elasticsearch.index.search.MatchQuery
- setAnalyzer(Analyzer) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setAnalyzeWildcard(boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setAndGetObservedState() - Method in class org.elasticsearch.cluster.ClusterStateObserver
-
sets the last observed state to the currently applied cluster state and returns it
- setArtificial(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setAttributes(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets attributes that will include results
- setAutoGenerateMultiTermSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setAutoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.search.MatchQuery
- setBackoffPolicy(BackoffPolicy) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets a custom backoff policy.
- setBan(TaskId, String) - Method in class org.elasticsearch.tasks.TaskManager
-
Bans all tasks with the specified parent task from execution, cancels all tasks that are currently executing.
- setBatchedReduceSize(int) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the number of shard results that should be reduced at once on the coordinating node.
- setBatchedReduceSize(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the number of shard results that should be reduced at once on the coordinating node.
- setBatches(Integer) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setBatchSize(int) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
The scroll size to control number of documents processed per batch
- setBatchSize(int) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
The scroll size to control number of documents processed per batch
- setBinding(BindingImpl<T>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- setBlocks(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
- setBoost(boolean) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets whether to boost terms in query based on "score" or not.
- setBoost(float) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setBoost(int) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
-
Sets the query-time boost of the context.
- setBoost(int) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
-
Sets the query-time boost for the context Defaults to 1
- setBoostFactor(float) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the boost factor to use when boosting terms
- setBoostTerms(boolean) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setBoostTermsFactor(float) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setBreaker(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
- setBulkActions(int) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets when to flush a new bulk request based on the number of actions currently added.
- setBulkRetries(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setBulkSize(ByteSizeValue) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets when to flush a new bulk request based on the size of actions currently added.
- setCategory(String) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
-
Sets the category of the category.
- setCause(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The cause for this index creation.
- setCheckCancelled(Runnable) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
Set a
Runnable
that will be run on a regular basis while collecting documents. - setChildInnerHits(Map<String, InnerHitsContext.InnerHitSubContext>) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- setChunkSize(ByteSizeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setClient(Client) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
- setClusterStatePublisher(BiConsumer<ClusterChangedEvent, Discovery.AckListener>) - Method in class org.elasticsearch.cluster.service.MasterService
- setClusterStateSupplier(Supplier<ClusterState>) - Method in class org.elasticsearch.cluster.service.MasterService
- setCollapse(CollapseBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
- setCollector(InternalProfileCollector) - Method in class org.elasticsearch.search.profile.query.QueryProfiler
-
Set the collector that is associated with this profiler.
- setCommonTermsCutoff(Float) - Method in class org.elasticsearch.index.search.MatchQuery
- setCompletion(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setCompletionFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setCompress(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- setCompressionEnabled(boolean) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets compression enabled for this connection profile
- setConcreteIndex(Index) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Sets a concrete index for this put mapping request.
- setConcreteIndex(Index) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
- setConcreteNodes(DiscoveryNode[]) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- setConcurrentRequests(int) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets the number of concurrent requests allowed to be executed.
- setConflicts(String) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Sets abortOnVersionConflict based on REST-friendly names.
- setConnectTimeout(TimeValue) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets a connect timeout for this connection profile
- setContent(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequestBuilder
-
Set the source of the script along with the content type of the source
- setContextMappings(ContextMappings) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- setCopySettings(Boolean) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- setCorners(double, double, double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds top left point.
- setCorners(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds points from a single geohash.
- setCorners(String, String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds points.
- setCorners(GeoPoint, GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds points.
- setCornersOGC(String, String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds corners in OGC standard bbox/ envelop format.
- setCornersOGC(GeoPoint, GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds corners in OGC standard bbox/ envelop format.
- setCreate(boolean) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Set to
true
to force only creation, not an update of an index template. - setCreate(boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Set to
true
to force this index to useDocWriteRequest.OpType.CREATE
. - setCreated(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setCurrentNode(String) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Requests the explain API to explain an already assigned replica shard currently allocated to the given node.
- setCurrentNode(String) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Requests the explain API to explain an already assigned replica shard currently allocated to the given node.
- setCurrentReference(T) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- setCurrentRefreshLocationSupplier(Supplier<Translog.Location>) - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Setup the translog used to find the last refreshed location.
- setCurrentSnapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Makes the request to return the current snapshot
- setCustoms(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Should the cluster state result include the
ClusterState.Custom
. - setDateTimeFormatter(DateFormatter) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- setDateTimeFormatter(DateFormatter) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- setDebugMode(RoutingAllocation.DebugMode) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- setDefaultDistanceErrorPct(double) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- setDefaultOperator(QueryParser.Operator) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setDefaultOperator(BooleanClause.Occur) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- setDefaultPipeline(String) - Method in class org.elasticsearch.index.IndexSettings
- setDeferredCollector(Iterable<BucketCollector>) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Set the deferred collectors.
- setDeferredCollector(Iterable<BucketCollector>) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
Set the deferred collectors.
- setDeferredCollector(Iterable<BucketCollector>) - Method in class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
- setDeferredCollector(Iterable<BucketCollector>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
-
Set the deferred collectors.
- setDeleted(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setDependency(Dependency) - Method in class org.elasticsearch.common.inject.internal.InternalContext
- setDestDocType(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the document type for the destination index
- setDestIndex(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the target index for the ReindexRequest
- setDestOpType(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Sets the optype on the destination index
- setDestPipeline(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Allows to set the ingest pipeline for the target index.
- setDestRouting(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the routing to decide which shard the documents need to be routed to
- setDestVersionType(VersionType) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the version type for the target index.
- setDetailed(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Should the detailed task information be returned.
- setDetailed(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequestBuilder
-
Should detailed task information be returned.
- setDetailed(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequestBuilder
- setDetectNoop(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets whether to perform extra effort to detect noop updates via docAsUpsert.
- setDiscovery(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the discovery stats be returned.
- setDistanceErrorPct(double) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- setDistanceErrorPct(double) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- setDoc(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(byte[], XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(Object...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified, the doc provided is a field and value pairs.
- setDoc(String, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(Map) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(Map, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(XContentBuilder) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the artificial document from which to generate term vectors.
- setDoc(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(XContentType, Object...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified, the doc provided is a field and value pairs.
- setDocAsUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets whether the specified doc parameter should be used as upsert document.
- setDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- setDocCount(long) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- setDocs(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setDocTypes(String...) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Set the document types for the delete
- setDocTypes(String...) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set the document types for the update
- setDocument(int) - Method in class org.elasticsearch.script.FilterScript
-
Set the current document to run the script on next.
- setDocument(int) - Method in class org.elasticsearch.script.ScoreScript
-
Set the current document to run the script on next.
- setDocument(int) - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- setDocument(int) - Method in class org.elasticsearch.script.SearchScript
-
Set the current document to run the script on next.
- setDocument(int) - Method in class org.elasticsearch.script.TermsSetQueryScript
-
Set the current document to run the script on next.
- setDocument(int) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- setDocument(int) - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
- setDocument(int) - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- setDocValueFields(List<DocValueFieldsContext.FieldAndFormat>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Sets the stored fields to load from the docvalue and return.
- setDocVersion(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setDryRun(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Sets a dry run flag (defaults to
false
) allowing to run the commands without actually applying them to the cluster state, and getting the resulting cluster state back. - setEagerGlobalOrdinals(boolean) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setEnableAssignment(EnableAssignmentDecider.Allocation) - Method in class org.elasticsearch.persistent.decider.EnableAssignmentDecider
- setEnabled(boolean) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- setEnableGcDeletes(boolean) - Method in class org.elasticsearch.index.engine.EngineConfig
-
Enables / disables gc deletes
- setEnablePositionIncrements(boolean) - Method in class org.elasticsearch.index.search.MatchQuery
- setError(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- setException(Throwable) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Subclasses should invoke this method to set the result of the computation to an error,
throwable
. - setExists(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setExpandWildcardsClosed(boolean) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
-
Controls whether wildcard expressions will be expanded to existing closed indices
- setExpandWildcardsOpen(boolean) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
-
Controls whether wildcard expressions will be expanded to existing open indices
- setExpireAfterAccess(TimeValue) - Method in class org.elasticsearch.common.cache.CacheBuilder
-
Sets the amount of time before an entry in the cache expires after it was last accessed.
- setExpireAfterWrite(TimeValue) - Method in class org.elasticsearch.common.cache.CacheBuilder
-
Sets the amount of time before an entry in the cache expires after it was written.
- setExplain(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Sets the explain flag (defaults to
false
). - setExplain(boolean) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets explain
- setExplain(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
Indicates if detailed information about the query should be returned.
- setExplain(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should each
SearchHit
be returned with an explanation of the hit (ranking). - setExplain(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setFeatures(Set<String>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Set the features on the stream.
- setFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
- setFetchSource(boolean) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Indicates whether the response should contain the stored _source
- setFetchSource(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Indicates whether the response should contain the stored _source.
- setFetchSource(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicates whether the response should contain the stored _source for every hit
- setFetchSource(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Indicates whether the response should contain the updated _source.
- setFetchSource(String[], String[]) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String[], String[]) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String[], String[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String[], String[]) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String, String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String, String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String, String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String, String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setField(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets the field that its analyzer will be used to analyze the text.
- setField(String) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
Set the field to be used for random number generation.
- setField(String) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setFielddata(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- setFieldData(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setFieldDataCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- setFieldDataFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setFielddataMaxFrequency(double) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- setFielddataMinFrequency(double) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- setFielddataMinSegmentSize(int) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- setFieldName(String) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setFieldNames(String[]) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the field names that will be used when generating the 'More Like This' query.
- setFieldNames(List<String>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Deprecated.Use
InnerHitBuilder.setStoredFieldNames(List)
instead. - setFields(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- setFields(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
-
Sets the fields to retrieve.
- setFields(String...) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequestBuilder
-
The list of field names to retrieve.
- setFields(String...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Deprecated.
- setFields(Fields, Set<String>, EnumSet<TermVectorsRequest.Flag>, Fields) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setFields(Fields, Set<String>, EnumSet<TermVectorsRequest.Flag>, Fields, AggregatedDfs, TermVectorsFilter) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setFieldStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the field statistics for each term in the shard or skip.
- setFieldValue(String, Object) - Method in class org.elasticsearch.ingest.IngestDocument
-
Sets the provided value to the provided path in the document.
- setFieldValue(TemplateScript.Factory, ValueSource) - Method in class org.elasticsearch.ingest.IngestDocument
-
Sets the provided value to the provided path in the document.
- setFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- setFiltersAsList(List<AdjacencyMatrixAggregator.KeyedFilter>) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- setFiltersAsMap(Map<String, QueryBuilder>) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- setFilterSettings(TermVectorsRequest.FilterSettings) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the settings for filtering out terms.
- setFlags(String) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions.Builder
-
Sets the regular expression syntax flags see
RegexpFlag
- setFlush(boolean) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequestBuilder
-
Should flush be performed after the merge.
- setFlush(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setFlushInterval(TimeValue) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets a flush interval flushing *any* bulk actions pending if the interval passes.
- setForce(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
- setForceAnalyzer(Analyzer) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setForcedRefresh(boolean) - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- setForcedRefresh(boolean) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setForcedRefresh(boolean) - Method in class org.elasticsearch.action.DocWriteResponse
- setForcedRefresh(boolean) - Method in class org.elasticsearch.action.resync.ResyncReplicationResponse
- setForcedRefresh(boolean) - Method in interface org.elasticsearch.action.support.WriteResponse
-
Mark the response as having forced a refresh? Requests that set
WriteRequest.setRefreshPolicy(RefreshPolicy)
toWriteRequest.RefreshPolicy.IMMEDIATE
should always mark this as true. - setForcedRefresh(boolean) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Response
- setForceQuoteAnalyzer(Analyzer) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setFreq(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- setFrom(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
From index to start the search from.
- setFrom(int) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setFs(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node file system stats be returned.
- setFuzziness(int) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the level of fuzziness used to create suggestions using a
Fuzziness
instance. - setFuzziness(Fuzziness) - Method in class org.elasticsearch.index.search.MatchQuery
- setFuzziness(Fuzziness) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setFuzziness(Fuzziness) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the level of fuzziness used to create suggestions using a
Fuzziness
instance. - setFuzzyMaxExpansions(int) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setFuzzyMinLength(int) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the minimum length of input string before fuzzy suggestions are returned, defaulting to 3.
- setFuzzyPrefixLength(int) - Method in class org.elasticsearch.index.search.MatchQuery
- setFuzzyPrefixLength(int) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the minimum length of the input, which is not checked for fuzzy alternatives, defaults to 1
- setFuzzyRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.elasticsearch.index.search.MatchQuery
- setFuzzyRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setFuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setGatewayAllocator(GatewayAllocator) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- setGeoPoint(GeoPoint) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
-
Sets the geo point of the context.
- setGet(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setGetResult(GetResult) - Method in class org.elasticsearch.action.update.UpdateResponse.Builder
- setGetResult(GetResult) - Method in class org.elasticsearch.action.update.UpdateResponse
- setGlobalIndex(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setGlobalPipeline(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setGlobalRouting(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setGlobalText(String) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Sets the text to provide suggestions for.
- setGlobalType(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setGroups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setGroupTieBreaker(float) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setHandshakeTimeout(TimeValue) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets a handshake timeout for this connection profile
- setHasDocValues(boolean) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setHasPendingAsyncFetch() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Sets a flag that signals that current allocation run has not processed all of the in-flight or available shard or store fetches.
- setHeader(BytesReference) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setHighFreqMinimumNumberShouldMatch(String) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
- setHighlightBuilder(HighlightBuilder) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setHit(SearchHit) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- setHttp(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node HTTP info be returned.
- setHttp(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node HTTP stats be returned.
- setId(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequestBuilder
- setId(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequestBuilder
- setId(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequestBuilder
- setId(String) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the id of the document to delete.
- setId(String) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setId(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the id to get a score explanation for.
- setId(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the id of the document to fetch.
- setId(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the id to index the document under.
- setId(String) - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- setId(String) - Method in class org.elasticsearch.action.ingest.DeletePipelineRequestBuilder
-
Sets the id of the pipeline to delete.
- setId(String) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- setId(String) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Set the id for the pipeline to simulate
- setId(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the id of the document.
- setId(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the id of the indexed document.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
only perform this delete request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
only perform this delete request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in interface org.elasticsearch.action.DocWriteRequest
-
only performs this request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.index.IndexRequest
-
only performs this indexing request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
only perform this indexing request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.update.UpdateRequest
-
only performs this update request if the document's last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
only perform this update request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.index.engine.Engine.Get
- setIfSeqNo(long) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
only perform this delete request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
only perform this delete request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in interface org.elasticsearch.action.DocWriteRequest
-
only perform this request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.index.IndexRequest
-
only perform this indexing request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
only perform this indexing request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.update.UpdateRequest
-
only perform this update request if the document's modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
only perform this update request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.index.engine.Engine.Get
- setIgnoreIdleThreads(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setIgnoreIndexSettings(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets the list of index settings and index settings groups that shouldn't be restored from snapshot
- setIgnoreIndexSettings(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets the list of index settings and index settings groups that shouldn't be restored from snapshot
- setIgnoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Makes the request ignore unavailable snapshots
- setIgnoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Set to
true
to ignore unavailable snapshots, instead of throwing an exception. - setIgnoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setIncludeAliases(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If set to true the restore procedure will restore aliases
- setIncludeDiskInfo(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Whether to include information about the gathered disk information of nodes in the cluster
- setIncludeGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Set to true if snapshot should include global cluster state
- setIncludeInAllDefault(boolean) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a view of this
ParseContext
that changes the return value ofParseContext.getIncludeInAllDefault()
. - setIncludeSegmentFileSizes(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setIncludeYesDecisions(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Whether to include "YES" decider decisions in the response instead of only "NO" decisions
- setIndex(String) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Sets the index name of the shard to explain.
- setIndex(String) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
The index name to use when finding the shard to explain
- setIndex(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the name of the index to be created
- setIndex(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
- setIndex(String) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
- setIndex(String) - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequestBuilder
-
Sets the index.
- setIndex(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the index where the document is located.
- setIndex(String) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- setIndex(String) - Method in exception org.elasticsearch.ElasticsearchException
- setIndex(Index) - Method in exception org.elasticsearch.ElasticsearchException
- setIndexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setIndexing(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setIndexSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets index settings that should be added or replaced during restore
- setIndexSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets index settings that should be added or replaced during restore
- setIndexSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets index settings that should be added or replaced during restore
- setIndexSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets index settings that should be added or replaced during restore
- setIndices(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node indices info be returned.
- setIndices(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node indices stats be returned.
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
Sets the indices the search will be executed on.
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets a list of indices that should be included into the snapshot
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets the list of indices that should be restored from snapshot
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
When
ClusterStateRequestBuilder.setMetaData(boolean)
is set, which indices to return theIndexMetaData
for. - setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
-
Sets the indices to be closed
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
- setIndices(String[]) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
- setIndices(String[]) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
-
Sets the indices to be opened
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the indices the update settings will execute on
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoreRequestBuilder
-
Sets the indices for the shard stores request
- setIndices(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the indices the search will be executed on.
- setIndices(String...) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- setIndices(CommonStatsFlags) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node indices stats be returned.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
Specifies what type of requested indices to ignore and how to deal indices wildcard expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Specifies the indices options.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions For example indices that don't exist.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
-
Specifies what type of requested indices to ignore and how to deal with wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoreRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions By default, expands wildcards to both open and closed indices
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Specifies what type of requested indices to ignore and how to deal with wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Set the IndicesOptions for controlling unavailable indices
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set the IndicesOptions for controlling unavailable indices
- setIngest(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node ingest info be returned.
- setIngest(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should ingest statistics be returned.
- setInitialState(ClusterState) - Method in interface org.elasticsearch.cluster.service.ClusterApplier
-
Sets the initial state for this applier.
- setInitialState(ClusterState) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- setInnerCollapse(CollapseBuilder) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setInnerHits(List<InnerHitBuilder>) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- setInnerHits(Map<String, SearchHits>) - Method in class org.elasticsearch.search.SearchHit
- setInnerHits(InnerHitBuilder) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- setInternalActionLongTimeout(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setInternalActionTimeout(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setInterval(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- setInterval(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setInterval(TimeValue) - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Change the interval between runs.
- setIsFilter(boolean) - Method in class org.elasticsearch.index.query.QueryShardContext
-
Public for testing only! Sets whether we are currently parsing a filter or a query
- setJvm(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node JVM info be returned.
- setJvm(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node JVM stats be returned.
- setKeyAsString(String) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- setKeyed(boolean) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- setLastAccessTime() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
sets the lasAccessTime flag to now
- setLenient(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Deprecated.use #lenient() instead
- setLenient(boolean) - Method in class org.elasticsearch.index.search.MatchQuery
- setLevel(Logger, String) - Static method in class org.elasticsearch.common.logging.Loggers
-
Set the level of the logger.
- setLevel(Logger, Level) - Static method in class org.elasticsearch.common.logging.Loggers
- setLikeFields(Fields...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setLikeText(String...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setLikeText(List<String>) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setListener(IndexFieldDataCache.Listener) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
-
Sets a
IndexFieldDataCache.Listener
passed to eachIndexFieldData
creation to capture onCache and onRemoval events. - setLocal(boolean) - Method in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequestBuilder
-
Specifies if the request should be executed on local node rather than on master
- setLocalNode(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- setLowFreqMinimumNumberShouldMatch(String) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
- setMapUnmappedFieldAsString(boolean) - Method in class org.elasticsearch.index.query.QueryShardContext
- setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequestBuilder
-
Sets the master node timeout in case the master has not yet been discovered.
- setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequestBuilder
-
Sets the master node timeout in case the master has not yet been discovered.
- setMaxChildren(int) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- setMaxConcurrentGroupRequests(int) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- setMaxConcurrentSearchRequests(int) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Sets how many search requests specified in this multi search requests are allowed to be ran concurrently.
- setMaxConcurrentShardRequests(int) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the number of shard requests that should be executed concurrently.
- setMaxConcurrentShardRequests(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the number of shard requests that should be executed concurrently.
- setMaxDeterminizedStates(int) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the maximum automaton states allowed for the fuzzy expansion
- setMaxDeterminizedStates(int) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions.Builder
-
Sets the maximum automaton states allowed for the regular expression expansion
- setMaxDocFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMaxDocFreq(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMaxDocFreq(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Set the maximum frequency in which words may still appear.
- setMaxDocFreqPct(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Set the maximum percentage in which words may still appear.
- setMaxExpansions(int) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- setMaxExpansions(int) - Method in class org.elasticsearch.index.search.MatchQuery
- setMaximumWeight(long) - Method in class org.elasticsearch.common.cache.CacheBuilder
- setMaxNumSegments(int) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequestBuilder
-
Will force merge the index down to <= maxNumSegments.
- setMaxNumTerms(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMaxNumTokensParsed(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- setMaxQueryTerms(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMaxQueryTerms(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the maximum number of query terms that will be included in any generated query.
- setMaxRetries(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set the total number of retries attempted for rejections.
- setMaxRetries(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Total number of retries attempted for rejections.
- setMaxTermFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMaxWordLen(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMaxWordLen(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the maximum word length above which words will be ignored.
- setMaxWordLength(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMBPerSec(ByteSizeValue) - Method in class org.elasticsearch.common.util.CombinedRateLimiter
- setMerge(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setMetaData(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Should the cluster state result include the
MetaData
. - setMetaData(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- setMetaData(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Associate metadata with this
AggregationBuilder
. - setMetaData(Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.BaseAggregationBuilder
-
Set the aggregation's metadata.
- setMetaData(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- setMetaData(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Associate metadata with this
PipelineAggregationBuilder
. - setMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- setMinDocFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMinDocFreq(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMinDocFreq(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the frequency at which words will be ignored which do not occur in at least this many docs.
- setMinimumShouldMatch(String) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
- setMinimumShouldMatchField(String) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- setMinimumShouldMatchScript(Script) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- setMinScore(float) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the minimum score below which docs will be filtered out.
- setMinScore(float) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- setMinTermFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMinTermFreq(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the frequency below which terms will be ignored in the source doc.
- setMinTermFrequency(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMinTranslogGenerationForRecovery(long) - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- setMinWordLen(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMinWordLen(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the minimum word length below which words will be ignored.
- setMinWordLength(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMissing(Object) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setMoreLikeFields(String[]) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMultiValueMode(MultiValueMode) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- setName(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequestBuilder
-
Sets the repository name
- setName(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository name
- setName(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequestBuilder
-
Sets the repository name
- setName(String) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
-
Sets the name of the index template to delete.
- setName(String) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setName(String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setName(String) - Method in class org.elasticsearch.search.aggregations.ParsedAggregation
- setNames(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
- setNeighbours(List<Integer>) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
-
Sets the precision levels at which geohash cells neighbours are considered.
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Deprecated.set nested sort with
FieldSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withFieldSortBuilder.getNestedSort()
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.set nested sort with
GeoDistanceSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withGeoDistanceSortBuilder.getNestedSort()
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Deprecated.set nested sort with
ScriptSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withScriptSortBuilder.getNestedSort()
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Deprecated.set nested sort with
FieldSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withFieldSortBuilder.getNestedSort()
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.set nested sort with
GeoDistanceSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withGeoDistanceSortBuilder.getNestedSort()
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Deprecated.set nested sort with
ScriptSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withScriptSortBuilder.getNestedSort()
- setNestedSort(NestedSortBuilder) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Sets the
NestedSortBuilder
to be used for fields that are inside a nested object. - setNestedSort(NestedSortBuilder) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Sets the
NestedSortBuilder
to be used for fields that are inside a nested object. - setNestedSort(NestedSortBuilder) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- setNestedSort(NestedSortBuilder) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Sets the
NestedSortBuilder
to be used for fields that are inside a nested object. - setNewIndexName(String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Sets the alias to rollover to another index
- setNewIndexName(String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- setNext(ShapeBuilder.Edge) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
- setNextAggregationValue(Object) - Method in class org.elasticsearch.script.SearchScript
-
Sets per-document aggregation
_value
. - setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
-
Set the current doc ID.
- setNextDocId(int) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- setNextVar(String, Object) - Method in class org.elasticsearch.script.SearchScript
- setNode(String) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- setNodeConnectionsService(NodeConnectionsService) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- setNodeConnectionsService(NodeConnectionsService) - Method in class org.elasticsearch.cluster.service.ClusterService
- setNodeName(String) - Static method in class org.elasticsearch.common.logging.LogConfigurator
-
Sets the node name.
- setNodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Should the cluster state result include the
DiscoveryNodes
. - setNodes(String...) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setNodes(List<VerifyRepositoryResponse.NodeView>) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- setNodesIds(String...) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
- setNodesIds(String...) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
- setNoops(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setNormalizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Instead of setting the analyzer and tokenizer, sets the normalizer as name
- setNormalizer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- setNullValue(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Sets the null value and initializes the string version
- setNumBuckets(int) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- setNumPriorUsesInASequence(short) - Method in interface org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttribute
- setNumPriorUsesInASequence(short) - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- setOccur(BooleanClause.Occur) - Method in class org.elasticsearch.index.search.MatchQuery
- setOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type modelling a
Set
whose elements are of typeelementType
. - setOffsets(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the start and stop offsets for each term if they were stored or skip offsets.
- setOnCancel(CancellableThreads.OnCancel) - Method in class org.elasticsearch.common.util.CancellableThreads
-
Registers a callback that will be invoked when some running operations are cancelled or
CancellableThreads.checkForCancel()
is called. - setOnce(int, E) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
- setOnlyExpungeDeletes(boolean) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequestBuilder
-
Should the merge only expunge deletes from the index, without full merging.
- setOperationPrimaryTerm(long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Sets the current operation primary term.
- setOpType(DocWriteRequest.OpType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the type of operation to perform.
- setOrder(int) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the order of this template if more than one template matches.
- setOrientation(ShapeBuilder.Orientation) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- setOs(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node OS info be returned.
- setOs(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node OS stats be returned.
- setOutput(OutputStream) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Sets the output stream to use for writing until this writer is closed.
- setOutputStream(OutputStream) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Deprecated.Replaced by
UTF8StreamWriter.setOutput(OutputStream)
- setParams(PersistentTaskParams) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- setParent(String) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the parent id of this document.
- setParent(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Simple sets the routing.
- setParent(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the parent id of this document.
- setParent(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the parent id of this document.
- setParent(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the parent id of this document.
- setParent(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
- setParent(String) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setParentTask(String, long) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- setParentTask(String, long) - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Set a reference to task that caused this task to be run.
- setParentTask(TaskId) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- setParentTask(TaskId) - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Set a reference to task that created this request.
- setParentTask(TaskId) - Method in class org.elasticsearch.transport.TransportRequest
-
Set a reference to task that created this request.
- setParentTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setParentTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
-
Match all children of the provided task.
- setPartial(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
If set to true the request should snapshot indices with unavailable shards
- setPartial(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If set to true the restore procedure will restore partially snapshotted indices
- setPatterns(List<String>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the match expression that will be used to match on indices created.
- setPayloads(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the payloads for each term or skip.
- setPerFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the analyzer used at each field when generating term vectors.
- setPersistentSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the source containing the persistent settings to be updated.
- setPersistentSettings(Map) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the persistent settings to be updated.
- setPersistentSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the persistent settings to be updated.
- setPersistentSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the persistent settings to be updated.
- setPhase(String) - Method in class org.elasticsearch.action.support.replication.ReplicationTask
-
Set the current phase of the task.
- setPhase(String) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
Set the current phase of the task.
- setPhraseSlop(int) - Method in class org.elasticsearch.index.search.MatchQuery
- setPhraseSlop(int) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setPingInterval(TimeValue) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets a ping interval for this connection profile
- setPipeline(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the ingest pipeline to be executed before indexing the document
- setPipeline(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the ingest pipeline to be executed before indexing the document
- setPipeline(String) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set the ingest pipeline to set on index requests made by this action.
- setPipeline(String) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- setPlugins(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node plugins info be returned.
- setPointsOnly(boolean) - Method in class org.elasticsearch.common.geo.XShapeCollection
- setPointsOnly(boolean) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- setPointsOnly(boolean) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- setPositions(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the positions for each term if stored or skip.
- setPostFilter(QueryBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a filter that will be executed after the query has been executed and only has affect on the search hits (not aggregations).
- setPrecision(int) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
-
Sets the precision level for computing the geohash from the context geo point.
- setPrecision(String) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- setPrecisionInMeters(double) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- setPreference(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the shard preference.
- setPreference(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the preference to execute the search.
- setPreFilterShardSize(int) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets a threshold that enforces a pre-filter roundtrip to pre-filter search shards based on query rewriting if the number of shards the search request expands to exceeds the threshold.
- setPreFilterShardSize(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a threshold that enforces a pre-filter roundtrip to pre-filter search shards based on query rewriting if the number of shards the search request expands to exceeds the threshold.
- setPrefix(boolean) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
-
Sets if the context should be treated as a prefix or not.
- setPrefix(BytesRef) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setPreserveExisting(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Iff set to
true
this settings update will only add settings not already set on an index. - setPreserveExisting(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Iff set to
true
this settings update will only add settings not already set on an index. - setPreserveExisting(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
- setPreservePositionIncrements(boolean) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- setPreserveSep(boolean) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- setPrimary(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Whether the primary or replica should be explained
- setPrimary(Boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Sets whether to explain the allocation of the primary shard or a replica shard copy for the shard id (see
ClusterAllocationExplainRequest.getShard()
). - setPrimaryTerm(long) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setPrimaryTerm(long) - Method in class org.elasticsearch.search.SearchHit
- setPrimaryTerm(Long) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setProcess(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node OS process be returned.
- setProcess(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node OS stats be returned.
- setProfile(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should the query be profiled.
- setProfile(boolean) - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- setProfile(boolean) - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
Sets if this shard search needs to be profiled or not
- setProfile(boolean) - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- setProfiler(QueryProfiler) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- setProxyDelegates(T) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- setQuery(Query) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
The query to validate.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the query to get a score explanation for.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Constructs a new search source builder with a search query.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Set the query for selective delete
- setQuery(QueryBuilder) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set the query for selective update
- setQueryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- setQueryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Sets the original query weight for rescoring.
- setQuoteFieldSuffix(String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setRealtime(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
- setRealtime(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- setRealtime(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether term vectors are generated real-time.
- setReason(String) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
-
Set the reason for canceling the task.
- setReasonCancelled(String) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setRecheckInterval(TimeValue) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
- setRecovery(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setRefresh(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setRefresh(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Should a refresh be executed before this get operation causing the operation to return the latest value.
- setRefresh(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
Should a refresh be executed before this get operation causing the operation to return the latest value.
- setRefresh(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Call refresh on the indexes we've written to after the request ends?
- setRefreshPolicy(String) - Method in interface org.elasticsearch.action.support.WriteRequest
-
Parse the refresh policy from a string, only modifying it if the string is non null.
- setRefreshPolicy(String) - Method in interface org.elasticsearch.action.support.WriteRequestBuilder
-
Parse the refresh policy from a string, only modifying it if the string is non null.
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in class org.elasticsearch.action.bulk.BulkRequest
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in interface org.elasticsearch.action.support.WriteRequest
-
Should this request trigger a refresh (WriteRequest.RefreshPolicy.IMMEDIATE), wait for a refresh ( WriteRequest.RefreshPolicy.WAIT_UNTIL), or proceed ignore refreshes entirely (WriteRequest.RefreshPolicy.NONE, the default).
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in interface org.elasticsearch.action.support.WriteRequestBuilder
-
Should this request trigger a refresh (WriteRequest.RefreshPolicy.IMMEDIATE), wait for a refresh ( WriteRequest.RefreshPolicy.WAIT_UNTIL), or proceed ignore refreshes entirely (WriteRequest.RefreshPolicy.NONE, the default).
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in class org.elasticsearch.action.update.UpdateRequest
- setRegex(BytesRef) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setRemoteInfo(RemoteInfo) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the
RemoteInfo
if the source indices are in a remote cluster. - setRemoteInfo(RemoteInfo) - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
-
Setup reindexing from a remote cluster.
- setRenamePattern(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets rename pattern that should be applied to restored indices.
- setRenameReplacement(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets rename replacement
- setRepositories(String...) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Sets list of repositories to get
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets the repository name
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
-
Sets the repository name
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Sets the repository name
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets repository name
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Sets the repository name
- setRequest(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- setRequest(PersistentTaskParams) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.RequestBuilder
- setRequestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- setRequestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setRequestCache(Boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets if this request should use the request cache or not, assuming that it can (for example, if "now" is used, it will never be cached).
- setRequestsPerSecond(float) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set the throttle for this request in sub-requests per second.
- setRequestsPerSecond(float) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set the throttle for this request in sub-requests per second.
- setRequestsPerSecond(Float) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setRequiredSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- setRescoredDocs(Set<Integer>) - Method in class org.elasticsearch.search.rescore.RescoreContext
- setRescoreQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setRescoreQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Sets the original query weight for rescoring.
- setRescorer(RescorerBuilder<?>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Clears all rescorers on the builder and sets the first one.
- setRescorer(RescorerBuilder, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Clears all rescorers on the builder and sets the first one.
- setResizeType(ResizeType) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
The type of the resize operation
- setResizeType(ResizeType) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- setResources(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
- setResponse(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- setRestoreGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If set to true the restore procedure will restore global cluster state.
- setResult(DocWriteResponse.Result) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setResyncedOperations(int) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- setRetentionAgeInMillis(long) - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- setRetentionSizeInBytes(long) - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- setRetries(Tuple<Long, Long>) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setRetryBackoffInitialTime(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set the initial delay after a rejection before retrying request.
- setRetryBackoffInitialTime(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Initial delay after a rejection before retrying a bulk request.
- setRetryDelayNetwork(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setRetryDelayStateSync(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setRetryFailed(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Sets the retry failed flag (defaults to
false
). - setRetryFailed(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Sets the retry failed flag (defaults to
false
). - setRetryOnConflict(int) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the number of retries of a version conflict occurs because the document was updated between getting it and updating it.
- setRewrite(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
Indicates whether the query should be rewritten into primitive queries
- setRewriteMethod(MultiTermQuery, MultiTermQuery.RewriteMethod) - Static method in class org.elasticsearch.index.query.support.QueryParsers
- setRouting(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
A comma separated list of routing values to control the shards the search will be executed on.
- setRouting(String) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Controls the shard routing of the delete request.
- setRouting(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the routing for sharding.
- setRouting(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Controls the shard routing of the request.
- setRouting(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Controls the shard routing of the request.
- setRouting(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
A comma separated list of routing values to control the shards the search will be executed on.
- setRouting(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the routing.
- setRouting(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Controls the shard routing of the request.
- setRouting(String) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Set routing limiting the process to the shards that match that routing value
- setRouting(String) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setRouting(String) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set routing limiting the process to the shards that match that routing value
- setRouting(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
The routing values to control the shards that the search will be executed on.
- setRouting(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The routing values to control the shards that the search will be executed on.
- setRoutingNumShards(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
Sets the number of shards that should be used for routing.
- setRoutingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Should the cluster state result include the
RoutingTable
. - Sets - Class in org.elasticsearch.common.util.set
- setScore(float) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- setScoreMode(String) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setScoreMode(QueryRescoreMode) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setScoreMode(QueryRescoreMode) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Sets the original query score mode.
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
- setScorer(Scorer) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
- setScorer(Scorer) - Method in interface org.elasticsearch.common.lucene.ScorerAware
- setScorer(Scorer) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- setScorer(Scorer) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- setScorer(Scorer) - Method in class org.elasticsearch.script.ScoreScript
- setScorer(Scorer) - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- setScorer(Scorer) - Method in class org.elasticsearch.script.SearchScript
- setScorer(Scorer) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollector
- setScorer(Scorer) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollectorBase
- setScorer(Scorer) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
- setScorer(Scorer) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
- setScorer(Scorer) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
- setScorer(Scorer) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingLeafBucketCollector
- setScript(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
- setScript(Script) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
The script to execute.
- setScript(Script) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
-
Script to modify the documents before they are processed.
- setScript(Script) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setScriptedUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets whether the script should be run in the case of an insert
- setScriptFields(Set<SearchSourceBuilder.ScriptField>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setScroll(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(String) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(String) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
-
Set the id of the last scroll.
- setScroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set scroll timeout for
SearchRequest
- setScroll(Scroll) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
If set, will enable scrolling of the search request.
- setScroll(Scroll) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
If set, will enable scrolling of the search request.
- setScrollId(String) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
The scroll id to use to continue scrolling.
- setScrollIds(List<String>) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- setScrollIds(List<String>) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
- setSearch(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setSearchAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setSearcherWrapper(IndexModule.IndexSearcherWrapperFactory) - Method in class org.elasticsearch.index.IndexModule
-
Sets a
IndexModule.IndexSearcherWrapperFactory
that is called once the IndexService is fully constructed. - setSearchQuoteAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setSearchRetries(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setSearchShardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- setSearchShardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- setSearchShardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- setSearchShardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.SearchPhaseResult
- setSearchType(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The a string representation search type to execute, defaults to
SearchType.DEFAULT
. - setSearchType(SearchType) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The search type to execute, defaults to
SearchType.DEFAULT
. - setSecureSettings(SecureSettings) - Method in class org.elasticsearch.common.settings.Settings.Builder
- setSegmentAndDocument(LeafReaderContext, int) - Method in class org.elasticsearch.search.lookup.SourceLookup
- setSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setSelectedFields(String...) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return only term vectors for special selected fields.
- setSeqNo(long) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setSeqNo(long) - Method in class org.elasticsearch.search.SearchHit
- setSeqNo(Long) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setSeqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setSettings(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node settings be returned.
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings in Json or Yaml format
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings in YAML or JSON format
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets repository-specific restore settings in JSON or YAML format
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with (either json or yaml format)
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated (either json or yaml format)
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to crete the index template with (either json or yaml format)
- setSettings(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with (either json/yaml/properties format)
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings.
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets repository-specific restore settings
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to crete the index template with (either json or yaml format)
- setSettings(TermVectorsRequest.FilterSettings) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings.
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets repository-specific restore settings.
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with.
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to created the index template with.
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings.
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets repository-specific restore settings.
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with.
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to created the index template with.
- setSettings(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Allows to set the settings using a json builder.
- setShard(int) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
The shard number to use when finding the shard to explain
- setShard(int) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- setShard(Integer) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Sets the shard id of the shard to explain.
- setShard(ShardId) - Method in exception org.elasticsearch.ElasticsearchException
- setShardId(ShardId) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Override this method from ReplicationAction, this is where we are storing our state in the request object (which we really shouldn't do).
- setShardId(ShardId) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setShardId(ShardId) - Method in class org.elasticsearch.action.index.IndexRequest
-
Override this method from ReplicationAction, this is where we are storing our state in the request object (which we really shouldn't do).
- setShardId(ShardId) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Sets the target shard id for the request.
- setShardIndex(int) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- setShardIndex(int) - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- setShardIndex(int) - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- setShardIndex(int) - Method in class org.elasticsearch.search.SearchPhaseResult
- setShardIndex(int) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- setShardIndex(int) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- setShardInfo(ReplicationResponse.ShardInfo) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setShardInfo(ReplicationResponse.ShardInfo) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.PrimaryResult
- setShardInfo(ReplicationResponse.ShardInfo) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse
- setShardInfo(ReplicationResponse.ShardInfo) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- setShardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- setShardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- setShardSize(int) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setShardStatuses(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoreRequestBuilder
-
Set statuses to filter shards to get stores info on.
- setShouldStoreResult(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Should this task store its result after it has finished?
- setShouldStoreResult(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Should this task store its result after it has finished?
- setSimilarity(Similarity) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setSimilarity(TFIDFSimilarity) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- setSimilarity(SimilarityProvider) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setSize(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The number of search hits to return.
- setSize(int) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setSize(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Maximum number of processed documents.
- setSize(int) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setSkippedOperations(int) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- setSkipTerms(Set<Term>) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets a list of terms to never select from
- setSliceId(Integer) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setSlices(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The number of slices this task should be divided into.
- setSlices(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
The number of slices this task should be divided into.
- setSliceStatuses(List<BulkByScrollTask.StatusOrException>) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setSlop(int) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Sets the phrase slop for this query.
- setSlowTaskLoggingThreshold(TimeValue) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- setSlowTaskLoggingThreshold(TimeValue) - Method in class org.elasticsearch.cluster.service.MasterService
- setSnapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets the snapshot name
- setSnapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
-
Sets the snapshot name
- setSnapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets snapshot name
- setSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Sets list of snapshots to return
- setSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Sets list of snapshots to return
- setSorts(List<SortBuilder<?>>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setSortValues(Object[]) - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- setSource(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the document to index in bytes form (assumed to be safe to be used from different threads).
- setSource(byte[], XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(byte[], XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(byte[], XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the document to index in bytes form.
- setSource(Object...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- setSource(Object...) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field name and value pairs.
- setSource(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The mapping source definition.
- setSource(String, XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the document source to index.
- setSource(Map) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The mapping source definition.
- setSource(Map) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(Map<String, ?>) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Index the Map as a JSON.
- setSource(Map<String, ?>, XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Index the Map as the provided content type.
- setSource(Map<String, Object>) - Method in class org.elasticsearch.search.lookup.SourceLookup
- setSource(BytesReference) - Method in class org.elasticsearch.search.lookup.SourceLookup
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the source.
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The mapping source definition.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the content source to index.
- setSource(XContentType, Object...) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field name and value pairs.
- setSource(SearchSourceBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a SearchSourceBuilder.
- setSourceBatchSize(int) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Sets the scroll size for setting how many documents are to be processed in one batch during reindex
- setSourceContentType(XContentType) - Method in class org.elasticsearch.search.lookup.SourceLookup
- setSourceDocTypes(String...) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the document types which need to be copied from the source indices
- setSourceIndex(String) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- setSourceIndex(String) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- setSourceIndices(String...) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the indices which will act as the source for the ReindexRequest
- setSourceQuery(QueryBuilder) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the query for selecting documents from the source indices
- setSpatialStrategy(SpatialStrategy) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- setSplitQueriesOnWhitespace(boolean) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- setStage(RecoveryState.Stage) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- setState(PersistentTaskState) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- setState(PersistentTaskState) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.RequestBuilder
- setStats(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The stats groups this request will be aggregated under.
- setStats(List<String>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The stats groups this request will be aggregated under.
- setStatus(ClusterHealthStatus) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
Allows to explicitly override the derived cluster health status.
- setStopWords(Set<?>) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setStopWords(Set<?>) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Set the set of stopwords.
- setStore(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setStoredFieldNames(List<String>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Sets the stored fields to load and return.
- setStoredFields(String...) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Explicitly specify the stored fields that will be returned for the explained document.
- setStoredFields(String...) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Explicitly specify the fields that will be returned.
- setStrategy(SpatialStrategy) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- setTargetIndex(CreateIndexRequest) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- setTargetIndex(CreateIndexRequest) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- setTask(SearchTask) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- setTask(SearchTask) - Method in class org.elasticsearch.search.internal.SearchContext
- setTaskId(String) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- setTaskId(String) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.RequestBuilder
- setTaskId(String) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- setTaskId(String) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.RequestBuilder
- setTaskId(String) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- setTaskId(String) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.RequestBuilder
- setTaskId(TaskId) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Set the TaskId to look up.
- setTaskId(TaskId) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequestBuilder
-
Set the TaskId to look up.
- setTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
-
Set the task to lookup.
- setTaskName(String) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- setTaskResultsService(TaskResultsService) - Method in class org.elasticsearch.tasks.TaskManager
- setTemplate(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Deprecated.Replaced by
PutIndexTemplateRequestBuilder.setPatterns(List)
- setTerminateAfter(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
An optional document count, upon collecting which the search query will early terminate
- setTermStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the term statistics for each term in the shard or skip.
- setTermVectorsField(BytesStreamOutput) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setText(String) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- setText(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets texts to analyze
- setText(CharacterIterator) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- setText(BytesRef) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setThreadContext(ThreadContext) - Static method in class org.elasticsearch.common.logging.DeprecationLogger
-
Set the
ThreadContext
used to add deprecation headers to network responses. - setThreadPool(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node thread pool info be returned.
- setThreadPool(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node thread pool stats be returned.
- setThreads(int) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setThrottled(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setThrottledUntil(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setTieBreaker(float) - Method in class org.elasticsearch.index.search.MultiMatchQuery
- setTimedOut(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- setTimeout(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setTimeout(String) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(String) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequestBuilder
-
Timeout to wait for the operation to be acknowledged by current cluster nodes.
- setTimeout(String) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
- setTimeout(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(String) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(String) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setTimeout(String) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Timeout to wait for the shards on to be available for each bulk request?
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Timeout to wait for any async actions this request must take.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequestBuilder
-
Timeout to wait for any async actions this request must take.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
An optional timeout to control how long search is allowed to take.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequestBuilder
-
Sets the maximum wait for acknowledgement from other nodes
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
- setTimeout(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Timeout to wait for the shards on to be available for each bulk request?
- setTimer(T, Timer) - Method in class org.elasticsearch.search.profile.AbstractProfileBreakdown
- setTimeZone(DateTimeZone) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setTimeZone(DateTimeZone) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- Setting<T> - Class in org.elasticsearch.common.settings
-
A setting.
- Setting(String, String, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(String, String, Function<String, T>, Setting.Validator<T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new
Setting
instance. - Setting(String, Function<Settings, String>, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(String, Setting<T>, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(Setting.Key, Function<Settings, String>, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(Setting.Key, Function<Settings, String>, Function<String, T>, Setting.Validator<T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new
Setting
instance. - Setting(Setting.Key, Setting<T>, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- SETTING - Static variable in class org.elasticsearch.cluster.metadata.AutoExpandReplicas
- SETTING_ALLOCATION_MAX_RETRY - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- SETTING_AUTO_EXPAND_REPLICAS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_BLOCKS_METADATA - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_BLOCKS_READ - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_BLOCKS_WRITE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_CLUSTER_MAX_SHARDS_PER_NODE - Static variable in class org.elasticsearch.cluster.metadata.MetaData
- SETTING_CORS_ALLOW_CREDENTIALS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_ALLOW_HEADERS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_ALLOW_METHODS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_ALLOW_ORIGIN - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_ENABLED - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_MAX_AGE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CREATION_DATE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_CREATION_DATE_STRING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_DATA_PATH - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_HTTP_BIND_HOST - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_COMPRESSION - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_COMPRESSION_LEVEL - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_CONTENT_TYPE_REQUIRED - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_DETAILED_ERRORS_ENABLED - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_HOST - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_CHUNK_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_CONTENT_LENGTH - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_HEADER_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_INITIAL_LINE_LENGTH - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_WARNING_HEADER_COUNT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_WARNING_HEADER_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_PORT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_PUBLISH_HOST - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_PUBLISH_PORT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_READ_TIMEOUT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_RESET_COOKIES - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_KEEP_ALIVE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_NO_DELAY - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_REUSE_ADDRESS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_INDEX_PROVIDED_NAME - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
The user provided name for an index.
- SETTING_INDEX_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_INDEX_VERSION_CREATED - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_MAX_TOMBSTONES - Static variable in class org.elasticsearch.cluster.metadata.IndexGraveyard
-
Setting for the maximum tombstones allowed in the cluster state; prevents the cluster state size from exploding too large, but it opens the very unlikely risk that if there are greater than MAX_TOMBSTONES index deletions while a node was offline, when it comes back online, it will have missed index deletions that it may need to process.
- SETTING_NUMBER_OF_REPLICAS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_NUMBER_OF_SHARDS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_PIPELINING - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_PIPELINING_MAX_EVENTS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_PRIORITY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_READ_ONLY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_READ_ONLY_ALLOW_DELETE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_READ_ONLY_ALLOW_DELETE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.MetaData
- SETTING_READ_ONLY_SETTING - Static variable in class org.elasticsearch.cluster.metadata.MetaData
- SETTING_ROUTING_PARTITION_SIZE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_TV_HIGHLIGHT_MULTI_VALUE - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.FastVectorHighlighter
- SETTING_VERSION_CREATED - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_VERSION_CREATED_STRING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_VERSION_UPGRADED - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_VERSION_UPGRADED_STRING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
- SETTING_WAIT_FOR_ACTIVE_SHARDS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
The number of active shard copies to check for before proceeding with a write operation.
- Setting.AffixKey - Class in org.elasticsearch.common.settings
-
A key that allows for static pre and suffix.
- Setting.AffixSetting<T> - Class in org.elasticsearch.common.settings
- Setting.GroupKey - Class in org.elasticsearch.common.settings
- Setting.Key - Interface in org.elasticsearch.common.settings
- Setting.ListKey - Class in org.elasticsearch.common.settings
- Setting.Property - Enum in org.elasticsearch.common.settings
- Setting.SimpleKey - Class in org.elasticsearch.common.settings
- Setting.Validator<T> - Interface in org.elasticsearch.common.settings
-
Represents a validator for a setting.
- settings - Variable in class org.elasticsearch.client.support.AbstractClient
- settings - Variable in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- settings - Variable in class org.elasticsearch.transport.RemoteClusterAware
- settings - Variable in class org.elasticsearch.transport.TcpTransport
- settings() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node settings be returned.
- settings() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Returns repository settings
- settings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns repository-specific snapshot settings
- settings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns repository-specific restore settings
- settings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- settings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with.
- settings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- settings() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Returns the
Settings
to update - settings() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- settings() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- settings() - Method in class org.elasticsearch.bootstrap.BootstrapContext
- settings() - Method in interface org.elasticsearch.client.Client
-
Returns this clients settings
- settings() - Method in class org.elasticsearch.client.support.AbstractClient
- settings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- settings() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Returns the merged transient and persistent settings.
- settings() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
-
Returns repository settings
- settings() - Method in interface org.elasticsearch.common.settings.Setting.Validator
-
The settings on which the validity of this setting depends.
- settings() - Method in class org.elasticsearch.env.Environment
-
The settings used to build this environment.
- settings() - Method in class org.elasticsearch.node.Node
-
The settings that are used by this node.
- settings(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node settings be returned.
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the repository settings.
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings in JSON or YAML format
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository-specific restore settings in JSON or YAML format
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with (either json or yaml format)
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated (either json or yaml format)
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with (either json/yaml format).
- settings(Map) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with (either json/yaml/properties format)
- settings(Map) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated (either json or yaml format)
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the repository settings.
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings.
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository-specific restore settings
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with (either json or yaml format).
- settings(Settings) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the repository settings
- settings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings.
- settings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository-specific restore settings.
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with.
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Sets the
Settings
to update - settings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with.
- settings(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- settings(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- settings(Settings) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- settings(Settings) - Method in class org.elasticsearch.repositories.RepositoriesService.RegisterRepositoryRequest
-
Sets repository settings
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the repository settings
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings.
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository-specific restore settings.
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with.
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with.
- settings(Settings.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- settings(Settings.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- settings(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Allows to set the settings using a json builder.
- Settings - Class in org.elasticsearch.common.settings
-
An immutable settings implementation.
- Settings() - Constructor for class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Generates default
SimpleQueryStringQueryParser.Settings
object (uses ROOT locale, does lowercase terms, no lenient parsing, no wildcard analysis). - Settings(SimpleQueryStringQueryParser.Settings) - Constructor for class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- SETTINGS - org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- SETTINGS - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- SETTINGS - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
- SETTINGS_FILTER_PARAM - Static variable in class org.elasticsearch.common.settings.SettingsFilter
-
Can be used to specify settings filter that will be used to filter out matching settings in toXContent method
- Settings.Builder - Class in org.elasticsearch.common.settings
-
A builder allowing to put different settings and then
Settings.Builder.build()
an immutable settings implementation. - SettingsBasedHostsProvider - Class in org.elasticsearch.discovery.zen
-
An implementation of
UnicastHostsProvider
that reads hosts/ports from the "discovery.zen.ping.unicast.hosts" node setting. - SettingsBasedHostsProvider(Settings, TransportService) - Constructor for class org.elasticsearch.discovery.zen.SettingsBasedHostsProvider
- SettingsException - Exception in org.elasticsearch.common.settings
-
A generic failure to handle settings.
- SettingsException(String) - Constructor for exception org.elasticsearch.common.settings.SettingsException
- SettingsException(String, Object...) - Constructor for exception org.elasticsearch.common.settings.SettingsException
- SettingsException(String, Throwable) - Constructor for exception org.elasticsearch.common.settings.SettingsException
- SettingsException(StreamInput) - Constructor for exception org.elasticsearch.common.settings.SettingsException
- SettingsFilter - Class in org.elasticsearch.common.settings
-
A class that allows to filter settings objects by simple regular expression patterns or full settings keys.
- SettingsFilter(Collection<String>) - Constructor for class org.elasticsearch.common.settings.SettingsFilter
- settingsKey(String, String) - Static method in class org.elasticsearch.threadpool.ExecutorBuilder
- SettingsModule - Class in org.elasticsearch.common.settings
-
A module that binds the provided settings to the
Settings
interface. - SettingsModule(Settings, List<Setting<?>>, List<String>, Set<SettingUpgrader<?>>) - Constructor for class org.elasticsearch.common.settings.SettingsModule
- SettingsModule(Settings, Setting<?>...) - Constructor for class org.elasticsearch.common.settings.SettingsModule
- settingsVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- settingsVersion(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- SettingUpgrader<T> - Interface in org.elasticsearch.common.settings
-
Represents the logic to upgrade a setting.
- setTokenizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Instead of setting the analyzer, sets the tokenizer as name that will be used as part of a custom analyzer.
- setTokenizer(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Instead of setting the analyzer, sets the tokenizer using custom settings that will be used as part of a custom analyzer.
- setTookInMillis(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setTotal(long) - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- setTotal(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setTotalOperations(int) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- setTrackScores(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Applies when sorting, and controls if scores will be tracked as well.
- setTrackScores(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setTrackTotalHits(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicates if the total hit count for the query should be tracked.
- setTragicException(Exception) - Method in class org.elasticsearch.index.translog.TragicExceptionHolder
-
Sets the tragic exception or if the tragic exception is already set adds passed exception as suppressed exception
- setTransientSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the source containing the transient settings to be updated.
- setTransientSettings(Map) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the transient settings to be updated.
- setTransientSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the transient settings to be updated.
- setTransientSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the transient settings to be updated.
- setTranslog(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setTranslogGenerationOfLastCommit(long) - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
-
Sets the translog generation of the last index commit.
- setTransport(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node Transport info be returned.
- setTransport(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node Transport stats be returned.
- setTranspositions(boolean) - Method in class org.elasticsearch.index.search.MatchQuery
- setTranspositions(boolean) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets if transpositions (swapping one character for another) counts as one character change or two.
- setTree(String) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- setTree(String) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- setTreeLevels(int) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- setTreeLevels(int) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- setType(String) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setType(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository type
- setType(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The type of the mappings.
- setType(String) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the type of the document to delete.
- setType(String) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setType(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the type to get a score explanation for.
- setType(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the type of the document to fetch.
- setType(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the type to index the document to.
- setType(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the type of the document.
- setType(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the type of the indexed document.
- setType(MultiMatchQueryBuilder.Type) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setTypes(String...) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
- setTypes(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- setTypes(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
Document types to return stats for.
- setTypes(String...) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
The types of documents the query will run against.
- setTypes(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The document types to execute the search against.
- setTypes(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- setTypes(String...) - Method in class org.elasticsearch.index.query.QueryShardContext
- setUid(Uid) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- setUnicodeAware(boolean) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Set to true if all measurements (like edit distance, transpositions and lengths) are in unicode code points (actual letters) instead of bytes.
- setUnlikeFields(Fields...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setUnlikeText(String[]) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setUpdateAllTypes(boolean) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Deprecated.useless with 6.x indices which may only have one type
- setUpdateAllTypes(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
Deprecated.useless with 6.x indices which may only have one type
- setUpdated(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.Builder
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.Builder
-
Deprecated.
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- setUpgradeInProgress(boolean, boolean) - Method in class org.elasticsearch.index.shard.ElasticsearchMergePolicy
-
When
upgrade
is true, running a force merge will upgrade any segments written with older versions. - setUpgradeOnlyAncientSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequestBuilder
-
Should the upgrade only the ancient (older major version of Lucene) segments?
- setupHunspellDictionaries(List<AnalysisPlugin>) - Method in class org.elasticsearch.indices.analysis.AnalysisModule
- setupInnerHitsContext(QueryShardContext, InnerHitsContext.InnerHitSubContext) - Method in class org.elasticsearch.index.query.InnerHitContextBuilder
- setupParser(String, TriFunction<List<TaskInfo>, List<TaskOperationFailure>, List<ElasticsearchException>, T>) - Static method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- setUpsert(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(byte[], XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(Object...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(String, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(Map) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(Map, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the index request to be used if the document does not exists.
- setUpsert(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(XContentType, Object...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setValidationMethod(GeoValidationMethod) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Specify whether or not to ignore validation errors of bounding boxes.
- setValidationMethod(GeoValidationMethod) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Set validation method for geo coordinates.
- setValidationMethod(GeoValidationMethod) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Sets the validation method to use for geo coordinates.
- setValue(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- setValueAsString(String) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- setVerbose(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Set to
false
to only show the snapshot names and the indices they contain. - setVerbose(boolean) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
- setVerbose(boolean) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- setVerbose(boolean) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Enable or disable verbose mode
- setVerify(boolean) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets whether or not repository should be verified after creation
- setVersion(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should each
SearchHit
be returned with its version. - setVersion(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setVersion(long) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the version, which will cause the delete operation to only be performed if a matching version exists and no changes happened on the doc since then.
- setVersion(long) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the version, which will cause the get operation to only be performed if a matching version exists and no changes happened on the doc since then.
- setVersion(long) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the version, which will cause the index operation to only be performed if a matching version exists and no changes happened on the doc since then.
- setVersion(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
- setVersion(long) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the version, which will cause the index operation to only be performed if a matching version exists and no changes happened on the doc since then.
- setVersion(Integer) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the optional version of this template.
- setVersion(Long) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Set the version of the node on the other side of this stream.
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Set the version of the node on the other side of this stream.
- setVersionConflicts(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setVersions(Map<String, Tuple<Version, String>>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequestBuilder
-
Sets the index versions to be updated
- setVersionType(VersionType) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the type of versioning to use.
- setVersionType(VersionType) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the versioning type.
- setVersionType(VersionType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the versioning type.
- setVersionType(VersionType) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
- setVersionType(VersionType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the versioning type.
- setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
A shortcut for
ClusterHealthRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
A shortcut for
CreateIndexRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
-
A shortcut for
OpenIndexRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
A shortcut for
ResizeRequest.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
-
A shortcut for
ResizeRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
A shortcut for
BulkRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
A shortcut for
ReplicationRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
A shortcut for
UpdateRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
A shortcut for
AbstractBulkByScrollRequest.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
Sets the number of shard copies that must be active before getting the health status.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the number of shard copies that should be active for index creation to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
-
Sets the number of shard copies that should be active for indices opening to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Sets the number of shard copies that should be active for creation of the new shrunken index to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
-
Sets the number of shard copies that should be active for creation of the new shrunken index to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Sets the number of shard copies that must be active before proceeding with the write.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
Sets the number of shard copies that must be active before proceeding with the write.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the number of shard copies that must be active before proceeding with the write.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Sets the number of shard copies that must be active before proceeding with the write.
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Should this request wait for all found tasks to complete?
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequestBuilder
-
Should this request wait for all found tasks to complete?
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Should this request wait for all found tasks to complete?
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequestBuilder
-
Should this request wait for all found tasks to complete?
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
If set to true the request should wait for the snapshot completion before returning.
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If this parameter is set to true the operation will wait for completion of restore process before returning.
- setWaitForEvents(Priority) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setWaitForGreenStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setWaitForNodes(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
Waits for N number of nodes.
- setWaitForNoInitializingShards(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
Sets whether the request should wait for there to be no initializing shards before retrieving the cluster health status.
- setWaitForNoRelocatingShards(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
Sets whether the request should wait for there to be no relocating shards before retrieving the cluster health status.
- setWaitForStatus(ClusterHealthStatus) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setWaitForYellowStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setWaitIfOngoing(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
- setWarmer(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setWeight(float) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Set the weight applied to the function before combining.
- setWindow(int) - Method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovFnPipelineAggregationBuilder
-
Sets the window size for this aggregation
- setWorker(float, Integer) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Sets this task to be a worker task that performs search requests
- setWorkerCount(int) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Sets this task to be a leader task for
slices
sliced subtasks - setZeroTermsQuery(MatchQuery.ZeroTermsQuery) - Method in class org.elasticsearch.index.search.MatchQuery
- sha1() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Returns a
MessageDigest
instance for SHA-1 digests; note that the instance returned is thread local and must not be shared amongst threads. - sha256() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Returns a
MessageDigest
instance for SHA-256 digests; note that the instance returned is thread local and must not be shared amongst threads. - shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Create a shallow copy of this builder and replacing
AggregationBuilder.factoriesBuilder
andmetaData
. - shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.mad.MedianAbsoluteDeviationAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- shape() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- shape(ShapeBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- ShapeBuilder<T extends org.locationtech.spatial4j.shape.Shape,E extends ShapeBuilder<T,E>> - Class in org.elasticsearch.common.geo.builders
-
Basic class for building GeoJSON shapes like Polygons, Linestrings, etc
- ShapeBuilder() - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder
-
default ctor
- ShapeBuilder(List<Coordinate>) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder
-
ctor from list of coordinates
- ShapeBuilder(StreamInput) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder
-
ctor from serialized stream input
- ShapeBuilder.Edge - Class in org.elasticsearch.common.geo.builders
-
This helper class implements a linked list for
Coordinate
. - ShapeBuilder.Orientation - Enum in org.elasticsearch.common.geo.builders
- ShapeBuilders - Class in org.elasticsearch.common.geo.builders
-
Deprecated.this class is replaced by each builder's constructor e.g. instead of using
ShapeBuilders.newMultiPoint
usenew MultiPointBuilder()
- ShapeBuilders() - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilders
-
Deprecated.
- shapeName() - Method in enum org.elasticsearch.common.geo.GeoShapeType
- ShapeParser - Interface in org.elasticsearch.common.geo.parsers
-
first point of entry for a shape parser
- ShapeRelation - Enum in org.elasticsearch.common.geo
-
Enum representing the relationship between a Query / Filter Shape and indexed Shapes that will be used to determine if a Document should be matched or not
- ShapesAvailability - Class in org.elasticsearch.common.geo
- shard - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- shard() - Method in class org.elasticsearch.action.search.ShardSearchFailure
-
The search shard target the failure occurred on.
- shard() - Method in exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
-
Returns the shard instance referenced by this exception
- shard() - Method in exception org.elasticsearch.search.SearchException
- shard(int) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- shard(SearchShardTarget) - Method in class org.elasticsearch.search.SearchHit
- SHARD_BALANCE_FACTOR_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- SHARD_COUNT_LIMIT_SETTING - Static variable in class org.elasticsearch.action.search.TransportSearchAction
-
The maximum number of shards for a single search request.
- SHARD_FAILED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.shard.ShardStateAction
- SHARD_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- SHARD_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- SHARD_INACTIVE_TIME_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
If we see no indexing operations after this much time for a given shard, we consider that shard inactive (default: 5 minutes).
- SHARD_MEMORY_INTERVAL_TIME_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
How frequently we check indexing memory usage (default: 5 seconds).
- SHARD_MIN_DOC_COUNT_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- SHARD_PARSER - Static variable in class org.elasticsearch.cluster.health.ClusterIndexHealth
- SHARD_SIZE_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- SHARD_SIZE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- SHARD_STARTED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.shard.ShardStateAction
- ShardAllocationDecision - Class in org.elasticsearch.cluster.routing.allocation
-
Represents the decision taken for the allocation of a single shard.
- ShardAllocationDecision(AllocateUnassignedDecision, MoveDecision) - Constructor for class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- ShardAllocationDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- shardBitsetFilterCache() - Method in class org.elasticsearch.index.shard.IndexShard
- ShardBitsetFilterCache - Class in org.elasticsearch.index.cache.bitset
- ShardBitsetFilterCache(ShardId, IndexSettings) - Constructor for class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
- ShardCoreKeyMap - Class in org.elasticsearch.common.lucene
-
A map between segment core cache keys and the shard that these segments belong to.
- ShardCoreKeyMap() - Constructor for class org.elasticsearch.common.lucene.ShardCoreKeyMap
- shardCountPerPath(Index) - Method in class org.elasticsearch.env.NodeEnvironment
-
Find all the shards for this index, returning a map of the
NodePath
to the number of shards on that path - shardExecute(Task, Request, ShardId, ActionListener<ShardResponse>) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetaDataUpdater
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- shardFailed(ShardRouting, UnassignedInfo) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when a shard is failed or cancelled.
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- ShardFailedClusterStateTaskExecutor(AllocationService, RoutingService, Logger) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardFailedClusterStateTaskExecutor
- ShardFailure(ShardRouting, String, Exception) - Constructor for class org.elasticsearch.index.shard.IndexShard.ShardFailure
- shardFailures() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- shardFailures() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns shard failures; an empty list will be returned if there were no shard failures, or if
SnapshotInfo.state()
returnsnull
. - ShardFetchRequest - Class in org.elasticsearch.search.fetch
-
Shard level fetch base request.
- ShardFetchRequest() - Constructor for class org.elasticsearch.search.fetch.ShardFetchRequest
- ShardFetchRequest(long, IntArrayList, ScoreDoc) - Constructor for class org.elasticsearch.search.fetch.ShardFetchRequest
- ShardFetchSearchRequest - Class in org.elasticsearch.search.fetch
-
Shard level fetch request used with search.
- ShardFetchSearchRequest() - Constructor for class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- ShardFetchSearchRequest(OriginalIndices, long, IntArrayList, ScoreDoc) - Constructor for class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- ShardFieldData - Class in org.elasticsearch.index.fielddata
- ShardFieldData() - Constructor for class org.elasticsearch.index.fielddata.ShardFieldData
- ShardFlushRequest - Class in org.elasticsearch.action.admin.indices.flush
- ShardFlushRequest() - Constructor for class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- ShardFlushRequest(FlushRequest, ShardId) - Constructor for class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- ShardGetService - Class in org.elasticsearch.index.get
- ShardGetService(IndexSettings, IndexShard, MapperService) - Constructor for class org.elasticsearch.index.get.ShardGetService
- shardId - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- shardId - Variable in class org.elasticsearch.action.ShardOperationFailedException
- shardId - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Target shard the request should execute on.
- shardId - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- shardId - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- shardId - Variable in class org.elasticsearch.gateway.AsyncShardFetch
- shardId - Variable in class org.elasticsearch.index.engine.Engine
- shardId - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- shardId - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- shardId - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- shardId() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- shardId() - Method in class org.elasticsearch.action.ShardOperationFailedException
-
The index the operation failed on.
- shardId() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- shardId() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- shardId() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- shardId() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Get the shard id
- shardId() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
Get the id of the shard which allocation should be canceled
- shardId() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- shardId() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the shards id
- shardId() - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
- shardId() - Method in interface org.elasticsearch.cluster.routing.ShardIterator
-
The shard id this group relates to.
- shardId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard id.
- shardId() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Returns the shard id this index belongs to.
- shardId() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
-
Returns the shard id this segment belongs to.
- shardId() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- shardId() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- shardId() - Method in interface org.elasticsearch.index.shard.IndexShardComponent
- shardId() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Returns the shard id of this shard.
- shardId() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- shardId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- shardId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- shardId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryFinalizeRecoveryRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryWaitForClusterStateRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- shardId() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- shardId() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- shardId() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- shardId() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- shardId() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- shardId(ClusterState, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- ShardId - Class in org.elasticsearch.index.shard
-
Allows for shard level components to be injected with the shard id.
- ShardId(String, String, int) - Constructor for class org.elasticsearch.index.shard.ShardId
- ShardId(Index, int) - Constructor for class org.elasticsearch.index.shard.ShardId
- shardIds() - Method in class org.elasticsearch.index.IndexService
- ShardIndexWarmerService - Class in org.elasticsearch.index.warmer
- ShardIndexWarmerService(ShardId, IndexSettings) - Constructor for class org.elasticsearch.index.warmer.ShardIndexWarmerService
- shardInfo - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- ShardInfo() - Constructor for class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- ShardInfo(int, int, ReplicationResponse.ShardInfo.Failure...) - Constructor for class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetaDataUpdater
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- shardInitialized(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when unassigned shard is initialized.
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- ShardIterator - Interface in org.elasticsearch.cluster.routing
-
Allows to iterate over a set of shard instances (routing) within a shard id group.
- shardLock(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Tries to lock the given shards ID.
- shardLock(ShardId, long) - Method in class org.elasticsearch.env.NodeEnvironment
-
Tries to lock the given shards ID.
- ShardLock - Class in org.elasticsearch.env
-
A shard lock guarantees exclusive access to a shards data directory.
- ShardLock(ShardId) - Constructor for class org.elasticsearch.env.ShardLock
- ShardLockObtainFailedException - Exception in org.elasticsearch.env
-
Exception used when the in-memory lock for a shard cannot be obtained
- ShardLockObtainFailedException(StreamInput) - Constructor for exception org.elasticsearch.env.ShardLockObtainFailedException
- ShardLockObtainFailedException(ShardId, String) - Constructor for exception org.elasticsearch.env.ShardLockObtainFailedException
- ShardLockObtainFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.env.ShardLockObtainFailedException
- shardMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Returns the minimum document count required per term, per shard
- shardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
-
Set the minimum document count terms should have on the shard in order to appear in the response.
- shardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
-
Set the minimum document count terms should have on the shard in order to appear in the response.
- shardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set the minimum document count terms should have on the shard in order to appear in the response.
- ShardNotFoundException - Exception in org.elasticsearch.index.shard
- ShardNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotFoundException(ShardId) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotFoundException(ShardId, String, Object...) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotFoundException(ShardId, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotFoundException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotInPrimaryModeException - Exception in org.elasticsearch.index.shard
- ShardNotInPrimaryModeException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.ShardNotInPrimaryModeException
- ShardNotInPrimaryModeException(ShardId, IndexShardState) - Constructor for exception org.elasticsearch.index.shard.ShardNotInPrimaryModeException
- shardOperation(AnalyzeRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- shardOperation(ClearIndicesCacheRequest, ShardRouting) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- shardOperation(ForceMergeRequest, ShardRouting) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- shardOperation(GetFieldMappingsIndexRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- shardOperation(RecoveryRequest, ShardRouting) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- shardOperation(IndicesSegmentsRequest, ShardRouting) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- shardOperation(IndicesStatsRequest, ShardRouting) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- shardOperation(UpgradeStatusRequest, ShardRouting) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- shardOperation(UpgradeRequest, ShardRouting) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- shardOperation(ShardValidateQueryRequest, Task) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- shardOperation(ExplainRequest, ShardId) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- shardOperation(FieldCapabilitiesIndexRequest, ShardId) - Method in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesIndexAction
- shardOperation(GetRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportGetAction
- shardOperation(MultiGetShardRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- shardOperation(MultiTermVectorsShardRequest, ShardId) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- shardOperation(TermVectorsRequest, ShardId) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- shardOperation(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- shardOperation(UpdateRequest, ActionListener<UpdateResponse>, int) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- shardOperation(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- shardOperation(Request, ShardRouting) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Executes the shard-level operation.
- shardOperation(Request, ShardId) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- shardOperation(ShardRequest, Task) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- ShardOperationFailedException - Class in org.elasticsearch.action
-
An exception indicating that a failure occurred performing an operation on the shard.
- ShardOperationFailedException() - Constructor for class org.elasticsearch.action.ShardOperationFailedException
- ShardOperationFailedException(String, int, String, RestStatus, Throwable) - Constructor for class org.elasticsearch.action.ShardOperationFailedException
- shardOperationOnPrimary(TransportVerifyShardBeforeCloseAction.ShardRequest, IndexShard) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- shardOperationOnPrimary(ShardFlushRequest, IndexShard) - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- shardOperationOnPrimary(BulkShardRequest, IndexShard) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- shardOperationOnPrimary(ResyncReplicationRequest, IndexShard) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- shardOperationOnPrimary(BasicReplicationRequest, IndexShard) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- shardOperationOnPrimary(GlobalCheckpointSyncAction.Request, IndexShard) - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- shardOperationOnPrimary(RetentionLeaseBackgroundSyncAction.Request, IndexShard) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- shardOperationOnPrimary(RetentionLeaseSyncAction.Request, IndexShard) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- shardOperationOnPrimary(Request, IndexShard) - Method in class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- shardOperationOnPrimary(Request, IndexShard) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Primary operation on node with primary copy.
- shardOperationOnPrimary(Request, IndexShard) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
-
Called on the primary with a reference to the primary IndexShard to modify.
- shardOperationOnReplica(TransportVerifyShardBeforeCloseAction.ShardRequest, IndexShard) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- shardOperationOnReplica(ShardFlushRequest, IndexShard) - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- shardOperationOnReplica(BulkShardRequest, IndexShard) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- shardOperationOnReplica(ResyncReplicationRequest, IndexShard) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- shardOperationOnReplica(BasicReplicationRequest, IndexShard) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- shardOperationOnReplica(GlobalCheckpointSyncAction.Request, IndexShard) - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- shardOperationOnReplica(RetentionLeaseBackgroundSyncAction.Request, IndexShard) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- shardOperationOnReplica(RetentionLeaseSyncAction.Request, IndexShard) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- shardOperationOnReplica(ReplicaRequest, IndexShard) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Synchronously execute the specified replica operation.
- shardOperationOnReplica(ReplicaRequest, IndexShard) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
-
Called once per replica with a reference to the replica IndexShard to modify.
- shardOperationOnReplica(Request, IndexShard) - Method in class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- shardPath() - Method in class org.elasticsearch.index.shard.IndexShard
- ShardPath - Class in org.elasticsearch.index.shard
- ShardPath(boolean, Path, Path, ShardId) - Constructor for class org.elasticsearch.index.shard.ShardPath
- shardRecoveryStates() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- ShardRequest(ShardId, ClusterBlock, TaskId) - Constructor for class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- ShardRequestCache - Class in org.elasticsearch.index.cache.request
-
Tracks the portion of the request cache in use for a particular shard.
- ShardRequestCache() - Constructor for class org.elasticsearch.index.cache.request.ShardRequestCache
- shardResponses() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- ShardRestoreStatus(String) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Constructs a new shard restore status in initializing state on the given node
- ShardRestoreStatus(String, RestoreInProgress.State) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Constructs a new shard restore status in with specified state on the given node
- ShardRestoreStatus(String, RestoreInProgress.State, String) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Constructs a new shard restore status in with specified state on the given node with specified failure reason
- shardRouting - Variable in class org.elasticsearch.index.shard.IndexShard
- ShardRouting - Class in org.elasticsearch.cluster.routing
-
ShardRouting
immutably encapsulates information about shard indexRoutings like id, state, version, etc. - ShardRouting(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.ShardRouting
- ShardRouting(ShardId, StreamInput) - Constructor for class org.elasticsearch.cluster.routing.ShardRouting
- shardRoutingChanged(IndexShard, ShardRouting, ShardRouting) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called when the shard routing has changed state.
- ShardRoutingState - Enum in org.elasticsearch.cluster.routing
-
Represents the current state of a
ShardRouting
as defined by the cluster. - shardRoutingTable(String, int) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All shards for the provided index and shard id
- shardRoutingTable(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All shards for the provided
ShardId
- shardRoutingTableOrNull(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- shards() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns list of shards that being restore and their status
- shards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- shards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of shards - shards() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- shards(Predicate<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- shards(ClusterState, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- shards(ClusterState, ClearIndicesCacheRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
-
The refresh request works against *all* shards.
- shards(ClusterState, ForceMergeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
-
The refresh request works against *all* shards.
- shards(ClusterState, RecoveryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- shards(ClusterState, IndicesSegmentsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
-
Segments goes across *all* active shards.
- shards(ClusterState, IndicesStatsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
-
Status goes across *all* shards.
- shards(ClusterState, UpgradeStatusRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
-
Getting upgrade stats from *all* active shards.
- shards(ClusterState, UpgradeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
-
The upgrade request works against *all* shards.
- shards(ClusterState, ValidateQueryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesIndexAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
Returns the candidate shards to execute the operation on or
null
the execute the operation locally (the node that received the request) - shards(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- shards(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
Should return an iterator with a single shard!
- shards(ClusterState, Request, String[]) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Determines the shards on which this operation will be executed on.
- shards(ClusterState, Request, String[]) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
-
Determines the shards this operation will be executed on.
- shards(Request, ClusterState) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- SHARDS - org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
- SHARDS - org.elasticsearch.cluster.routing.Preference
-
Route to specific shards
- SHARDS_ALLOCATOR_TYPE_SETTING - Static variable in class org.elasticsearch.cluster.ClusterModule
- ShardsAcknowledgedResponse - Class in org.elasticsearch.action.support.master
- ShardsAcknowledgedResponse() - Constructor for class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- ShardsAcknowledgedResponse(boolean, boolean) - Constructor for class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- ShardsAllocator - Interface in org.elasticsearch.cluster.routing.allocation.allocator
-
A
ShardsAllocator
is the main entry point for shard allocation on nodes in the cluster. - ShardSearchFailure - Class in org.elasticsearch.action.search
-
Represents a failure to search on a specific shard.
- ShardSearchFailure(Exception) - Constructor for class org.elasticsearch.action.search.ShardSearchFailure
- ShardSearchFailure(Exception, SearchShardTarget) - Constructor for class org.elasticsearch.action.search.ShardSearchFailure
- ShardSearchLocalRequest - Class in org.elasticsearch.search.internal
-
Shard level search request that gets created and consumed on the local node.
- ShardSearchLocalRequest(ShardId, int, SearchType, SearchSourceBuilder, String[], Boolean, AliasFilter, float, boolean, String[], String) - Constructor for class org.elasticsearch.search.internal.ShardSearchLocalRequest
- ShardSearchLocalRequest(ShardId, String[], long, AliasFilter) - Constructor for class org.elasticsearch.search.internal.ShardSearchLocalRequest
- ShardSearchRequest - Interface in org.elasticsearch.search.internal
-
Shard level request that represents a search.
- ShardSearchStats - Class in org.elasticsearch.index.search.stats
- ShardSearchStats() - Constructor for class org.elasticsearch.index.search.stats.ShardSearchStats
- ShardSearchTransportRequest - Class in org.elasticsearch.search.internal
-
Shard level search request that represents an actual search sent from the coordinating node to the nodes holding the shards where the query needs to be executed.
- ShardSearchTransportRequest() - Constructor for class org.elasticsearch.search.internal.ShardSearchTransportRequest
- ShardSearchTransportRequest(OriginalIndices, SearchRequest, ShardId, int, AliasFilter, float, long, String, String[]) - Constructor for class org.elasticsearch.search.internal.ShardSearchTransportRequest
- ShardSegments - Class in org.elasticsearch.action.admin.indices.segments
- ShardShuffler - Class in org.elasticsearch.cluster.routing
-
A shuffler for shards whose primary goal is to balance load.
- ShardShuffler() - Constructor for class org.elasticsearch.cluster.routing.ShardShuffler
- shardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- shardsIt() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
A shard iterator with just this shard in it.
- shardsIt(int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- ShardsIterator - Interface in org.elasticsearch.cluster.routing
-
Allows to iterate over unrelated shards.
- shardSize - Variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- shardSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- shardSize - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- shardSize() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- shardSize() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Get the max num docs to be returned from each shard.
- shardSize() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
-
Get the max num docs to be returned from each shard.
- shardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Returns the number of term buckets per shard that are currently configured
- shardSize() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the
SuggestionBuilder.shardSize()
parameter - shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Set the max num docs to be returned from each shard.
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
-
Set the max num docs to be returned from each shard.
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
-
Sets the shard_size - indicating the number of term buckets each shard will return to the coordinating node (the node that coordinates the search execution).
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
-
Sets the shard_size - indicating the number of term buckets each shard will return to the coordinating node (the node that coordinates the search execution).
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Sets the shard_size - indicating the number of term buckets each shard will return to the coordinating node (the node that coordinates the search execution).
- shardSize(Integer) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Sets the maximum number of suggested term to be retrieved from each individual shard.
- SHARDSIZE_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- ShardsLimitAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
limits the number of shards per node on a per index or node-wide basis. - ShardsLimitAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
- ShardSnapshotStatus(String) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- ShardSnapshotStatus(String, SnapshotsInProgress.State) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- ShardSnapshotStatus(String, SnapshotsInProgress.State, String) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- ShardSnapshotStatus(StreamInput) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- shardsRandomIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- shardsStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- ShardsSyncedFlushResult - Class in org.elasticsearch.indices.flush
-
Result for all copies of a shard
- ShardsSyncedFlushResult(ShardId, int, String) - Constructor for class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
-
failure constructor
- ShardsSyncedFlushResult(ShardId, String, int, Map<ShardRouting, SyncedFlushService.ShardSyncedFlushResponse>) - Constructor for class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
-
success constructor
- shardStarted(ShardRouting, long, String, ActionListener<Void>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
- shardStarted(ShardRouting, long, String, ActionListener<Void>, ClusterState) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetaDataUpdater
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- shardStarted(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when an initializing shard is started.
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- ShardStartedClusterStateTaskExecutor(AllocationService, Logger) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardStartedClusterStateTaskExecutor
- shardStateAction - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- ShardStateAction - Class in org.elasticsearch.cluster.action.shard
- ShardStateAction(ClusterService, TransportService, AllocationService, RoutingService, ThreadPool) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction
- ShardStateAction.FailedShardEntry - Class in org.elasticsearch.cluster.action.shard
- ShardStateAction.NoLongerPrimaryShardException - Exception in org.elasticsearch.cluster.action.shard
- ShardStateAction.ShardFailedClusterStateTaskExecutor - Class in org.elasticsearch.cluster.action.shard
- ShardStateAction.ShardStartedClusterStateTaskExecutor - Class in org.elasticsearch.cluster.action.shard
- ShardStateAction.StartedShardEntry - Class in org.elasticsearch.cluster.action.shard
- ShardStateMetaData - Class in org.elasticsearch.index.shard
- ShardStateMetaData(boolean, String, AllocationId) - Constructor for class org.elasticsearch.index.shard.ShardStateMetaData
- shardStatePathToDataPath(Path) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Returns the
NodePath.path
for this shard. - ShardStats - Class in org.elasticsearch.action.admin.indices.stats
- ShardStats() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- ShardStats(ShardRouting, ShardPath, CommonStats, CommitStats, SeqNoStats, RetentionLeaseStats) - Constructor for class org.elasticsearch.action.admin.indices.stats.ShardStats
- shardStatuses() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Returns the shard criteria to get store information on
- shardStatuses(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Set statuses to filter shards to get stores info on.
- ShardStoreInfo(long) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- ShardStoreInfo(String, boolean, Exception) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- ShardStoreInfo(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- shardStores(IndicesShardStoresRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The shard stores info of one or more indices.
- shardStores(IndicesShardStoresRequest, ActionListener<IndicesShardStoresResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The shard stores info of one or more indices.
- shardsWithState(String, ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Determine the shards of an index with a specific state
- shardsWithState(String, ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- shardsWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Returns a
List
of shards that match one of the states listed instates
- shardsWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- shardsWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Determine the shards with a specific state
- shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- ShardSyncedFlushRequest() - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- ShardSyncedFlushRequest(ShardId, String, Engine.CommitId) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- ShardSyncedFlushResponse() - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- ShardSyncedFlushResponse(String) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- shardTarget() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- shardTarget() - Method in class org.elasticsearch.search.internal.SearchContext
- ShardToolCli - Class in org.elasticsearch.index.shard
-
Class encapsulating and dispatching commands from the
elasticsearch-shard
command line tool - ShardUpgradeRequest - Class in org.elasticsearch.action.admin.indices.upgrade.post
- ShardUpgradeRequest() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.ShardUpgradeRequest
- ShardUpgradeStatus - Class in org.elasticsearch.action.admin.indices.upgrade.get
- ShardUtils - Class in org.elasticsearch.index.shard
- ShardValidateQueryRequest - Class in org.elasticsearch.action.admin.indices.validate.query
-
Internal validate request executed directly against a specific index shard.
- ShardValidateQueryRequest() - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- ShardValidateQueryRequest(ShardId, AliasFilter, ValidateQueryRequest) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- sharedDataFile() - Method in class org.elasticsearch.env.Environment
-
The shared data location
- sharedDataPath() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns shared data path for this node environment
- shell() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- shift(Coordinate, double) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- ShingleTokenFilterFactory - Class in org.elasticsearch.index.analysis
- ShingleTokenFilterFactory(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
- ShingleTokenFilterFactory.Factory - Class in org.elasticsearch.index.analysis
- SHORT - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- SHORT - org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- shortHash() - Method in class org.elasticsearch.Build
- shortSummary() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- shortSummary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
A short description of the shard.
- shortSummary() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- shortSummary() - Method in class org.elasticsearch.common.StopWatch
-
Return a short description of the total running time.
- shortToBytes(int) - Static method in class org.elasticsearch.common.Numbers
-
Converts an int to a byte array.
- should() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Gets the list of clauses that should be matched by the returned documents.
- should(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Adds a clause that should be matched by the returned documents.
- shouldAutoCreate(String, ClusterState) - Method in class org.elasticsearch.action.support.AutoCreateIndex
-
Should the index be auto created?
- shouldBootstrapNewHistoryUUID() - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- shouldBootstrapNewHistoryUUID() - Method in class org.elasticsearch.cluster.routing.RecoverySource
- shouldCancelChildrenOnCancellation() - Method in class org.elasticsearch.action.search.SearchTask
- shouldCancelChildrenOnCancellation() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
- shouldCancelChildrenOnCancellation() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- shouldCancelChildrenOnCancellation() - Method in class org.elasticsearch.tasks.CancellableTask
-
Returns true if this task can potentially have children that need to be cancelled when it parent is cancelled.
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
-
This method should be overridden by subclasses that want to defer calculation of a child aggregation until a first pass is complete and a set of buckets has been pruned.
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- shouldIgnoreOrRejectNewClusterState(Logger, ClusterState, ClusterState) - Static method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
In the case we follow an elected master the new cluster state needs to have the same elected master and the new cluster state version needs to be equal or higher than our cluster state version.
- shouldIgnoreShardForNode(ShardId, String) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns whether the given node id should be ignored from consideration when
AllocationDeciders
is deciding whether to allocate the specified shard id to that node. - shouldPeriodicallyFlush() - Method in class org.elasticsearch.index.engine.Engine
-
Checks if this engine should be flushed periodically.
- shouldPeriodicallyFlush() - Method in class org.elasticsearch.index.engine.InternalEngine
- shouldPeriodicallyFlush() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- shouldRollGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Tests whether or not the translog generation should be rolled to a new generation.
- shouldRollTranslogGeneration() - Method in class org.elasticsearch.index.engine.Engine
-
Tests whether or not the translog generation should be rolled to a new generation.
- shouldRollTranslogGeneration() - Method in class org.elasticsearch.index.engine.InternalEngine
- shouldRollTranslogGeneration() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- shouldSerialize(StreamOutput, T) - Static method in interface org.elasticsearch.cluster.ClusterState.FeatureAware
-
Tests whether or not the custom should be serialized.
- shouldUseFilterForMultitermQueries() - Method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Can this
TokenFilter
be used in multi-term queries? - shouldUseFilterForMultitermQueries() - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Can this
TokenFilter
be used in multi-term queries? - SHOW_TERM_DOC_COUNT_ERROR - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- showDocCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- showTermDocCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- showTermDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Get whether doc count error will be return for individual terms
- showTermDocCountError(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set whether doc count error will be return for individual terms
- SHRINK - org.elasticsearch.action.admin.indices.shrink.ResizeType
- ShrinkAction - Class in org.elasticsearch.action.admin.indices.shrink
- shuffle() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- shuffle(List<?>) - Static method in class org.elasticsearch.common.Randomness
- shuffle(List<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.ShardShuffler
-
Equivalent to calling
shuffle(shards, nextSeed())
. - shuffle(List<ShardRouting>, int) - Method in class org.elasticsearch.cluster.routing.RotationShardShuffler
- shuffle(List<ShardRouting>, int) - Method in class org.elasticsearch.cluster.routing.ShardShuffler
-
Return a shuffled view over the list of shards.
- shutdown() - Method in class org.elasticsearch.threadpool.ThreadPool
- shutdown(EsThreadPoolExecutor.ShutdownListener) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- shutdownNow() - Method in class org.elasticsearch.threadpool.ThreadPool
- SiblingPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- SiblingPipelineAggregator(String, String[], Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
- SiblingPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
-
Read from a stream.
- sigma() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- sigma() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
-
Get the value of sigma to use when calculating the standard deviation bounds
- sigma(double) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregationBuilder
- sigma(double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregationBuilder
-
Set the value of sigma to use when calculating the standard deviation bounds
- SIGMA_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
- significanceHeuristic - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- significanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- significanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- significanceHeuristic(SignificanceHeuristic) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- significanceHeuristic(SignificanceHeuristic) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- SignificanceHeuristic - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
Heuristic for that
SignificantTerms
uses to pick out significant terms. - SignificanceHeuristic() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristic
- SignificanceHeuristicBuilder - Interface in org.elasticsearch.search.aggregations.bucket.significant.heuristics
- SignificanceHeuristicParser - Interface in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
Parses
SignificanceHeuristic
s from anXContentParser
. - SignificantLongTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
-
Result of the running the significant terms aggregation on a numeric field.
- SignificantLongTerms(String, int, long, List<PipelineAggregator>, Map<String, Object>, DocValueFormat, long, long, SignificanceHeuristic, List<SignificantLongTerms.Bucket>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
- SignificantLongTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
-
Read from a stream.
- SignificantLongTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.significant
- SignificantLongTermsAggregator(String, AggregatorFactories, ValuesSource.Numeric, DocValueFormat, TermsAggregator.BucketCountThresholds, SearchContext, Aggregator, SignificanceHeuristic, SignificantTermsAggregatorFactory, IncludeExclude.LongFilter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
- significantlySmallerThanSinglePackedOrdinals(int, int, long, float) - Static method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
-
Return true if this impl is going to be smaller than
SinglePackedOrdinals
by at least 20%. - SignificantStringTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
-
Result of the running the significant terms aggregation on a String field.
- SignificantStringTerms(String, int, long, List<PipelineAggregator>, Map<String, Object>, DocValueFormat, long, long, SignificanceHeuristic, List<SignificantStringTerms.Bucket>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
- SignificantStringTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
-
Read from a stream.
- SignificantStringTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.significant
- SignificantStringTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.significant
-
An aggregator of significant string values.
- SignificantStringTermsAggregator(String, AggregatorFactories, ValuesSource, DocValueFormat, TermsAggregator.BucketCountThresholds, IncludeExclude.StringFilter, SearchContext, Aggregator, SignificanceHeuristic, SignificantTermsAggregatorFactory, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
- significantTerms(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
SignificantTerms
aggregation with the given name. - SignificantTerms - Interface in org.elasticsearch.search.aggregations.bucket.significant
-
An aggregation that collects significant terms in comparison to a background set.
- SignificantTerms.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.significant
- SignificantTermsAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant
- SignificantTermsAggregationBuilder(String, ValueType) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- SignificantTermsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
-
Read from a Stream.
- SignificantTermsAggregationBuilder(SignificantTermsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- SignificantTermsAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.significant
- SignificantTermsAggregatorFactory(String, ValuesSourceConfig<ValuesSource>, IncludeExclude, String, QueryBuilder, TermsAggregator.BucketCountThresholds, SignificanceHeuristic, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
- SignificantTermsAggregatorFactory.ExecutionMode - Enum in org.elasticsearch.search.aggregations.bucket.significant
- SignificantTermsHeuristicScoreScript - Class in org.elasticsearch.script
-
A script used in significant terms heuristic scoring.
- SignificantTermsHeuristicScoreScript() - Constructor for class org.elasticsearch.script.SignificantTermsHeuristicScoreScript
- SignificantTermsHeuristicScoreScript.Factory - Interface in org.elasticsearch.script
- significantText(String, String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
SignificantTextAggregationBuilder
aggregation with the given name and text field name - SignificantTextAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant
- SignificantTextAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- SignificantTextAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
-
Read from a stream.
- SignificantTextAggregationBuilder(SignificantTextAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- SignificantTextAggregator - Class in org.elasticsearch.search.aggregations.bucket.significant
- SignificantTextAggregator(String, AggregatorFactories, SearchContext, Aggregator, List<PipelineAggregator>, TermsAggregator.BucketCountThresholds, IncludeExclude.StringFilter, SignificanceHeuristic, SignificantTextAggregatorFactory, String, String[], boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregator
- SignificantTextAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.significant
- SignificantTextAggregatorFactory(String, IncludeExclude, QueryBuilder, TermsAggregator.BucketCountThresholds, SignificanceHeuristic, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, String, String[], boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregatorFactory
- similarity() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- similarity(MapperService) - Method in class org.elasticsearch.index.similarity.SimilarityService
- similarity(SimilarityProvider) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- SIMILARITY_SETTINGS_PREFIX - Static variable in class org.elasticsearch.index.IndexModule
- similarityLookupService() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- SimilarityProvider - Class in org.elasticsearch.index.similarity
-
Wrapper around a
Similarity
and its name. - SimilarityProvider(String, Similarity) - Constructor for class org.elasticsearch.index.similarity.SimilarityProvider
- SimilarityScript - Class in org.elasticsearch.script
-
A script that is used to build
ScriptedSimilarity
instances. - SimilarityScript() - Constructor for class org.elasticsearch.script.SimilarityScript
- SimilarityScript.Factory - Interface in org.elasticsearch.script
- similarityService() - Method in class org.elasticsearch.index.IndexService
- similarityService() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- similarityService() - Method in class org.elasticsearch.search.internal.SearchContext
- SimilarityService - Class in org.elasticsearch.index.similarity
- SimilarityService(IndexSettings, ScriptService, Map<String, TriFunction<Settings, Version, ScriptService, Similarity>>) - Constructor for class org.elasticsearch.index.similarity.SimilarityService
- SimilarityWeightScript - Class in org.elasticsearch.script
-
A script that is used to compute scoring factors that are the same for all documents.
- SimilarityWeightScript() - Constructor for class org.elasticsearch.script.SimilarityWeightScript
- SimilarityWeightScript.Factory - Interface in org.elasticsearch.script
- Simple() - Constructor for class org.elasticsearch.action.support.ActionFilter.Simple
- SIMPLE - org.elasticsearch.index.mapper.DynamicTemplate.MatchType
- SIMPLE - org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- SimpleAnalyzerProvider - Class in org.elasticsearch.index.analysis
- SimpleAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SimpleAnalyzerProvider
- SimpleFragmentsBuilder - Class in org.elasticsearch.search.fetch.subphase.highlight
-
Direct Subclass of Lucene's org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder that corrects offsets for broken analysis chains.
- SimpleFragmentsBuilder(MappedFieldType, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SimpleFragmentsBuilder
- SIMPLEFS - org.elasticsearch.index.IndexModule.Type
- SimpleKey(String) - Constructor for class org.elasticsearch.common.settings.Setting.SimpleKey
- SimpleMappedFieldType - Class in org.elasticsearch.index.mapper
-
MappedFieldType
base impl for field types that are neither dates nor ranges. - SimpleMappedFieldType() - Constructor for class org.elasticsearch.index.mapper.SimpleMappedFieldType
- SimpleMappedFieldType(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.SimpleMappedFieldType
- simpleMatch(String[], String) - Static method in class org.elasticsearch.common.regex.Regex
-
Match a String against the given patterns, supporting the following simple pattern styles: "xxx*", "*xxx", "*xxx*" and "xxx*yyy" matches (with an arbitrary number of pattern parts), as well as direct equality.
- simpleMatch(String[], String[]) - Static method in class org.elasticsearch.common.regex.Regex
- simpleMatch(String, String) - Static method in class org.elasticsearch.common.regex.Regex
-
Match a String against the given pattern, supporting the following simple pattern styles: "xxx*", "*xxx", "*xxx*" and "xxx*yyy" matches (with an arbitrary number of pattern parts), as well as direct equality.
- simpleMatch(List<String>, String) - Static method in class org.elasticsearch.common.regex.Regex
-
Similar to
Regex.simpleMatch(String[], String)
, but accepts a list of strings instead of an array of strings for the patterns to match. - simpleMatchToAutomaton(String) - Static method in class org.elasticsearch.common.regex.Regex
-
Return an
Automaton
that matches the given pattern. - simpleMatchToAutomaton(String...) - Static method in class org.elasticsearch.common.regex.Regex
-
Return an Automaton that matches the union of the provided patterns.
- simpleMatchToFullName(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Returns all the fields that match the given pattern.
- simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.query.QueryShardContext
-
Returns all the fields that match a given pattern.
- SimpleModel - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
-
Calculate a simple unweighted (arithmetic) moving average
- SimpleModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- SimpleModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
-
Read from a stream.
- SimpleModel.SimpleModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
- SimpleModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel.SimpleModelBuilder
- simpleName() - Method in class org.elasticsearch.index.mapper.Mapper
-
Returns the simple name, which identifies this mapper against other mappers at the same level in the mappers hierarchy TODO: make this protected once Mapper and FieldMapper are merged together
- SimpleQueryStringBuilder - Class in org.elasticsearch.index.query
-
SimpleQuery is a query parser that acts similar to a query_string query, but won't throw exceptions for any weird string syntax.
- SimpleQueryStringBuilder(String) - Constructor for class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Construct a new simple query with this query string.
- SimpleQueryStringBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Read from a stream.
- SimpleQueryStringFlag - Enum in org.elasticsearch.index.query
-
Flags for the XSimpleQueryString parser
- simpleQueryStringQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that acts similar to a query_string query, but won't throw exceptions for any weird string syntax.
- SimpleQueryStringQueryParser - Class in org.elasticsearch.index.search
-
Wrapper class for Lucene's SimpleQueryStringQueryParser that allows us to redefine different types of queries.
- SimpleQueryStringQueryParser(Map<String, Float>, int, SimpleQueryStringQueryParser.Settings, QueryShardContext) - Constructor for class org.elasticsearch.index.search.SimpleQueryStringQueryParser
-
Creates a new parser with custom flags used to enable/disable certain features.
- SimpleQueryStringQueryParser(Analyzer, Map<String, Float>, int, SimpleQueryStringQueryParser.Settings, QueryShardContext) - Constructor for class org.elasticsearch.index.search.SimpleQueryStringQueryParser
-
Creates a new parser with custom flags used to enable/disable certain features.
- SimpleQueryStringQueryParser.Settings - Class in org.elasticsearch.index.search
-
Class encapsulating the settings for the SimpleQueryString query, with their default values
- simpleString(String, String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance with a String value
- simpleString(String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- simpleString(String, Setting.Validator<String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- simpleString(String, Setting<String>, Function<String, String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- simpleString(String, Setting<String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- SimpleValue - Interface in org.elasticsearch.search.aggregations.pipeline
- simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity
- SimulatedAnealingMinimizer - Class in org.elasticsearch.search.aggregations.pipeline.movavg
-
A cost minimizer which will fit a MovAvgModel to the data.
- SimulatedAnealingMinimizer() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.SimulatedAnealingMinimizer
- SimulateDocumentBaseResult - Class in org.elasticsearch.action.ingest
-
Holds the end result of what a pipeline did to sample document provided via the simulate api.
- SimulateDocumentBaseResult(Exception) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- SimulateDocumentBaseResult(StreamInput) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
-
Read from a stream.
- SimulateDocumentBaseResult(IngestDocument) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- SimulateDocumentResult - Interface in org.elasticsearch.action.ingest
- SimulateDocumentVerboseResult - Class in org.elasticsearch.action.ingest
-
Holds the result of what a pipeline did to a sample document via the simulate api, but instead of
SimulateDocumentBaseResult
this result class holds the intermediate result each processor did to the sample document. - SimulateDocumentVerboseResult(List<SimulateProcessorResult>) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- SimulateDocumentVerboseResult(StreamInput) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
-
Read from a stream.
- simulatePipeline(SimulatePipelineRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Simulates an ingest pipeline
- simulatePipeline(SimulatePipelineRequest, ActionListener<SimulatePipelineResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Simulates an ingest pipeline
- SimulatePipelineAction - Class in org.elasticsearch.action.ingest
- SimulatePipelineAction() - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineAction
- SimulatePipelineRequest - Class in org.elasticsearch.action.ingest
- SimulatePipelineRequest(BytesReference) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequest
-
Deprecated.use
SimulatePipelineRequest(BytesReference, XContentType)
that does not attempt content autodetection - SimulatePipelineRequest(BytesReference, XContentType) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequest
-
Creates a new request with the given source and its content type
- SimulatePipelineRequest.Fields - Class in org.elasticsearch.action.ingest
- SimulatePipelineRequestBuilder - Class in org.elasticsearch.action.ingest
- SimulatePipelineRequestBuilder(ElasticsearchClient, SimulatePipelineAction) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Create a new builder for
SimulatePipelineRequest
s - SimulatePipelineRequestBuilder(ElasticsearchClient, SimulatePipelineAction, BytesReference) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Deprecated.use
SimulatePipelineRequestBuilder(ElasticsearchClient, SimulatePipelineAction, BytesReference, XContentType)
to avoid content type auto-detection on the source bytes - SimulatePipelineRequestBuilder(ElasticsearchClient, SimulatePipelineAction, BytesReference, XContentType) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Create a new builder for
SimulatePipelineRequest
s - SimulatePipelineResponse - Class in org.elasticsearch.action.ingest
- SimulatePipelineResponse() - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineResponse
- SimulatePipelineResponse(String, boolean, List<SimulateDocumentResult>) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineResponse
- SimulatePipelineTransportAction - Class in org.elasticsearch.action.ingest
- SimulatePipelineTransportAction(Settings, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, NodeService) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineTransportAction
- SimulateProcessorResult - Class in org.elasticsearch.action.ingest
- SimulateProcessorResult(String, Exception) - Constructor for class org.elasticsearch.action.ingest.SimulateProcessorResult
- SimulateProcessorResult(String, IngestDocument) - Constructor for class org.elasticsearch.action.ingest.SimulateProcessorResult
- SimulateProcessorResult(String, IngestDocument, Exception) - Constructor for class org.elasticsearch.action.ingest.SimulateProcessorResult
- single(Decision.Type, String, String, Object...) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Creates a simple decision
- Single() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- Single(Decision.Type) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
-
Creates a new
Decision.Single
decision of a given type - Single(Decision.Type, String, String, Object...) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
-
Creates a new
Decision.Single
decision of a given type - SINGLE - org.elasticsearch.common.unit.SizeUnit
- SINGLE_INSTANCE_AND_SCOPE - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- SINGLE_MAPPING_NAME - Static variable in class org.elasticsearch.index.mapper.MapperService
- SingleBucketAggregation - Interface in org.elasticsearch.search.aggregations.bucket
-
A single bucket aggregation
- SingleBucketAggregator - Interface in org.elasticsearch.search.aggregations.bucket
-
A bucket aggregator that doesn't create new buckets.
- SingleFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
- SingleFieldsVisitor(String) - Constructor for class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- SingleNodeDiscovery - Class in org.elasticsearch.discovery.single
-
A discovery implementation where the only member of the cluster is the local node.
- SingleNodeDiscovery(Settings, TransportService, MasterService, ClusterApplier) - Constructor for class org.elasticsearch.discovery.single.SingleNodeDiscovery
- SingleObjectCache<T> - Class in org.elasticsearch.common.util
-
A very simple single object cache that allows non-blocking refresh calls triggered by expiry time.
- SingleObjectCache(TimeValue, T) - Constructor for class org.elasticsearch.common.util.SingleObjectCache
- SinglePackedOrdinals - Class in org.elasticsearch.index.fielddata.ordinals
- SinglePackedOrdinals(OrdinalsBuilder, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.SinglePackedOrdinals
- singles() - Method in class org.elasticsearch.common.unit.SizeValue
- SingleShardOperationRequestBuilder<Request extends SingleShardRequest<Request>,Response extends ActionResponse,RequestBuilder extends SingleShardOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.single.shard
- SingleShardOperationRequestBuilder(ElasticsearchClient, Action<Request, Response, RequestBuilder>, Request) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardOperationRequestBuilder
- SingleShardRequest<Request extends SingleShardRequest<Request>> - Class in org.elasticsearch.action.support.single.shard
- SingleShardRequest() - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
- SingleShardRequest(String) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
- singleton(String, boolean, boolean, Function<TokenStream, TokenStream>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Create a pre-configured token filter that may not vary at all.
- singleton(String, boolean, Function<Reader, Reader>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Create a pre-configured char filter that may not vary at all.
- singleton(String, boolean, Function<TokenStream, TokenStream>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Create a pre-configured token filter that may not vary at all.
- singleton(String, Supplier<Tokenizer>, Supplier<TokenFilterFactory>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
-
Create a pre-configured tokenizer that may not vary at all.
- singleton(BinaryDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a multi-valued view over the provided
BinaryDocValues
. - singleton(GeoPointValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a multi-valued view over the provided
GeoPointValues
. - singleton(NumericDoubleValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a multi-valued view over the provided
NumericDoubleValues
. - Singleton - Annotation Type in org.elasticsearch.common.inject
-
Apply this to implementation classes when you want only one instance (per
Injector
) to be reused for all injections for that binding. - SINGLETON - Static variable in class org.elasticsearch.common.inject.Scopes
-
One instance per
Injector
. - SINGLETON_ANNOTATION - Static variable in class org.elasticsearch.common.inject.internal.Scoping
- SINGLETON_INSTANCE - Static variable in class org.elasticsearch.common.inject.internal.Scoping
- singletonWithVersion(String, boolean, 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.
- singletonWithVersion(String, boolean, BiFunction<Reader, Version, Reader>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Create a pre-configured char filter that may not vary at all, provide access to the elasticsearch version
- singletonWithVersion(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.
- SingleValue(String, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
- SingleValue(String, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.SingleValue
- SingleValue(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
-
Read from a stream.
- size - Variable in class org.elasticsearch.index.translog.Translog.Location
- size - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
- size - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- size() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- size() - Method in class org.elasticsearch.action.termvectors.TermVectorsFields
- size() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Return the number of groups
- size() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the number of this shards instances.
- size() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- size() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- size() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns the number of routing nodes
- size() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns the size of the non-ignored unassigned shards
- size() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
The number of shard routing instances.
- size() - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- size() - Method in class org.elasticsearch.common.collect.EvictingQueue
- size() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- size() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- size() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- size() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- size() - Method in class org.elasticsearch.common.inject.internal.Errors
- size() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
-
Returns the current size of the buffer.
- size() - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Return the number of tracked segments.
- size() - Method in class org.elasticsearch.common.settings.Settings
-
Returns the number of settings in this settings object.
- size() - Method in interface org.elasticsearch.common.util.BigArray
-
Return the length of this array.
- size() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- size() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- size() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingCollection
-
the number of nodes for which there are known pings
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- size() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- size() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the number of files in this snapshot
- size() - Method in class org.elasticsearch.index.store.Store.RecoveryDiff
-
Returns the sum of the files in this diff.
- size() - Method in class org.elasticsearch.index.store.StoreStats
- size() - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
the number of ongoing recoveries
- size() - Method in class org.elasticsearch.script.DeprecationMap
- size() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- size() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- size() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Returns the number of term buckets currently configured
- size() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Gets the number of search hits to return.
- size() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the number of search hits to return.
- size() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- size() - Method in class org.elasticsearch.search.internal.SearchContext
- size() - Method in class org.elasticsearch.search.internal.SubSearchContext
- size() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- size() - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
- size() - Method in class org.elasticsearch.search.lookup.SourceLookup
- size() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns the maximum size of this results top docs.
- size() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
- size() - Method in class org.elasticsearch.search.suggest.Suggest
-
The number of suggestions in this
Suggest
result - size() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the
SuggestionBuilder.size()
parameter - size() - Method in class org.elasticsearch.transport.ConnectionManager
-
Returns the number of nodes this manager is connected to.
- size() - Method in class org.elasticsearch.transport.TransportRequestDeduplicator
- size(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
The maximum number of documents to attempt.
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
-
The number of composite buckets to return.
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
-
Sets the size - indicating how many term buckets should be returned (defaults to 10)
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
-
Sets the size - indicating how many term buckets should be returned (defaults to 10)
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Sets the size - indicating how many term buckets should be returned (defaults to 10)
- size(int) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
The number of search hits to return.
- size(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The number of search hits to return.
- size(int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- size(int) - Method in class org.elasticsearch.search.internal.SearchContext
- size(int) - Method in class org.elasticsearch.search.internal.SubSearchContext
- size(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
- size(int) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets the maximum suggestions to be returned per suggest text term.
- size(int) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Sets the maximum suggestions to be returned per suggest text term.
- size(Integer) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketsort.BucketSortPipelineAggregationBuilder
- size(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- SIZE_ALL_MATCHES - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- SIZE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SIZE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- SIZE_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- SIZE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- sizeActive() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- sizeActive() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
The number of active shard routing instances
- SizeBlockingQueue<E> - Class in org.elasticsearch.common.util.concurrent
-
A size based queue wrapping another blocking queue to provide (somewhat relaxed) capacity checks.
- SizeBlockingQueue(BlockingQueue<E>, int) - Constructor for class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- sizeInBytes - Variable in class org.elasticsearch.index.engine.Segment
- sizeInBytes() - Method in class org.elasticsearch.index.store.StoreStats
- sizeInBytes() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- sizeInBytes() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the size in bytes of the v files
- sizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogReader
- sizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogWriter
- sizeInBytesByMinGen(long) - Method in class org.elasticsearch.index.translog.Translog
-
Returns the size in bytes of the translog files at least the given generation
- SizeUnit - Enum in org.elasticsearch.common.unit
- SizeValue - Class in org.elasticsearch.common.unit
- SizeValue(long) - Constructor for class org.elasticsearch.common.unit.SizeValue
- SizeValue(long, SizeUnit) - Constructor for class org.elasticsearch.common.unit.SizeValue
- SizeValue(StreamInput) - Constructor for class org.elasticsearch.common.unit.SizeValue
- sizing(Recycler<T>, Recycler<T>, int) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Wrap two recyclers and forward to calls to
smallObjectRecycler
whensize < minSize
and todefaultRecycler
otherwise. - skip(int) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- skip(long) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- skip(long) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- skip(long) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- SKIP - org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
- skipDueToVersionConflict(VersionConflictEngineException, boolean, long, long) - Static method in class org.elasticsearch.index.engine.InternalEngine.IndexingStrategy
- skipDueToVersionConflict(VersionConflictEngineException, long, long, boolean) - Static method in class org.elasticsearch.index.engine.InternalEngine.DeletionStrategy
- skipDuplicates - Variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- skipDuplicates() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Returns whether duplicate suggestions should be filtered out.
- skipDuplicates(boolean) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Should duplicates be filtered or not.
- SKIPPED_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- skippedOperations() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
-
The number of operations have been skipped (overridden or trimmed) in the snapshot so far.
- skipSources(Class...) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns a binder that skips
classesToSkip
when identify the calling code. - skipSources(Class...) - Method in interface org.elasticsearch.common.inject.PrivateBinder
- skipTranslogRecovery() - Method in class org.elasticsearch.index.engine.Engine
-
Do not replay translog operations, but make the engine be ready.
- skipTranslogRecovery() - Method in class org.elasticsearch.index.engine.InternalEngine
- skipTranslogRecovery() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- slice() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the slice used to filter the search hits, the top hits and the aggregations.
- slice(int, int) - Method in class org.elasticsearch.common.bytes.ByteBufferReference
- slice(int, int) - Method in class org.elasticsearch.common.bytes.BytesArray
- slice(int, int) - Method in class org.elasticsearch.common.bytes.BytesReference
-
Slice the bytes from the
from
index up tolength
. - slice(int, int) - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- slice(int, int) - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- slice(String, long, long) - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- slice(SliceBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
- slice(SliceBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a filter that will restrict the search hits, the top hits and the aggregations to a slice of the results of the main query.
- SLICE - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SLICE_ID_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- SliceBuilder - Class in org.elasticsearch.search.slice
-
A slice builder allowing to split a scroll in multiple partitions.
- SliceBuilder(int, int) - Constructor for class org.elasticsearch.search.slice.SliceBuilder
- SliceBuilder(String, int, int) - Constructor for class org.elasticsearch.search.slice.SliceBuilder
- SliceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.slice.SliceBuilder
- SlicedInputStream - Class in org.elasticsearch.index.snapshots.blobstore
-
A
SlicedInputStream
is a logical concatenation one or more input streams. - SlicedInputStream(long) - Constructor for class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
Creates a new SlicedInputStream
- SliceQuery - Class in org.elasticsearch.search.slice
-
An abstract
Query
that defines an hash function to partition the documents in multiple slices. - SliceQuery(String, int, int) - Constructor for class org.elasticsearch.search.slice.SliceQuery
- SLICES_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- slop() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Get the slop factor for phrase queries.
- slop() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Get the slop factor for phrase queries.
- slop() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- slop() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- slop(int) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Sets a slop factor for phrase queries
- slop(int) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Sets a slop factor for phrase queries
- slop(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Set the phrase slop if evaluated to a phrase query type.
- SLOP - org.elasticsearch.index.query.SimpleQueryStringFlag
- SLOP_FIELD - Static variable in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- SlowLogLevel - Enum in org.elasticsearch.index
- smartNameFieldType(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- smartNameFieldType(String) - Method in class org.elasticsearch.search.internal.SearchContext
-
Looks up the given field, but does not restrict to fields in the types set on this context.
- SMOOTHING_MODEL_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- smoothingModel() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Gets the
SmoothingModel
- smoothingModel(SmoothingModel) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets an explicit smoothing model used for this suggester.
- SmoothingModel - Class in org.elasticsearch.search.suggest.phrase
- SmoothingModel() - Constructor for class org.elasticsearch.search.suggest.phrase.SmoothingModel
- snapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
The snapshot name
- snapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Returns repository name
- snapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns the name of the snapshot.
- snapshot() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns snapshot
- snapshot() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- snapshot() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- snapshot() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot id
- snapshot() - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
- snapshot() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- snapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets the snapshot name
- snapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Sets snapshot name
- snapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the name of the snapshot.
- snapshot(String, SnapshotId) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Retrieves snapshot from repository
- snapshot(Snapshot) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- Snapshot - Class in org.elasticsearch.snapshots
-
Basic information about a snapshot - a SnapshotId and the repository that the snapshot belongs to.
- Snapshot(String, SnapshotId) - Constructor for class org.elasticsearch.snapshots.Snapshot
-
Constructs a snapshot.
- Snapshot(StreamInput) - Constructor for class org.elasticsearch.snapshots.Snapshot
-
Constructs a snapshot from the stream input.
- SNAPSHOT - org.elasticsearch.cluster.metadata.MetaData.XContentContext
- SNAPSHOT - org.elasticsearch.cluster.routing.RecoverySource.Type
- SNAPSHOT - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SNAPSHOT_INFO_PARSER - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- SNAPSHOT_ONLY_FORMAT_PARAMS - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
- SnapshotCreationException - Exception in org.elasticsearch.snapshots
-
Thrown when snapshot creation fails completely
- SnapshotCreationException(String, SnapshotId, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotCreationException
- SnapshotCreationException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotCreationException
- SnapshotDeletionsInProgress - Class in org.elasticsearch.cluster
-
A class that represents the snapshot deletions that are in progress in the cluster.
- SnapshotDeletionsInProgress() - Constructor for class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- SnapshotDeletionsInProgress(StreamInput) - Constructor for class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- SnapshotDeletionsInProgress.Entry - Class in org.elasticsearch.cluster
-
A class representing a snapshot deletion request entry in the cluster state.
- SnapshotException - Exception in org.elasticsearch.snapshots
-
Generic snapshot exception
- SnapshotException(String, String, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(String, String, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(String, SnapshotId, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(Snapshot, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(Snapshot, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotFailedEngineException - Exception in org.elasticsearch.index.engine
- SnapshotFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.SnapshotFailedEngineException
- SnapshotFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.SnapshotFailedEngineException
- SnapshotFiles - Class in org.elasticsearch.index.snapshots.blobstore
-
Contains a list of files participating in a snapshot
- SnapshotFiles(String, List<BlobStoreIndexShardSnapshot.FileInfo>) - Constructor for class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
- snapshotId - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- snapshotId() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot id
- SnapshotId - Class in org.elasticsearch.snapshots
-
SnapshotId - snapshot name + snapshot UUID
- SnapshotId(String, String) - Constructor for class org.elasticsearch.snapshots.SnapshotId
-
Constructs a new snapshot
- SnapshotId(StreamInput) - Constructor for class org.elasticsearch.snapshots.SnapshotId
-
Constructs a new snapshot from a input stream
- SnapshotIndexShardStage - Enum in org.elasticsearch.action.admin.cluster.snapshots.status
- SnapshotIndexShardStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- SnapshotIndexStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Represents snapshot status of all shards in the index
- SnapshotIndexStatus(String, Map<Integer, SnapshotIndexShardStatus>, SnapshotShardsStats, SnapshotStats) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- SnapshotInfo - Class in org.elasticsearch.snapshots
-
Information about a snapshot
- SnapshotInfo(StreamInput) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
-
Constructs snapshot information from stream input
- SnapshotInfo(SnapshotId, List<String>, long, Boolean) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
- SnapshotInfo(SnapshotId, List<String>, long, String, long, int, List<SnapshotShardFailure>, Boolean) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
- SnapshotInfo(SnapshotId, List<String>, SnapshotState) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
- SnapshotInfo(SnapshotId, List<String>, SnapshotState, Version) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
- SnapshotInfo.SnapshotInfoBuilder - Class in org.elasticsearch.snapshots
- SnapshotInfoBuilder() - Constructor for class org.elasticsearch.snapshots.SnapshotInfo.SnapshotInfoBuilder
- SnapshotInProgressAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
prevents shards that are currently been snapshotted to be moved to other nodes. - SnapshotInProgressAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
- SnapshotInProgressException - Exception in org.elasticsearch.snapshots
-
Thrown on the attempt to execute an action that requires that no snapshot is in progress.
- SnapshotInProgressException(String) - Constructor for exception org.elasticsearch.snapshots.SnapshotInProgressException
- SnapshotInProgressException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotInProgressException
- SnapshotMissingException - Exception in org.elasticsearch.snapshots
-
Thrown if requested snapshot doesn't exist
- SnapshotMissingException(String, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
- SnapshotMissingException(String, SnapshotId, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
- SnapshotMissingException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
- SnapshotRecoverySource(String, Snapshot, Version, String) - Constructor for class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- SnapshotRestoreException - Exception in org.elasticsearch.snapshots
-
Snapshot restore exception
- SnapshotRestoreException(String, String, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
- SnapshotRestoreException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
- SnapshotRestoreException(Snapshot, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
- SnapshotRestoreException(Snapshot, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns the names of the snapshots.
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Returns the names of the snapshots.
- snapshots() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Returns list of snapshots
- snapshots(int) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- snapshots(String[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Sets the list of snapshots to be returned
- snapshots(String[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Sets the list of snapshots to be returned
- snapshots(String, List<SnapshotId>, Set<SnapshotId>, boolean) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Returns a list of snapshots from repository sorted by snapshot creation date
- snapshots(Snapshot[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- snapshotsFromXContent(XContentParser, long) - Static method in class org.elasticsearch.repositories.RepositoryData
-
Reads an instance of
RepositoryData
from x-content, loading the snapshots and indices metadata. - snapshotShard(IndexShard, Store, SnapshotId, IndexId, IndexCommit, IndexShardSnapshotStatus) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- snapshotShard(IndexShard, Store, SnapshotId, IndexId, IndexCommit, IndexShardSnapshotStatus) - Method in class org.elasticsearch.repositories.FilterRepository
- snapshotShard(IndexShard, Store, SnapshotId, IndexId, IndexCommit, IndexShardSnapshotStatus) - Method in interface org.elasticsearch.repositories.Repository
-
Creates a snapshot of the shard based on the index commit point.
- SnapshotShardFailure - Class in org.elasticsearch.snapshots
-
Stores information about failures that occurred during shard snapshotting process
- SnapshotShardFailure(String, ShardId, String) - Constructor for class org.elasticsearch.snapshots.SnapshotShardFailure
-
Constructs new snapshot shard failure object
- snapshotShards(String, RepositoryData, SnapshotInfo) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Returns status of shards currently finished snapshots
- SnapshotShardsService - Class in org.elasticsearch.snapshots
-
This service runs on data and master nodes and controls currently snapshotted shards on these nodes.
- SnapshotShardsService(Settings, ClusterService, SnapshotsService, ThreadPool, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.snapshots.SnapshotShardsService
- SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest - Class in org.elasticsearch.snapshots
-
Internal request that is used to send changes in snapshot status to master
- SnapshotShardsStats - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Status of a snapshot shards
- SnapshotShardsStats(int, int, int, int, int, int) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
- SnapshotsInProgress - Class in org.elasticsearch.cluster
-
Meta data about snapshots that are currently executing
- SnapshotsInProgress(List<SnapshotsInProgress.Entry>) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress
- SnapshotsInProgress(SnapshotsInProgress.Entry...) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress
- SnapshotsInProgress(StreamInput) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress
- SnapshotsInProgress.Entry - Class in org.elasticsearch.cluster
- SnapshotsInProgress.ShardSnapshotStatus - Class in org.elasticsearch.cluster
- SnapshotsInProgress.State - Enum in org.elasticsearch.cluster
- SnapshotsService - Class in org.elasticsearch.snapshots
-
Service responsible for creating snapshots
- SnapshotsService(Settings, ClusterService, IndexNameExpressionResolver, RepositoriesService, ThreadPool) - Constructor for class org.elasticsearch.snapshots.SnapshotsService
- snapshotsStatus(SnapshotsStatusRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- snapshotsStatus(SnapshotsStatusRequest, ActionListener<SnapshotsStatusResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- SnapshotsStatusAction - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Snapshots status action
- snapshotsStatusRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Get status of snapshots
- SnapshotsStatusRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Get snapshot status request
- SnapshotsStatusRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- SnapshotsStatusRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Constructs a new get snapshots request with given repository name
- SnapshotsStatusRequest(String, String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Constructs a new get snapshots request with given repository name and list of snapshots
- SnapshotsStatusRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Snapshots status request builder
- SnapshotsStatusRequestBuilder(ElasticsearchClient, SnapshotsStatusAction) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Constructs the new snapshot status request
- SnapshotsStatusRequestBuilder(ElasticsearchClient, SnapshotsStatusAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Constructs the new snapshot status request with specified repository
- SnapshotsStatusResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Snapshot status response
- SnapshotState - Enum in org.elasticsearch.snapshots
-
Represents the state that a snapshot can be in
- SnapshotStats - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- SnapshotStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Status of a snapshot
- snapshotStoreMetadata() - Method in class org.elasticsearch.index.shard.IndexShard
-
gets a
Store.MetadataSnapshot
for the current directory. - snapshotsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.repositories.RepositoryData
-
Writes the snapshots metadata and the related indices metadata to x-content, omitting the incompatible snapshots.
- SnapshotUtils - Class in org.elasticsearch.snapshots
-
Snapshot utilities
- SnapshotUtils() - Constructor for class org.elasticsearch.snapshots.SnapshotUtils
- Snippet - Class in org.apache.lucene.search.uhighlight
-
Represents a scored highlighted snippet.
- Snippet(String, float, boolean) - Constructor for class org.apache.lucene.search.uhighlight.Snippet
- SOFT_DELETES_FIELD - Static variable in class org.elasticsearch.common.lucene.Lucene
- SOFT_LIMIT_MAX_BUCKETS - Static variable in class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- sort - Variable in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
- sort - Variable in class org.elasticsearch.search.sort.SortAndFormats
- sort() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
Sort values that are stored between offsets
0
andSortingBinaryDocValues.count
ofSortingBinaryDocValues.values
. - sort() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
Sort values that are stored between offsets
0
andSortingNumericDocValues.count
ofSortingNumericDocValues.values
. - sort() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
-
Sort values that are stored between offsets
0
andSortingNumericDoubleValues.docValueCount()
ofSortingNumericDoubleValues.values
. - sort() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- sort() - Method in class org.elasticsearch.search.internal.SearchContext
- sort() - Method in class org.elasticsearch.search.internal.SubSearchContext
- sort() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- sort() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the sort setting.
- sort(double[], int) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sort(float[], int) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sort(long[], int) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sort(ObjectArrayList<byte[]>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sort(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Add a sort against the given field name.
- sort(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Add a sort against the given field name.
- sort(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets how to sort the suggest terms per suggest text token.
- sort(String, SortOrder) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Adds a sort against the given field name and the sort ordering.
- sort(String, SortOrder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a sort against the given field name and the sort ordering.
- sort(Comparator<? super T>) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- sort(Comparator<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- sort(Comparator<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- sort(BytesRefArray, int[]) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sort(SortAndFormats) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- sort(SortAndFormats) - Method in class org.elasticsearch.search.internal.SearchContext
- sort(SortAndFormats) - Method in class org.elasticsearch.search.internal.SubSearchContext
- sort(SortBuilder<?>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Adds a sort builder.
- sort(SortBuilder<?>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a sort builder.
- sort(SortBy) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- sort(SortBy) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets how to sort the suggest terms per suggest text token.
- SORT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SORT_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- SORT_MODE - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- sortableLongBitsToDoubles(SortedNumericDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Given a
SortedNumericDocValues
, return aSortedNumericDoubleValues
instance that will translate long values to doubles usingNumericUtils.sortableLongToDouble(long)
. - sortAddresses(List<InetAddress>) - Static method in class org.elasticsearch.common.network.NetworkUtils
-
Deprecated.remove this when multihoming is really correct
- sortAndDedup(ObjectArrayList<byte[]>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sortAndDedup(BytesRefArray, int[]) - Static method in class org.elasticsearch.common.util.CollectionUtils
- SortAndFormats - Class in org.elasticsearch.search.sort
- SortAndFormats(Sort, DocValueFormat[]) - Constructor for class org.elasticsearch.search.sort.SortAndFormats
- SortBuilder<T extends SortBuilder<T>> - Class in org.elasticsearch.search.sort
- SortBuilder() - Constructor for class org.elasticsearch.search.sort.SortBuilder
- SortBuilders - Class in org.elasticsearch.search.sort
-
A set of static factory methods for
SortBuilder
s. - SortBuilders() - Constructor for class org.elasticsearch.search.sort.SortBuilders
- SortBy - Enum in org.elasticsearch.search.suggest
-
An enum representing the valid sorting options
- sortComparator() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- sortComparator() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- SortedBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
A list of per-document binary values, sorted according to
BytesRef.compareTo(BytesRef)
. - SortedBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortedBinaryDocValues
- sortedDifference(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
-
The relative complement, or difference, of the specified left and right set, returned as a sorted set.
- SortedNumericDoubleValues - Class in org.elasticsearch.index.fielddata
-
Clone of
SortedNumericDocValues
for double values. - SortedNumericDoubleValues() - Constructor for class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Sole constructor.
- SortedNumericDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
FieldData backed by
LeafReader.getSortedNumericDocValues(String)
- SortedNumericDVIndexFieldData(Index, String, IndexNumericFieldData.NumericType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
- SortedSetDVBytesAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
-
An
AtomicFieldData
implementation that uses LuceneSortedSetDocValues
. - SortedSetDVOrdinalsIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- SortedSetDVOrdinalsIndexFieldData(IndexSettings, IndexFieldDataCache, String, CircuitBreakerService, Function<SortedSetDocValues, ScriptDocValues<?>>) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Returns the
SortField
to used for sorting. - sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointDVIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.UidIndexFieldData
- SortFieldAndFormat - Class in org.elasticsearch.search.sort
- SortFieldAndFormat(SortField, DocValueFormat) - Constructor for class org.elasticsearch.search.sort.SortFieldAndFormat
- SortingBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
Base class for building
SortedBinaryDocValues
instances based on unsorted content. - SortingBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- SortingNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base class for building
SortedNumericDocValues
instances based on unsorted content. - SortingNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortingNumericDocValues
- SortingNumericDoubleValues - Class in org.elasticsearch.index.fielddata
-
Base class for building
SortedNumericDoubleValues
instances based on unsorted content. - SortingNumericDoubleValues() - Constructor for class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
- sortMissingFirst(Object) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Whether missing values should be sorted first.
- sortMissingLast(Object) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Whether missing values should be sorted last, this is the default.
- sortMode - Variable in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- sortMode() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- sortMode() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns what values to pick in the case a document contains multiple values for the targeted sort field.
- sortMode() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns which distance to use for sorting in the case a document contains multiple geo points.
- sortMode() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Get the sort mode.
- sortMode(SortMode) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Defines what values to pick in the case a document contains multiple values for the targeted sort field.
- sortMode(SortMode) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Defines which distance to use for sorting in the case a document contains multiple geo points.
- sortMode(SortMode) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Defines which distance to use for sorting in the case a document contains multiple values.
ForScriptSortBuilder.ScriptSortType.STRING
, the set of possible values is restricted toSortMode.MIN
andSortMode.MAX
- SortMode - Enum in org.elasticsearch.search.sort
-
Elasticsearch supports sorting by array or multi-valued fields.
- SORTMODE_FIELD - Static variable in class org.elasticsearch.search.sort.ScriptSortBuilder
- sortNodeDecisions(List<NodeAllocationResult>) - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Sorts a list of node level decisions by the decision type, then by weight ranking, and finally by node id.
- SortOrder - Enum in org.elasticsearch.search.sort
-
A sorting order.
- sorts() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Gets the bytes representing the sort builders for this request.
- sorts() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the bytes representing the sort builders for this request.
- sorts(List<SortBuilder<?>>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Adds a sort builder.
- sortValueFormats() - Method in class org.elasticsearch.search.query.QuerySearchResult
- sortValues(Object[], DocValueFormat[]) - Method in class org.elasticsearch.search.SearchHit
- sortValues(SearchSortValues) - Method in class org.elasticsearch.search.SearchHit
- source - Variable in class org.elasticsearch.cluster.service.SourcePrioritizedRunnable
- source - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- source - Variable in class org.elasticsearch.index.translog.Translog.Source
- source() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- source() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- source() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source() - Method in class org.elasticsearch.action.index.IndexRequest
-
The source of the document to index, recopied to a new array if it is unsafe.
- source() - Method in class org.elasticsearch.action.search.SearchRequest
-
The search source to execute.
- source() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
The source that caused this cluster event to be raised.
- source() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
- source() - Method in class org.elasticsearch.cluster.service.SourcePrioritizedRunnable
- source() - Method in class org.elasticsearch.index.engine.Engine.Index
- source() - Method in class org.elasticsearch.index.engine.Engine.Searcher
-
The source that caused this searcher to be acquired.
- source() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- source() - Method in class org.elasticsearch.index.get.GetResult
-
The source of the document if exists.
- source() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- source() - Method in class org.elasticsearch.index.mapper.SourceToParse
- source() - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- source() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
The search used to find documents to process.
- source() - Method in class org.elasticsearch.index.seqno.RetentionLease
-
The source of this retention lease.
- source() - Method in class org.elasticsearch.index.translog.Translog.Index
- source() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- source() - Method in class org.elasticsearch.search.internal.SearchContext
- source() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- source() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- source() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- source() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- source() - Method in class org.elasticsearch.search.lookup.SearchLookup
- source() - Method in class org.elasticsearch.search.lookup.SourceLookup
- source(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document to index in bytes form (assumed to be safe to be used from different threads).
- source(byte[], XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(byte[], XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(byte[], XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document to index in bytes form.
- source(Object...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- source(Object...) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the content source to index using the default content type (
Requests.INDEX_CONTENT_TYPE
) - source(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- source(String...) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set the source indices.
- source(String, String, String, BytesReference, XContentType) - Static method in class org.elasticsearch.index.mapper.SourceToParse
- source(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(String, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document source to index.
- source(Map) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(Map) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(Map) - Method in class org.elasticsearch.action.index.IndexRequest
-
Index the Map in
Requests.INDEX_CONTENT_TYPE
format - source(Map<String, ?>, DeprecationHandler) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Parses repository definition.
- source(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Parses snapshot definition.
- source(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Parses restore definition
- source(Map, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Index the Map as the provided content type.
- source(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(BytesReference, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document to index in bytes form.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(XContentBuilder) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the content source to index.
- source(XContentType, Object...) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the content source to index.
- source(SearchSourceBuilder) - Method in class org.elasticsearch.action.search.SearchRequest
-
The source of the search request.
- source(SearchSourceBuilder) - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- source(SearchSourceBuilder) - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- source(SearchSourceBuilder) - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- Source(BytesReference, String, String) - Constructor for class org.elasticsearch.index.translog.Translog.Source
- SOURCE - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- SOURCE_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for source on the inner level. - SOURCE_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for source on the inner level. - sourceAsMap() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
-
Returns the mappings as a map.
- sourceAsMap() - Method in class org.elasticsearch.action.index.IndexRequest
- sourceAsMap() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
Converts the serialized compressed form of the mappings into a parsed map.
- sourceAsMap() - Method in class org.elasticsearch.index.get.GetResult
-
The source of the document (As a map).
- sourceAsMap(BytesReference) - Static method in class org.elasticsearch.search.lookup.SourceLookup
- sourceAsMapAndType(BytesReference) - Static method in class org.elasticsearch.search.lookup.SourceLookup
- sourceAsString() - Method in class org.elasticsearch.index.get.GetResult
-
The source of the document (as a string).
- sourceContentType() - Method in class org.elasticsearch.search.lookup.SourceLookup
- SourceFieldMapper - Class in org.elasticsearch.index.mapper
- SourceFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- SourceFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- SourceFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- sourceFieldNames(List<String>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
-
Selects the fields to load from _source JSON and analyze.
- SourceLookup - Class in org.elasticsearch.search.lookup
- SourceLookup() - Constructor for class org.elasticsearch.search.lookup.SourceLookup
- sourceMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- sourceMetaSnapshot() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- sourceNode() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- sourceNode() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- SourcePrioritizedRunnable - Class in org.elasticsearch.cluster.service
-
PrioritizedRunnable that also has a source string
- SourcePrioritizedRunnable(Priority, String) - Constructor for class org.elasticsearch.cluster.service.SourcePrioritizedRunnable
- SourceProvider - Class in org.elasticsearch.common.inject.internal
-
Provides access to the calling line of code.
- SourceProvider() - Constructor for class org.elasticsearch.common.inject.internal.SourceProvider
- sourceRef() - Method in class org.elasticsearch.index.get.GetResult
-
Returns bytes reference, also un compress the source if needed.
- sourceRef(BytesReference) - Method in class org.elasticsearch.search.SearchHit
-
Sets representation, might be compressed....
- sourceRequested() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- sourceRequested() - Method in class org.elasticsearch.search.internal.SearchContext
-
A shortcut function to see whether there is a fetchSourceContext and it says the source is requested.
- sourceRequested() - Method in class org.elasticsearch.search.internal.SubSearchContext
- sources() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
-
Gets the list of
CompositeValuesSourceBuilder
for this aggregation. - SOURCES_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- SourceScoreOrderFragmentsBuilder - Class in org.elasticsearch.search.fetch.subphase.highlight
- SourceScoreOrderFragmentsBuilder(MappedFieldType, SearchContext, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SourceScoreOrderFragmentsBuilder
- SourceSimpleFragmentsBuilder - Class in org.elasticsearch.search.fetch.subphase.highlight
- SourceSimpleFragmentsBuilder(MappedFieldType, SearchContext, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SourceSimpleFragmentsBuilder
- sourceThrottleTimeInNanos() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- sourceThrottling() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- sourceToParse() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- sourceToParse() - Method in class org.elasticsearch.index.mapper.ParseContext
- SourceToParse - Class in org.elasticsearch.index.mapper
- SourceToParse.Origin - Enum in org.elasticsearch.index.mapper
- SPACE - Static variable in class org.elasticsearch.common.geo.parsers.GeoWKTParser
- SPACE - Static variable in class org.elasticsearch.common.logging.Loggers
- spaceify(int, String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
- SpanBooleanQueryRewriteWithMaxClause - Class in org.elasticsearch.common.lucene.search
-
A span rewrite method that extracts the first
maxExpansions
terms that match theMultiTermQuery
in the terms dictionary. - SpanBooleanQueryRewriteWithMaxClause() - Constructor for class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- SpanBooleanQueryRewriteWithMaxClause(int, boolean) - Constructor for class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- spanContainingQuery(SpanQueryBuilder, SpanQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a new
span_containing
builder. - SpanContainingQueryBuilder - Class in org.elasticsearch.index.query
-
Builder for
SpanContainingQuery
. - SpanContainingQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanContainingQueryBuilder
-
Read from a stream.
- SpanContainingQueryBuilder(SpanQueryBuilder, SpanQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanContainingQueryBuilder
- spanFirstQuery(SpanQueryBuilder, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanFirstQueryBuilder - Class in org.elasticsearch.index.query
- SpanFirstQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanFirstQueryBuilder
-
Read from a stream.
- SpanFirstQueryBuilder(SpanQueryBuilder, int) - Constructor for class org.elasticsearch.index.query.SpanFirstQueryBuilder
-
Query that matches spans queries defined in
matchBuilder
whose end position is less than or equal toend
. - SpanGapQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
-
Constructs a new SpanGapQueryBuilder term query.
- SpanGapQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
-
Read from a stream.
- SpanMatchNoDocsQuery - Class in org.apache.lucene.queries
-
A
SpanQuery
that matches no documents. - SpanMatchNoDocsQuery(String, String) - Constructor for class org.apache.lucene.queries.SpanMatchNoDocsQuery
- spanMultiTermQueryBuilder(MultiTermQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a
SpanQueryBuilder
which allows having a sub query which implementsMultiTermQueryBuilder
. - SpanMultiTermQueryBuilder - Class in org.elasticsearch.index.query
-
Query that allows wrapping a
MultiTermQueryBuilder
(one of wildcard, fuzzy, prefix, term, range or regexp query) as aSpanQueryBuilder
so it can be nested. - SpanMultiTermQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
-
Read from a stream.
- SpanMultiTermQueryBuilder(MultiTermQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- spanNearQuery(SpanQueryBuilder, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanNearQueryBuilder - Class in org.elasticsearch.index.query
-
Matches spans which are near one another.
- SpanNearQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder
-
Read from a stream.
- SpanNearQueryBuilder(SpanQueryBuilder, int) - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder
- SpanNearQueryBuilder.SpanGapQueryBuilder - Class in org.elasticsearch.index.query
-
SpanGapQueryBuilder enables gaps in a SpanNearQuery.
- spanNotQuery(SpanQueryBuilder, SpanQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanNotQueryBuilder - Class in org.elasticsearch.index.query
- SpanNotQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanNotQueryBuilder
-
Read from a stream.
- SpanNotQueryBuilder(SpanQueryBuilder, SpanQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanNotQueryBuilder
-
Construct a span query matching spans from
include
which have no overlap with spans fromexclude
. - spanOrQuery(SpanQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanOrQueryBuilder - Class in org.elasticsearch.index.query
-
Span query that matches the union of its clauses.
- SpanOrQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanOrQueryBuilder
-
Read from a stream.
- SpanOrQueryBuilder(SpanQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanOrQueryBuilder
- spanPrefixQuery(String, SpanMultiTermQueryWrapper.SpanRewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- spanPrefixQuery(String, SpanMultiTermQueryWrapper.SpanRewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- SpanQueryBuilder - Interface in org.elasticsearch.index.query
-
Marker interface for a specific type of
QueryBuilder
that allows to build span queries. - SpanQueryBuilder.SpanQueryBuilderUtil - Class in org.elasticsearch.index.query
- spanRewriteMethod - Variable in class org.elasticsearch.index.search.MatchQuery
- spanTermQuery(String, double) - Static method in class org.elasticsearch.index.query.QueryBuilders
- spanTermQuery(String, float) - Static method in class org.elasticsearch.index.query.QueryBuilders
- spanTermQuery(String, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
- spanTermQuery(String, long) - Static method in class org.elasticsearch.index.query.QueryBuilders
- spanTermQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanTermQueryBuilder - Class in org.elasticsearch.index.query
-
A Span Query that matches documents containing a term.
- SpanTermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
-
Read from a stream.
- spanWithinQuery(SpanQueryBuilder, SpanQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a new
span_within
builder. - SpanWithinQueryBuilder - Class in org.elasticsearch.index.query
-
Builder for
SpanWithinQuery
. - SpanWithinQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanWithinQueryBuilder
-
Read from a stream.
- SpanWithinQueryBuilder(SpanQueryBuilder, SpanQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanWithinQueryBuilder
-
Query that returns spans from
little
that are contained in a spans frombig
. - spare - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- SPATIAL_CONTEXT - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- SPATIAL4J_AVAILABLE - Static variable in class org.elasticsearch.common.geo.ShapesAvailability
- SpatialStrategy - Enum in org.elasticsearch.common.geo
- SpecialPermission - Class in org.elasticsearch
-
Elasticsearch-specific permission to check before entering
AccessController.doPrivileged()
blocks. - SpecialPermission() - Constructor for class org.elasticsearch.SpecialPermission
-
Creates a new SpecialPermision object.
- SpecialPermission(String, String) - Constructor for class org.elasticsearch.SpecialPermission
-
Creates a new SpecialPermission object.
- split(String, String) - Static method in class org.elasticsearch.common.Strings
-
Split a String at the first occurrence of the delimiter.
- SPLIT - org.elasticsearch.action.admin.indices.shrink.ResizeType
- splitCombinedPatterns(String) - Static method in interface org.elasticsearch.common.time.DateFormatter
- splitOnWhitespace() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Deprecated.
- splitOnWhitespace(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Deprecated.
- splitQueriesOnWhitespace() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- splitQueriesOnWhitespace(boolean) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- splitSmart(String, String, boolean) - Static method in class org.elasticsearch.common.Strings
-
Splits a backslash escaped string on the separator.
- splitStringByCommaToArray(String) - Static method in class org.elasticsearch.common.Strings
-
Split the specified string by commas to an array.
- SQRT - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- SQUARE - org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- stack - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
A temporary stack used to record where we are in the dependency tree.
- stackTrace(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
- StackTraceElements - Class in org.elasticsearch.common.inject.internal
-
Creates stack trace elements for members.
- StackTraceElements() - Constructor for class org.elasticsearch.common.inject.internal.StackTraceElements
- stage() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- Stage - Enum in org.elasticsearch.common.inject
-
The stage we're running in.
- StaleShard - Class in org.elasticsearch.cluster.routing.allocation
-
A class that represents a stale shard copy.
- StaleShard(ShardId, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.StaleShard
- STANDARD - org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- STANDARD - org.elasticsearch.indices.analysis.PreBuiltTokenizers
- STANDARD - Static variable in class org.elasticsearch.script.ClassPermission
- STANDARD_ANALYZER - Static variable in class org.elasticsearch.common.lucene.Lucene
- STANDARD_CLASSES - Static variable in class org.elasticsearch.script.ClassPermission
-
Typical set of classes for scripting: basic data types, math, dates, and simple collections
- StandardAnalyzerProvider - Class in org.elasticsearch.index.analysis
- StandardAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardAnalyzerProvider
- StandardTokenizerFactory - Class in org.elasticsearch.index.analysis
- StandardTokenizerFactory(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardTokenizerFactory
- start() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- start() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- start() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- start() - Method in interface org.elasticsearch.common.component.LifecycleComponent
- start() - Method in class org.elasticsearch.common.StopWatch
-
Start an unnamed task.
- start() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- start() - Method in interface org.elasticsearch.discovery.zen.ZenPing
- start() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- start() - Method in class org.elasticsearch.node.Node
-
Start the node.
- start() - Method in class org.elasticsearch.repositories.FilterRepository
- start() - Method in class org.elasticsearch.search.profile.Timer
-
Start the timer.
- start(String) - Method in class org.elasticsearch.common.StopWatch
-
Start a named task.
- start(Consumer<ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- START_RECOVERY - Static variable in class org.elasticsearch.indices.recovery.PeerRecoverySourceService.Actions
- startConstruction() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- started() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard is in started mode.
- started() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns
true
if the state is started. - STARTED - org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Index files are being copied
- STARTED - org.elasticsearch.cluster.RestoreInProgress.State
-
Started state
- STARTED - org.elasticsearch.cluster.routing.ShardRoutingState
-
The shard is started.
- STARTED - org.elasticsearch.cluster.SnapshotsInProgress.State
- STARTED - org.elasticsearch.common.component.Lifecycle.State
- STARTED - org.elasticsearch.index.shard.IndexShardState
- STARTED - org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Index files are being copied
- STARTED - org.elasticsearch.persistent.AllocatedPersistentTask.State
- startedPrimaryReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- startedPrimaryReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- startedPrimaryReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- startedPrimaryReinitialized(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called on started primary shard after it has been promoted from replica to primary and is reinitialized due to shadow replicas.
- StartedShardEntry(ShardId, String, long, String) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction.StartedShardEntry
- startElectionContext() - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
Accumulates any future incoming join request.
- startHeaders() - Method in class org.elasticsearch.common.Table
- startHeadersWithTimestamp() - Method in class org.elasticsearch.common.Table
- startingSeqNo() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- startInitialJoin() - Method in interface org.elasticsearch.discovery.Discovery
-
Triggers the first join cycle
- startInitialJoin() - Method in class org.elasticsearch.discovery.single.SingleNodeDiscovery
- startInitialJoin() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- startNanoTime - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- startNewSequence() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
-
Reset the sequence detection logic to avoid any continuation of the immediately previous bytes.
- startNextScroll(TimeValue, Consumer<ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- StartPersistentTaskAction - Class in org.elasticsearch.persistent
-
This action can be used to add the record for the persistent action to the cluster state.
- StartPersistentTaskAction.Request - Class in org.elasticsearch.persistent
- StartPersistentTaskAction.RequestBuilder - Class in org.elasticsearch.persistent
- StartPersistentTaskAction.TransportAction - Class in org.elasticsearch.persistent
- startRecovery(IndexShard, DiscoveryNode, PeerRecoveryTargetService.RecoveryListener) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- startRecovery(IndexShard, DiscoveryNode, PeerRecoveryTargetService.RecoveryListener, TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
Starts are new recovery for the given shard, source node and state
- startRecovery(RecoveryState, PeerRecoveryTargetService, PeerRecoveryTargetService.RecoveryListener, RepositoriesService, BiConsumer<String, MappingMetaData>, IndicesService) - Method in class org.elasticsearch.index.shard.IndexShard
- StartRecoveryRequest - Class in org.elasticsearch.indices.recovery
-
Represents a request for starting a peer recovery.
- StartRecoveryRequest() - Constructor for class org.elasticsearch.indices.recovery.StartRecoveryRequest
- StartRecoveryRequest(ShardId, String, DiscoveryNode, DiscoveryNode, Store.MetadataSnapshot, boolean, long, long) - Constructor for class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
Construct a request for starting a peer recovery.
- startRelocationHandoff() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Initiates a relocation handoff and returns the corresponding primary context.
- startRewriteTime() - Method in class org.elasticsearch.search.profile.query.QueryProfiler
-
Begin timing the rewrite phase of a request.
- startRow() - Method in class org.elasticsearch.common.Table
- startShard(Logger, ShardRouting, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Applies the relevant logic to start an initializing shard.
- startTerm(BytesRef) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
- startTime - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- startTime() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- startTime() - Method in class org.elasticsearch.index.engine.Engine.Operation
-
Returns operation start time in nanoseconds.
- startTime() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot start time
- startTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
Returns start time in millis
- startTime() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns time when snapshot started; a value of
0L
will be returned ifSnapshotInfo.state()
returnsnull
. - startVerification() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- startVerification() - Method in class org.elasticsearch.repositories.FilterRepository
- startVerification() - Method in interface org.elasticsearch.repositories.Repository
-
Verifies repository on the master node and returns the verification token.
- stashAndMergeHeaders(Map<String, String>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Removes the current context and resets a new context that contains a merge of the current headers and the given headers.
- stashContext() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Removes the current context and resets a default context.
- stashWithOrigin(String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Removes the current context and resets a default context marked with as originating from the supplied string.
- state - Variable in class org.elasticsearch.index.shard.IndexShard
- state() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- state() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
The new cluster state that caused this change event.
- state() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns current restore state
- state() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Returns current state
- state() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard state.
- state() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
The current cluster state.
- state() - Method in class org.elasticsearch.cluster.service.ClusterService
-
The currently applied cluster state.
- state() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- state() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- state() - Method in class org.elasticsearch.common.component.Lifecycle
- state() - Method in class org.elasticsearch.index.shard.IndexShard
- state() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Returns the latest internal shard state.
- state() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- state() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot state;
null
if the state is unknown. - state(ClusterStateRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The state of the cluster.
- state(ClusterStateRequest, ActionListener<ClusterStateResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The state of the cluster.
- state(IndexMetaData.State) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- state(IndexMetaData.State) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- STATE - org.elasticsearch.transport.TransportRequestOptions.Type
- STATE_DIR_NAME - Static variable in class org.elasticsearch.gateway.MetaDataStateFormat
- STATE_FILE_EXTENSION - Static variable in class org.elasticsearch.gateway.MetaDataStateFormat
- STATE_NOT_RECOVERED_BLOCK - Static variable in class org.elasticsearch.gateway.GatewayService
- statefulFactoryClazz - Variable in class org.elasticsearch.script.ScriptContext
-
A factory class for construct script instances.
- states - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- states - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- stateUUID() - Method in class org.elasticsearch.cluster.ClusterState
-
This stateUUID is automatically generated for for each version of cluster state.
- stateUUID(String) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- StaticInjectionRequest - Class in org.elasticsearch.common.inject.spi
-
A request to inject the static fields and methods of a type.
- stats() - Method in class org.elasticsearch.common.cache.Cache
-
The cache statistics tracking hits, misses and evictions.
- stats() - Method in interface org.elasticsearch.discovery.Discovery
- stats() - Method in class org.elasticsearch.discovery.single.SingleNodeDiscovery
- stats() - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
- stats() - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- stats() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- stats() - Method in interface org.elasticsearch.http.HttpServerTransport
- stats() - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- stats() - Method in class org.elasticsearch.index.get.ShardGetService
- stats() - Method in class org.elasticsearch.index.store.Store
- stats() - Method in class org.elasticsearch.index.translog.Translog
-
return stats
- stats() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
- stats() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
- stats() - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- stats() - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
- stats() - Method in class org.elasticsearch.ingest.IngestService
- stats() - Method in class org.elasticsearch.monitor.fs.FsService
- stats() - Method in class org.elasticsearch.monitor.jvm.JvmService
- stats() - Method in class org.elasticsearch.monitor.os.OsService
- stats() - Method in class org.elasticsearch.monitor.process.ProcessService
- stats() - Method in class org.elasticsearch.script.ScriptMetrics
- stats() - Method in class org.elasticsearch.script.ScriptService
- stats() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The stats groups this request will be aggregated under.
- stats() - Method in class org.elasticsearch.threadpool.ThreadPool
- stats() - Method in class org.elasticsearch.transport.TransportService
- stats(boolean) - Method in class org.elasticsearch.indices.IndicesService
-
Returns the node stats indices stats.
- stats(boolean, CommonStatsFlags) - Method in class org.elasticsearch.indices.IndicesService
- stats(String) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
- stats(String) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- stats(String) - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
- stats(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Stats
aggregation with the given name. - stats(String...) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
- stats(String...) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
-
Returns the stats, including group specific stats.
- stats(List<String>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The stats groups this request will be aggregated under.
- stats(CommonStatsFlags, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.node.NodeService
- stats(IndicesStatsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices stats.
- stats(IndicesStatsRequest, ActionListener<IndicesStatsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices stats.
- stats(FsInfo, ClusterInfo) - Method in class org.elasticsearch.monitor.fs.FsProbe
- Stats - Interface in org.elasticsearch.search.aggregations.metrics.stats
-
Statistics over a set of values (either aggregated over field data or scripts)
- Stats(long, long, long, long) - Constructor for class org.elasticsearch.ingest.IngestStats.Stats
- Stats(long, long, long, long, long, long, long, long, boolean, long) - Constructor for class org.elasticsearch.index.shard.IndexingStats.Stats
- Stats(long, long, long, long, long, long, long, long, long, long, long, long) - Constructor for class org.elasticsearch.index.search.stats.SearchStats.Stats
- Stats(long, long, ByteSizeValue) - Constructor for class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- Stats(String, int, int, int, long, int, long) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- Stats(StreamInput) - Constructor for class org.elasticsearch.ingest.IngestStats.Stats
-
Read from a stream.
- Stats(StreamInput) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- STATS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- StatsAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.stats
- StatsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- StatsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
-
Read from a stream.
- StatsAggregationBuilder(StatsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregationBuilder
- StatsAggregator - Class in org.elasticsearch.search.aggregations.metrics.stats
- StatsAggregator(String, ValuesSource.Numeric, DocValueFormat, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
- StatsAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.stats
- StatsAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregatorFactory
- statsBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- StatsBucket - Interface in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
-
Statistics over a set of buckets
- StatsBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
- StatsBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
- StatsBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregationBuilder
-
Read from a stream.
- StatsBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
- StatsBucketPipelineAggregator(String, String[], BucketHelpers.GapPolicy, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
- StatsBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
- status - Variable in class org.elasticsearch.action.ShardOperationFailedException
- status - Variable in class org.elasticsearch.transport.NetworkMessage
- status() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
-
Returns HTTP status
RestStatus.ACCEPTED
if snapshot is still in progressRestStatus.OK
if snapshot was successful or partially successfulRestStatus.INTERNAL_SERVER_ERROR
if snapshot failed completely - status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
- status() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- status() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
- status() - Method in class org.elasticsearch.action.bulk.BulkResponse
- status() - Method in class org.elasticsearch.action.delete.DeleteResponse
- status() - Method in class org.elasticsearch.action.DocWriteResponse
-
returns the rest status for this response (based on
ReplicationResponse.ShardInfo.status()
- status() - Method in class org.elasticsearch.action.explain.ExplainResponse
- status() - Method in class org.elasticsearch.action.index.IndexResponse
- status() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- status() - Method in exception org.elasticsearch.action.NoShardAvailableActionException
- status() - Method in exception org.elasticsearch.action.RoutingMissingException
- status() - Method in class org.elasticsearch.action.search.ClearScrollResponse
- status() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- status() - Method in class org.elasticsearch.action.search.SearchResponse
- status() - Method in class org.elasticsearch.action.ShardOperationFailedException
-
The status of the failure.
- status() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- status() - Method in exception org.elasticsearch.action.UnavailableShardsException
- status() - Method in class org.elasticsearch.action.update.UpdateResponse
- status() - Method in exception org.elasticsearch.client.transport.NoNodeAvailableException
- status() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- status() - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- status() - Method in exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
- status() - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- status() - Method in exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- status() - Method in exception org.elasticsearch.common.ParsingException
- status() - Method in interface org.elasticsearch.common.xcontent.StatusToXContentObject
-
Returns the REST status to make sure it is returned correctly
- status() - Method in exception org.elasticsearch.discovery.MasterNotDiscoveredException
- status() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the rest status code associated with this exception.
- status() - Method in exception org.elasticsearch.ElasticsearchParseException
- status() - Method in exception org.elasticsearch.ElasticsearchStatusException
- status() - Method in exception org.elasticsearch.index.engine.DocumentMissingException
- status() - Method in exception org.elasticsearch.index.engine.DocumentSourceMissingException
- status() - Method in exception org.elasticsearch.index.engine.VersionConflictEngineException
- status() - Method in exception org.elasticsearch.index.mapper.MapperParsingException
- status() - Method in exception org.elasticsearch.index.mapper.StrictDynamicMappingException
- status() - Method in exception org.elasticsearch.index.query.QueryShardException
- status() - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- status() - Method in exception org.elasticsearch.indices.IndexClosedException
- status() - Method in exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
- status() - Method in exception org.elasticsearch.indices.IndexTemplateMissingException
- status() - Method in exception org.elasticsearch.indices.InvalidAliasNameException
- status() - Method in exception org.elasticsearch.indices.InvalidIndexNameException
- status() - Method in exception org.elasticsearch.indices.InvalidIndexTemplateException
- status() - Method in exception org.elasticsearch.indices.InvalidTypeNameException
- status() - Method in exception org.elasticsearch.indices.TypeMissingException
- status() - Method in exception org.elasticsearch.repositories.RepositoryMissingException
- status() - Method in exception org.elasticsearch.repositories.RepositoryVerificationException
- status() - Method in exception org.elasticsearch.ResourceAlreadyExistsException
- status() - Method in exception org.elasticsearch.ResourceNotFoundException
- status() - Method in class org.elasticsearch.rest.BytesRestResponse
- status() - Method in class org.elasticsearch.rest.RestResponse
-
The rest status code.
- status() - Method in exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- status() - Method in exception org.elasticsearch.search.SearchContextMissingException
- status() - Method in exception org.elasticsearch.search.SearchParseException
- status() - Method in exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
- status() - Method in exception org.elasticsearch.snapshots.InvalidSnapshotNameException
- status() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
REST status of the operation
- status() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot REST status
- status() - Method in exception org.elasticsearch.snapshots.SnapshotInProgressException
- status() - Method in exception org.elasticsearch.snapshots.SnapshotMissingException
- status() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- status() - Method in exception org.elasticsearch.transport.TcpTransport.HttpOnTransportException
- status(int, int, ShardOperationFailedException...) - Static method in enum org.elasticsearch.rest.RestStatus
- status(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
- Status(Integer, long, long, long, long, int, long, long, long, long, TimeValue, float, String, TimeValue) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- Status(String) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask.Status
- Status(String, int, int, int) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- Status(List<BulkByScrollTask.StatusOrException>, String) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Constructor merging many statuses.
- Status(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- Status(AllocatedPersistentTask.State) - Constructor for class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- STATUS_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- STATUS_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- StatusBuilder() - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- StatusOrException(Exception) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- StatusOrException(StreamInput) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
-
Read from a stream.
- StatusOrException(BulkByScrollTask.Status) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- StatusToXContentObject - Interface in org.elasticsearch.common.xcontent
-
Objects that can both render themselves in as json/yaml/etc and can provide a
RestStatus
for their response. - stay(Decision) - Static method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Creates a move decision for the shard being able to remain on its current node, so the shard won't be forced to move to another node.
- stdDev(double[], double) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Calculate a standard deviation over the values using the provided average.
- stdDeviation - Variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- stdDeviationBoundLower - Variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- stdDeviationBoundUpper - Variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- StepListener<Response> - Class in org.elasticsearch.action
-
A
StepListener
provides a simple way to write a flow consisting of multiple asynchronous steps without having nested callbacks. - StepListener() - Constructor for class org.elasticsearch.action.StepListener
- STILL_ALLOCATED - org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
- stop() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- stop() - Method in interface org.elasticsearch.common.component.LifecycleComponent
- stop() - Method in class org.elasticsearch.common.StopWatch
-
Stop the current task.
- stop() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
-
stops all pinging
- stop() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- stop() - Method in class org.elasticsearch.repositories.FilterRepository
- stop() - Method in class org.elasticsearch.search.profile.Timer
-
Stop the timer.
- stop() - Method in class org.elasticsearch.watcher.WatcherHandle
- stop(String) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- STOP - org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- StopAnalyzerProvider - Class in org.elasticsearch.index.analysis
- StopAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StopAnalyzerProvider
- stopAndAddRewriteTime() - Method in class org.elasticsearch.search.profile.query.QueryProfiler
-
Stop recording the current rewrite and add it's time to the total tally, returning the cumulative time so far.
- stopCachedTimeThread() - Method in class org.elasticsearch.threadpool.ThreadPool
- stopElectionContext(String) - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
Stopped accumulating joins.
- stopInternal() - Method in class org.elasticsearch.transport.TcpTransport
-
Called to tear down internal resources
- stopped() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns
true
if the state is stopped. - STOPPED - org.elasticsearch.common.component.Lifecycle.State
- stoppedOrClosed() - Method in class org.elasticsearch.common.component.Lifecycle
- stopTime - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- stopTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
Returns stop time in millis
- StopTokenFilterFactory - Class in org.elasticsearch.index.analysis
- StopTokenFilterFactory(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StopTokenFilterFactory
- Stopwatch - Class in org.elasticsearch.common.inject.internal
-
Enables simple performance monitoring.
- Stopwatch() - Constructor for class org.elasticsearch.common.inject.internal.Stopwatch
- StopWatch - Class in org.elasticsearch.common
-
Simple stop watch, allowing for timing of a number of tasks, exposing total running time and running time for each named task.
- StopWatch() - Constructor for class org.elasticsearch.common.StopWatch
-
Construct a new stop watch.
- StopWatch(String) - Constructor for class org.elasticsearch.common.StopWatch
-
Construct a new stop watch with the given id.
- StopWatch.TaskInfo - Class in org.elasticsearch.common
-
Inner class to hold data about one task executed within the stop watch.
- stopWords() - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
- stopWords() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- stopWords(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Set the set of stopwords.
- stopWords(List<String>) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- store - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- store - Variable in class org.elasticsearch.index.engine.Engine
- store() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- store() - Method in class org.elasticsearch.index.shard.IndexShard
- store() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- store(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- store(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- store(OutputStream) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- Store - Class in org.elasticsearch.index.store
-
A Store provides plain access to files written by an elasticsearch index shard.
- Store - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- Store(ShardId, IndexSettings, Directory, ShardLock) - Constructor for class org.elasticsearch.index.store.Store
- Store(ShardId, IndexSettings, Directory, ShardLock, Store.OnClose) - Constructor for class org.elasticsearch.index.store.Store
- Store.MetadataSnapshot - Class in org.elasticsearch.index.store
-
Represents a snapshot of the current directory build from the latest Lucene commit.
- Store.OnClose - Interface in org.elasticsearch.index.store
-
A listener that is executed once the store is closed and all references to it are released
- Store.RecoveryDiff - Class in org.elasticsearch.index.store
-
A class representing the diff between a recovery source and recovery target
- STORED - org.elasticsearch.script.ScriptType
-
STORED scripts are saved as part of the
ClusterState
based on user requests. - STORED_FIELDS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- storedContext - Variable in class org.elasticsearch.transport.NetworkMessage
- storedField(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Adds a stored field to load and return (note, it must be stored) as part of the search request.
- storedField(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a stored field to load and return as part of the search request.
- storedFields() - Method in class org.elasticsearch.action.explain.ExplainRequest
- storedFields() - Method in class org.elasticsearch.action.get.GetRequest
-
Explicitly specify the stored fields that will be returned.
- storedFields() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- storedFields() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Gets the stored fields context
- storedFields() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the stored fields context.
- storedFields(String[]) - Method in class org.elasticsearch.action.explain.ExplainRequest
- storedFields(String...) - Method in class org.elasticsearch.action.get.GetRequest
-
Explicitly specify the stored fields that will be returned.
- storedFields(String...) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- storedFields(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds stored fields to load and return (note, it must be stored) as part of the search request.
- storedFields(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Sets the stored fields to load and return as part of the search request.
- storedFields(List<String>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the stored fields to load and return as part of the search request.
- storedFields(StoredFieldsContext) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates how the stored fields should be fetched.
- storedFieldsContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- storedFieldsContext() - Method in class org.elasticsearch.search.internal.SearchContext
- storedFieldsContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- storedFieldsContext(StoredFieldsContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- storedFieldsContext(StoredFieldsContext) - Method in class org.elasticsearch.search.internal.SearchContext
- storedFieldsContext(StoredFieldsContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- StoredFieldsContext - Class in org.elasticsearch.search.fetch
-
Context used to fetch the
stored_fields
. - StoredFieldsContext(StreamInput) - Constructor for class org.elasticsearch.search.fetch.StoredFieldsContext
- StoredFieldsContext(StoredFieldsContext) - Constructor for class org.elasticsearch.search.fetch.StoredFieldsContext
- storedFieldsRequested() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- storedFieldsRequested() - Method in class org.elasticsearch.search.internal.SearchContext
-
A shortcut function to see whether there is a storedFieldsContext and it says the fields are requested.
- storedFieldsRequested() - Method in class org.elasticsearch.search.internal.SubSearchContext
- StoredScriptSource - Class in org.elasticsearch.script
-
StoredScriptSource
represents user-defined parameters for a script saved in theClusterState
. - StoredScriptSource(String) - Constructor for class org.elasticsearch.script.StoredScriptSource
-
Constructor for use with
GetStoredScriptResponse
to support the deprecated stored script namespace. - StoredScriptSource(String, String, Map<String, String>) - Constructor for class org.elasticsearch.script.StoredScriptSource
-
Standard StoredScriptSource constructor.
- StoredScriptSource(StreamInput) - Constructor for class org.elasticsearch.script.StoredScriptSource
-
Reads a
StoredScriptSource
from a stream. - storeException() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- StoreFileMetaData - Class in org.elasticsearch.index.store
- StoreFileMetaData(String, long, String, Version) - Constructor for class org.elasticsearch.index.store.StoreFileMetaData
- StoreFileMetaData(String, long, String, Version, BytesRef) - Constructor for class org.elasticsearch.index.store.StoreFileMetaData
- StoreFileMetaData(StreamInput) - Constructor for class org.elasticsearch.index.store.StoreFileMetaData
-
Read from a stream.
- storeFilesMetaData() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
- StoreFilesMetaData(ShardId, Store.MetadataSnapshot) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- storeResult(TaskResult, ActionListener<Void>) - Method in class org.elasticsearch.tasks.TaskResultsService
- storeResult(Task, Exception, ActionListener<Response>) - Method in class org.elasticsearch.tasks.TaskManager
-
Stores the task failure
- storeResult(Task, Response, ActionListener<Response>) - Method in class org.elasticsearch.tasks.TaskManager
-
Stores the task result
- storeScript(String, StoredScriptSource) - Method in class org.elasticsearch.script.ScriptMetaData.Builder
-
Add a new script to the existing stored scripts based on a user-specified id.
- storeStats() - Method in class org.elasticsearch.index.shard.IndexShard
- StoreStats - Class in org.elasticsearch.index.store
- StoreStats() - Constructor for class org.elasticsearch.index.store.StoreStats
- StoreStats(long) - Constructor for class org.elasticsearch.index.store.StoreStats
- StoreStatus(DiscoveryNode, String, IndicesShardStoresResponse.StoreStatus.AllocationStatus, Exception) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- storeTermVectorOffsets(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- storeTermVectorPayloads(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- storeTermVectorPositions(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- storeTermVectors(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- strategy - Variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- strategy() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- strategy() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- strategy(SpatialStrategy) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Defines which spatial strategy will be used for building the geo shape Query.
- STRATEGY - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults
-
Deprecated.
- STRATEGY - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Names
-
Deprecated.
- Streamable - Interface in org.elasticsearch.common.io.stream
-
Implementers can be written to a StreamOutput and read from a StreamInput.
- streamInput() - Method in class org.elasticsearch.common.bytes.BytesReference
-
A stream input of the bytes.
- streamInput(StreamInput) - Method in interface org.elasticsearch.common.compress.Compressor
- streamInput(StreamInput) - Method in class org.elasticsearch.common.compress.DeflateCompressor
- StreamInput - Class in org.elasticsearch.common.io.stream
-
A stream from this node to another node.
- StreamInput() - Constructor for class org.elasticsearch.common.io.stream.StreamInput
- streamOutput(StreamOutput) - Method in interface org.elasticsearch.common.compress.Compressor
-
Creates a new stream output that compresses the contents and writes to the provided stream output.
- streamOutput(StreamOutput) - Method in class org.elasticsearch.common.compress.DeflateCompressor
- StreamOutput - Class in org.elasticsearch.common.io.stream
-
A stream from another node to this node.
- StreamOutput() - Constructor for class org.elasticsearch.common.io.stream.StreamOutput
- Streams - Class in org.elasticsearch.common.io
-
Simple utility methods for file and stream copying.
- Streams() - Constructor for class org.elasticsearch.common.io.Streams
- Streams() - Constructor for class org.elasticsearch.common.rounding.Rounding.Streams
- Streams() - Constructor for class org.elasticsearch.search.aggregations.InternalOrder.Streams
- STRICT - org.elasticsearch.index.mapper.ObjectMapper.Dynamic
- STRICT - org.elasticsearch.index.query.GeoValidationMethod
- STRICT_BASIC_WEEK_DATE - org.elasticsearch.common.time.FormatNames
- STRICT_BASIC_WEEK_DATE_TIME - org.elasticsearch.common.time.FormatNames
- STRICT_BASIC_WEEK_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- STRICT_DATE - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR_MINUTE - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR_MINUTE_SECOND - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR_MINUTE_SECOND_FRACTION - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR_MINUTE_SECOND_MILLIS - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_OPTIONAL_TIME - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_OPTIONAL_TIME_NANOS - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_TIME - org.elasticsearch.common.time.FormatNames
- STRICT_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- STRICT_EXPAND_OPEN - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_CLOSED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_FORBID_CLOSED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_FORBID_CLOSED_IGNORE_THROTTLED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_HOUR - org.elasticsearch.common.time.FormatNames
- STRICT_HOUR_MINUTE - org.elasticsearch.common.time.FormatNames
- STRICT_HOUR_MINUTE_SECOND - org.elasticsearch.common.time.FormatNames
- STRICT_HOUR_MINUTE_SECOND_FRACTION - org.elasticsearch.common.time.FormatNames
- STRICT_HOUR_MINUTE_SECOND_MILLIS - org.elasticsearch.common.time.FormatNames
- STRICT_ORDINAL_DATE - org.elasticsearch.common.time.FormatNames
- STRICT_ORDINAL_DATE_TIME - org.elasticsearch.common.time.FormatNames
- STRICT_ORDINAL_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- STRICT_SINGLE_INDEX_NO_EXPAND_FORBID_CLOSED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_T_TIME - org.elasticsearch.common.time.FormatNames
- STRICT_T_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- STRICT_TIME - org.elasticsearch.common.time.FormatNames
- STRICT_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- STRICT_WEEK_DATE - org.elasticsearch.common.time.FormatNames
- STRICT_WEEK_DATE_TIME - org.elasticsearch.common.time.FormatNames
- STRICT_WEEK_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- STRICT_WEEKYEAR - org.elasticsearch.common.time.FormatNames
- STRICT_WEEKYEAR_WEEK - org.elasticsearch.common.time.FormatNames
- STRICT_WEEKYEAR_WEEK_DAY - org.elasticsearch.common.time.FormatNames
- STRICT_YEAR - org.elasticsearch.common.time.FormatNames
- STRICT_YEAR_MONTH - org.elasticsearch.common.time.FormatNames
- STRICT_YEAR_MONTH_DAY - org.elasticsearch.common.time.FormatNames
- StrictDynamicMappingException - Exception in org.elasticsearch.index.mapper
- StrictDynamicMappingException(String, String) - Constructor for exception org.elasticsearch.index.mapper.StrictDynamicMappingException
- StrictDynamicMappingException(StreamInput) - Constructor for exception org.elasticsearch.index.mapper.StrictDynamicMappingException
- strictExpand() - Static method in class org.elasticsearch.action.support.IndicesOptions
- strictExpandOpen() - Static method in class org.elasticsearch.action.support.IndicesOptions
- strictExpandOpenAndForbidClosed() - Static method in class org.elasticsearch.action.support.IndicesOptions
- strictExpandOpenAndForbidClosedIgnoreThrottled() - Static method in class org.elasticsearch.action.support.IndicesOptions
- StrictISODateTimeFormat - Class in org.joda.time.format
-
Factory that creates instances of DateTimeFormatter based on the ISO8601 standard.
- StrictISODateTimeFormat() - Constructor for class org.joda.time.format.StrictISODateTimeFormat
-
Constructor.
- strictSingleIndexNoExpandForbidClosed() - Static method in class org.elasticsearch.action.support.IndicesOptions
- string() - Method in class org.elasticsearch.common.compress.CompressedXContent
- string() - Method in class org.elasticsearch.common.text.Text
-
Returns a
String
view of the data. - STRING - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- STRING - org.elasticsearch.search.aggregations.support.ValueType
- STRING - org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
-
script sort for a string value
- STRING_DISTANCE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- stringDistance - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- stringDistance() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- stringDistance() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the string distance implementation setting.
- stringDistance(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets what string distance implementation to use for comparing how similar suggested terms are.
- stringDistance(StringDistance) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- stringDistance(TermSuggestionBuilder.StringDistanceImpl) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets what string distance implementation to use for comparing how similar suggested terms are.
- stringEncode(double, double) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode to a geohash string from full resolution longitude, latitude)
- stringEncode(double, double, int) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode to a level specific geohash string from full resolution longitude, latitude
- stringEncode(long) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode to a geohash string from the geohash based long format
- stringEncodeFromMortonLong(long) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode to a full precision geohash string from a given morton encoded long value
- stringEncodeFromMortonLong(long, int) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
-
Encode to a geohash string at a given level from a morton long
- stringField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- StringFieldType - Class in org.elasticsearch.index.mapper
-
Base class for
MappedFieldType
implementations that use the same representation for internal index terms as the external representation so that partial matching queries such as prefix, wildcard and fuzzy queries can be implemented. - StringFieldType() - Constructor for class org.elasticsearch.index.mapper.StringFieldType
- StringFieldType(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.StringFieldType
- StringFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.StringFilter
- Strings - Class in org.elasticsearch.common.inject.internal
-
String utilities.
- Strings - Class in org.elasticsearch.common
- Strings(SortedBinaryDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
- Strings(SortedBinaryDocValues, BiConsumer<String, String>) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
- StringSetValueSerializer() - Constructor for class org.elasticsearch.cluster.DiffableUtils.StringSetValueSerializer
- StringTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the
TermsAggregator
when the field is a String. - StringTerms(String, BucketOrder, int, long, List<PipelineAggregator>, Map<String, Object>, DocValueFormat, int, boolean, long, List<StringTerms.Bucket>, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- StringTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
-
Read from a stream.
- StringTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- StringTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
-
An aggregator of string values.
- StringTermsAggregator(String, AggregatorFactories, ValuesSource, BucketOrder, DocValueFormat, TermsAggregator.BucketCountThresholds, IncludeExclude.StringFilter, SearchContext, Aggregator, Aggregator.SubAggCollectionMode, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
- stringValue() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- StupidBackoff - Class in org.elasticsearch.search.suggest.phrase
-
A "stupid-backoff" smoothing model similar to Katz's Backoff.
- StupidBackoff(double) - Constructor for class org.elasticsearch.search.suggest.phrase.StupidBackoff
-
Creates a Stupid-Backoff smoothing model.
- StupidBackoff(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.StupidBackoff
-
Read from a stream.
- subAggregation(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- subAggregation(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Add a sub aggregation to this builder.
- subAggregation(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- subAggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Add a sub aggregation to this aggregation.
- subAggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Add a sub aggregation to this builder.
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Registers sub-factories with this factory.
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Internal: Registers sub-factories with this factory.
- subAggregations(AggregatorFactories.Builder) - Method in interface org.elasticsearch.search.aggregations.BaseAggregationBuilder
-
Set the sub aggregations if this aggregation supports sub aggregations.
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder.LeafOnly
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Return the sub aggregator with the provided name.
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory.MultiBucketAggregatorWrapper
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- subAggregator(String) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- subAggregators - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- subAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- subclassesOf(Class<?>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches subclasses of the given type (as well as the given type).
- submitRequest(DiscoveryNode, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- submitRequest(DiscoveryNode, String, TransportRequest, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- SubmitReschedulingClusterInfoUpdatedJob() - Constructor for class org.elasticsearch.cluster.InternalClusterInfoService.SubmitReschedulingClusterInfoUpdatedJob
- submitStateUpdateTask(String, T) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Submits a cluster state update task; unlike
ClusterService.submitStateUpdateTask(String, Object, ClusterStateTaskConfig, ClusterStateTaskExecutor, ClusterStateTaskListener)
, submitted updates will not be batched. - submitStateUpdateTask(String, T) - Method in class org.elasticsearch.cluster.service.MasterService
-
Submits a cluster state update task; unlike
MasterService.submitStateUpdateTask(String, Object, ClusterStateTaskConfig, ClusterStateTaskExecutor, ClusterStateTaskListener)
, submitted updates will not be batched. - submitStateUpdateTask(String, T, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>, ClusterStateTaskListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Submits a cluster state update task; submitted updates will be batched across the same instance of executor.
- submitStateUpdateTask(String, T, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>, ClusterStateTaskListener) - Method in class org.elasticsearch.cluster.service.MasterService
-
Submits a cluster state update task; submitted updates will be batched across the same instance of executor.
- submitStateUpdateTasks(String, Map<T, ClusterStateTaskListener>, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Submits a batch of cluster state update tasks; submitted updates are guaranteed to be processed together, potentially with more tasks of the same executor.
- submitStateUpdateTasks(String, Map<T, ClusterStateTaskListener>, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>) - Method in class org.elasticsearch.cluster.service.MasterService
-
Submits a batch of cluster state update tasks; submitted updates are guaranteed to be processed together, potentially with more tasks of the same executor.
- submitTasks(List<? extends TaskBatcher.BatchedTask>, TimeValue) - Method in class org.elasticsearch.cluster.service.TaskBatcher
- submitToExecutor(AbstractRunnable) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- subOne(long) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- subPath(int, int) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- SubSearchContext - Class in org.elasticsearch.search.internal
- SubSearchContext(SearchContext) - Constructor for class org.elasticsearch.search.internal.SubSearchContext
- subSequence(int, int) - Method in class org.elasticsearch.common.settings.SecureString
- subsetDf - Variable in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- subsetSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- subsetSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- subsetSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- substring(String, int, int) - Static method in class org.elasticsearch.common.Strings
-
Return substring(beginIndex, endIndex) that is impervious to string length.
- substringMatch(CharSequence, int, CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Test whether the given string matches the given substring at the given index.
- subtypeNotProvided(Class<? extends Provider<?>>, Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- subtypeOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type that represents an unknown type that extends
bound
. - success() - Static method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- success() - Static method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
- success() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- success(T) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- SUCCESS - org.elasticsearch.cluster.RestoreInProgress.State
-
Restore finished successfully
- SUCCESS - org.elasticsearch.cluster.SnapshotsInProgress.State
- SUCCESS - org.elasticsearch.index.engine.Engine.Result.Type
- SUCCESS - org.elasticsearch.index.engine.Engine.SyncedFlushResult
- SUCCESS - org.elasticsearch.snapshots.SnapshotState
-
Snapshot process completed successfully
- successes(Iterable<T>) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- SUCCESSFUL_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- SuccessfullyProcessed - Interface in org.elasticsearch.index.reindex
-
Implemented by
WorkerBulkByScrollTaskState
andBulkByScrollTask.Status
to consistently implementSuccessfullyProcessed.getSuccessfullyProcessed()
. - successfulShards() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
-
total number of shards which were successfully sync-flushed
- successfulShards() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- successfulShards() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
Number of successful shards
- successfulShards() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns total number of shards that were successfully snapshotted; a value of
0
will be returned ifSnapshotInfo.state()
returnsnull
. - suggest - Variable in class org.elasticsearch.action.search.SearchResponseSections
- suggest() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- suggest() - Method in class org.elasticsearch.action.search.SearchResponseSections
- suggest() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the suggester builder for this request.
- suggest() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- suggest() - Method in class org.elasticsearch.search.internal.SearchContext
- suggest() - Method in class org.elasticsearch.search.query.QuerySearchResult
- suggest(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- suggest(Suggest) - Method in class org.elasticsearch.search.query.QuerySearchResult
- suggest(SuggestBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Delegates to
SearchSourceBuilder.suggest(SuggestBuilder)
- suggest(SuggestBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.SearchContext
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- Suggest - Class in org.elasticsearch.search.suggest
-
Top level suggest result, containing the result for each suggestion.
- Suggest - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- Suggest(List<Suggest.Suggestion<? extends Suggest.Suggestion.Entry<? extends Suggest.Suggestion.Entry.Option>>>) - Constructor for class org.elasticsearch.search.suggest.Suggest
- SUGGEST_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- Suggest.Suggestion<T extends Suggest.Suggestion.Entry> - Class in org.elasticsearch.search.suggest
-
The suggestion responses corresponding with the suggestions in the request.
- Suggest.Suggestion.Entry<O extends Suggest.Suggestion.Entry.Option> - Class in org.elasticsearch.search.suggest
-
Represents a part from the suggest text with suggested options.
- Suggest.Suggestion.Entry.Option - Class in org.elasticsearch.search.suggest
-
Contains the suggested text with its document frequency and score.
- SuggestBuilder - Class in org.elasticsearch.search.suggest
-
Defines how to perform suggesting.
- SuggestBuilder() - Constructor for class org.elasticsearch.search.suggest.SuggestBuilder
-
Build an empty SuggestBuilder.
- SuggestBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.SuggestBuilder
-
Read from a stream.
- SuggestBuilders - Class in org.elasticsearch.search.suggest
-
A static factory for building suggester lookup queries
- SuggestBuilders() - Constructor for class org.elasticsearch.search.suggest.SuggestBuilders
- Suggester<T extends SuggestionSearchContext.SuggestionContext> - Class in org.elasticsearch.search.suggest
- Suggester() - Constructor for class org.elasticsearch.search.suggest.Suggester
- SuggesterSpec(String, Writeable.Reader<T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SuggesterSpec
-
Specification of custom
Suggester
. - SuggesterSpec(ParseField, Writeable.Reader<T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SuggesterSpec
-
Specification of custom
Suggester
. - Suggestion() - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion
- Suggestion(String, int) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion
- SuggestionBuilder<T extends SuggestionBuilder<T>> - Class in org.elasticsearch.search.suggest
-
Base class for the different suggestion implementations.
- SuggestionBuilder(String) - Constructor for class org.elasticsearch.search.suggest.SuggestionBuilder
-
Creates a new suggestion.
- SuggestionBuilder(String, SuggestionBuilder<?>) - Constructor for class org.elasticsearch.search.suggest.SuggestionBuilder
-
internal copy constructor that copies over all class fields from second SuggestionBuilder except field name.
- SuggestionBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.SuggestionBuilder
-
Read from a stream.
- SuggestionContext(Suggester<?>, QueryShardContext) - Constructor for class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- suggestions() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext
- SuggestionSearchContext - Class in org.elasticsearch.search.suggest
- SuggestionSearchContext() - Constructor for class org.elasticsearch.search.suggest.SuggestionSearchContext
- SuggestionSearchContext.SuggestionContext - Class in org.elasticsearch.search.suggest
- suggestMode() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- suggestMode() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the suggest mode setting.
- suggestMode(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
The global suggest mode controls what suggested terms are included or controls for what suggest text tokens, terms should be suggested for.
- suggestMode(SuggestMode) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- suggestMode(TermSuggestionBuilder.SuggestMode) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
The global suggest mode controls what suggested terms are included or controls for what suggest text tokens, terms should be suggested for.
- SUGGESTMODE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- SuggestPhase - Class in org.elasticsearch.search.suggest
-
Suggest phase of a search request, used to collect suggestions
- SuggestPhase() - Constructor for class org.elasticsearch.search.suggest.SuggestPhase
- suggestShardSideQueueSize(int) - Static method in class org.elasticsearch.search.aggregations.bucket.BucketUtils
-
Heuristic used to determine the size of shard-side PriorityQueues when selecting the top N terms from a distributed index.
- sum - Variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- sum - Variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- sum - Variable in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- sum() - Method in class org.elasticsearch.common.metrics.MeanMetric
- sum(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Find the sum of a window of values If all values are missing/null/NaN, the return value will be 0.0
- sum(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Sum
aggregation with the given name. - Sum - Interface in org.elasticsearch.search.aggregations.metrics.sum
-
An aggregation that computes the sum of the values in the current bucket.
- SUM - org.elasticsearch.common.lucene.search.function.CombineFunction
- SUM - org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- SUM - org.elasticsearch.search.MultiValueMode
-
Pick the sum of all the values.
- SUM - org.elasticsearch.search.sort.SortMode
-
Use the sum of all values as sort value.
- SUM_OF_OTHER_DOC_COUNTS - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- SumAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.sum
- SumAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- SumAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
-
Read from a stream.
- SumAggregationBuilder(SumAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumAggregationBuilder
- SumAggregator - Class in org.elasticsearch.search.aggregations.metrics.sum
- SumAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.sum
- SumAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumAggregatorFactory
- sumBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
- SumBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum
- SumBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
- SumBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregationBuilder
-
Read from a stream.
- SumBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum
- SumBucketPipelineAggregator(String, String[], BucketHelpers.GapPolicy, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
- SumBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
-
Read from a stream.
- summary - Variable in class org.elasticsearch.cluster.service.MasterService.TaskInputs
- sumOfSquares - Variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- sumOtherDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- supersedes(ClusterState) - Method in class org.elasticsearch.cluster.ClusterState
-
a cluster state supersedes another state if they are from the same master and the version of this state is higher than that of the other state.
- supersetDf - Variable in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- supersetSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- supersetSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- supersetSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms
- supertypeOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type that represents an unknown supertype of
bound
. - SUPPORTS_V6 - Static variable in class org.elasticsearch.common.network.NetworkUtils
-
Deprecated.transition mechanism only, do not use
- supportsContentStream() - Method in class org.elasticsearch.rest.action.document.RestBulkAction
- supportsContentStream() - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- supportsContentStream() - Method in class org.elasticsearch.rest.DeprecationRestHandler
- supportsContentStream() - Method in interface org.elasticsearch.rest.RestHandler
-
Indicates if the RestHandler supports content as a stream.
- supportsDiffableValues() - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueSerializer
- supportsDiffableValues() - Method in class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- supportsDiffableValues() - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Whether this serializer supports diffable values
- supportsVersion(Diff<T>, Version) - Method in class org.elasticsearch.cluster.NamedDiffableValueSerializer
- supportsVersion(Diff<V>, Version) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Whether this serializer supports the version of the output stream
- supportsVersion(T, Version) - Method in class org.elasticsearch.cluster.NamedDiffableValueSerializer
- supportsVersion(V, Version) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Whether this serializer supports the version of the output stream
- SuppressLoggerChecks - Annotation Type in org.elasticsearch.common
-
Annotation to suppress logging usage checks errors inside a whole class or a method.
- SURVIVOR - Static variable in class org.elasticsearch.monitor.jvm.GcNames
- Swap(long, long) - Constructor for class org.elasticsearch.monitor.os.OsStats.Swap
- Swap(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsStats.Swap
- switchDoc(ParseContext.Document) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that has the provided document as the current document.
- SWITCHING_PROTOCOLS - org.elasticsearch.rest.RestStatus
-
The server understands and is willing to comply with the client's request, via the Upgrade message header field (section 14.42), for a change in the application protocol being used on this connection.
- sync() - Method in class org.elasticsearch.index.shard.IndexShard
- sync() - Method in class org.elasticsearch.index.translog.Translog
-
Sync's the translog.
- sync() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
write all buffered ops to disk and fsync file.
- sync(ResyncReplicationRequest, Task, String, long, ActionListener<ResyncReplicationResponse>) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- sync(ResyncReplicationRequest, Task, String, long, ActionListener<ResyncReplicationResponse>) - Method in interface org.elasticsearch.index.shard.PrimaryReplicaSyncer.SyncAction
- sync(ShardId, RetentionLeases, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
-
Sync the specified retention leases for the specified shard.
- sync(ShardId, RetentionLeases, ActionListener<ReplicationResponse>) - Method in interface org.elasticsearch.index.seqno.RetentionLeaseSyncer
-
Represents a method that when invoked syncs retention leases to replica shards after a new retention lease is added on the primary.
- sync(Translog.Location, Consumer<Exception>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Syncs the given location with the underlying storage unless already synced.
- SYNC_COMMIT_ID - Static variable in class org.elasticsearch.index.engine.Engine
- syncedFlush(SyncedFlushRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly sync flush one or more indices (write sync id to shards for faster recovery).
- syncedFlush(SyncedFlushRequest, ActionListener<SyncedFlushResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly sync flush one or more indices (write sync id to shards for faster recovery).
- SyncedFlushAction - Class in org.elasticsearch.action.admin.indices.flush
- syncedFlushRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a synced flush indices request.
- SyncedFlushRequest - Class in org.elasticsearch.action.admin.indices.flush
-
A synced flush request to sync flush one or more indices.
- SyncedFlushRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequest
-
Constructs a new synced flush request against one or more indices.
- SyncedFlushRequestBuilder - Class in org.elasticsearch.action.admin.indices.flush
- SyncedFlushRequestBuilder(ElasticsearchClient, SyncedFlushAction) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequestBuilder
- SyncedFlushResponse - Class in org.elasticsearch.action.admin.indices.flush
-
The result of performing a sync flush operation on all shards of multiple indices
- SyncedFlushResponse(Map<String, List<ShardsSyncedFlushResult>>) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- SyncedFlushService - Class in org.elasticsearch.indices.flush
- SyncedFlushService(IndicesService, ClusterService, TransportService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService
- SyncedFlushService.InFlightOpsRequest - Class in org.elasticsearch.indices.flush
- SyncedFlushService.PreShardSyncedFlushRequest - Class in org.elasticsearch.indices.flush
- SyncedFlushService.ShardSyncedFlushRequest - Class in org.elasticsearch.indices.flush
- SyncedFlushService.ShardSyncedFlushResponse - Class in org.elasticsearch.indices.flush
-
Response for third step of synced flush (writing the sync id) for one shard copy
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.engine.Engine
-
Attempts to do a special commit where the given syncID is put into the commit data.
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.engine.InternalEngine
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.shard.IndexShard
- syncId() - Method in class org.elasticsearch.index.engine.CommitStats
-
The synced-flush id of the commit if existed.
- syncId() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- syncId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- syncId() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- syncNeeded() - Method in class org.elasticsearch.index.translog.Translog
-
Returns
true
if an fsync is required to ensure durability of the translogs operations or it's metadata. - syncNeeded() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Returns
true
if there are buffered operations that have not been flushed and fsynced to disk or if the latest global checkpoint has not yet been fsynced - syncOperationResultOrThrow(Engine.Result, Translog.Location) - Static method in class org.elasticsearch.action.support.replication.TransportWriteAction
-
Syncs operation result to the translog or throws a shard not available failure
- syncRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Syncs the current retention leases to all replicas.
- syncTranslog() - Method in class org.elasticsearch.index.engine.Engine
- syncTranslog() - Method in class org.elasticsearch.index.engine.InternalEngine
- syncTranslog() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- syncUpTo(long) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Syncs the translog up to at least the given offset unless already synced
- SynonymGraphTokenFilterFactory - Class in org.elasticsearch.index.analysis
- SynonymGraphTokenFilterFactory(IndexSettings, Environment, AnalysisRegistry, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SynonymGraphTokenFilterFactory
- SynonymTokenFilterFactory - Class in org.elasticsearch.index.analysis
- SynonymTokenFilterFactory(IndexSettings, Environment, AnalysisRegistry, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
- SYSTEM_CALL_FILTER_SETTING - Static variable in class org.elasticsearch.bootstrap.BootstrapSettings
T
- T_TIME - org.elasticsearch.common.time.FormatNames
- T_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- Table - Class in org.elasticsearch.common
- Table() - Constructor for class org.elasticsearch.common.Table
- Table.Cell - Class in org.elasticsearch.common
- tag - Variable in class org.elasticsearch.ingest.AbstractProcessor
- TAG_KEY - Static variable in class org.elasticsearch.ingest.ConfigurationUtils
- tagsSchema(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Set a tag scheme that encapsulates a built in pre and post tags.
- take() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- TAR - org.elasticsearch.Build.Type
- target() - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection.RecoveryRef
- targetAllocationId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- targetNode - Variable in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- targetNode() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- targetNode() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- targetThrottling() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- task - Variable in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
-
the task object that is wrapped
- task - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- Task - Class in org.elasticsearch.tasks
-
Current task information
- Task(long, String, String, String, TaskId, long, long, Map<String, String>) - Constructor for class org.elasticsearch.tasks.Task
- Task(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.tasks.Task
- Task(DiscoveryNode, String) - Constructor for class org.elasticsearch.discovery.zen.ZenDiscovery.NodeRemovalClusterStateTaskExecutor.Task
- TASK_FAILURES - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- TASK_INDEX - Static variable in class org.elasticsearch.tasks.TaskResultsService
- TASK_RESULT_INDEX_MAPPING_FILE - Static variable in class org.elasticsearch.tasks.TaskResultsService
- TASK_RESULT_MAPPING_VERSION - Static variable in class org.elasticsearch.tasks.TaskResultsService
- TASK_RESULT_MAPPING_VERSION_META_FIELD - Static variable in class org.elasticsearch.tasks.TaskResultsService
- TASK_TYPE - Static variable in class org.elasticsearch.tasks.TaskResultsService
- Task.Status - Interface in org.elasticsearch.tasks
-
Report of the internal status of a task.
- TaskAwareRequest - Interface in org.elasticsearch.tasks
-
An interface for a request that can be used to register a task manager task
- TaskAwareTransportRequestHandler<T extends TransportRequest> - Class in org.elasticsearch.transport
-
Transport request handlers that is using task context
- TaskAwareTransportRequestHandler() - Constructor for class org.elasticsearch.transport.TaskAwareTransportRequestHandler
- TaskBatcher - Class in org.elasticsearch.cluster.service
-
Batching support for
PrioritizedEsThreadPoolExecutor
Tasks that share the same batching key are batched (seeTaskBatcher.BatchedTask.batchingKey
) - TaskBatcher(Logger, PrioritizedEsThreadPoolExecutor) - Constructor for class org.elasticsearch.cluster.service.TaskBatcher
- TaskBatcher.BatchedTask - Class in org.elasticsearch.cluster.service
-
Represents a runnable task that supports batching.
- TaskCancelledException - Exception in org.elasticsearch.tasks
-
A generic exception that can be thrown by a task when it's cancelled by the task manager API
- TaskCancelledException(String) - Constructor for exception org.elasticsearch.tasks.TaskCancelledException
- TaskCancelledException(StreamInput) - Constructor for exception org.elasticsearch.tasks.TaskCancelledException
- taskCount() - Method in class org.elasticsearch.common.StopWatch
-
Return the number of tasks timed.
- TaskGroup - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
Information about a currently running task and all its subtasks.
- TaskGroup(TaskInfo, List<TaskGroup>) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- TaskGroup.Builder - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
- taskId() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexClusterStateUpdateRequest
- TaskId - Class in org.elasticsearch.tasks
-
Task id that consists of node id and id of the task on the node
- TaskId(String) - Constructor for class org.elasticsearch.tasks.TaskId
- TaskId(String, long) - Constructor for class org.elasticsearch.tasks.TaskId
- taskInfo() - Method in class org.elasticsearch.common.StopWatch
-
Return an array of the data for tasks performed.
- taskInfo(String, boolean) - Method in class org.elasticsearch.tasks.Task
-
Build a version of the task status you can throw over the wire and back to the user.
- taskInfo(String, String, Task.Status) - Method in class org.elasticsearch.tasks.Task
-
Build a proper
TaskInfo
for this task. - TaskInfo - Class in org.elasticsearch.tasks
-
Information about a currently running task.
- TaskInfo(StreamInput) - Constructor for class org.elasticsearch.tasks.TaskInfo
-
Read from a stream.
- TaskInfo(TaskId, String, String, String, Task.Status, long, long, boolean, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.tasks.TaskInfo
- taskInfoGivenSubtaskInfo(String, List<TaskInfo>) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Build the status for this task given a snapshot of the information of running slices.
- TaskListener<Response> - Interface in org.elasticsearch.tasks
-
Listener for Task success or failure.
- taskManager - Variable in class org.elasticsearch.action.support.TransportAction
- taskManager - Variable in class org.elasticsearch.transport.TransportService
- TaskManager - Class in org.elasticsearch.tasks
-
Task Manager service for keeping track of currently running tasks on the nodes
- TaskManager(Settings, ThreadPool, Set<String>) - Constructor for class org.elasticsearch.tasks.TaskManager
- taskMap() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- taskOperation(CancelTasksRequest, CancellableTask, ActionListener<TaskInfo>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- taskOperation(ListTasksRequest, Task, ActionListener<TaskInfo>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- taskOperation(TasksRequest, OperationTask, ActionListener<TaskResponse>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
Perform the required operation on the task.
- TaskOperationFailure - Class in org.elasticsearch.action
-
Information about task operation failures The class is final due to serialization limitations
- TaskOperationFailure(String, long, Exception) - Constructor for class org.elasticsearch.action.TaskOperationFailure
- TaskOperationFailure(StreamInput) - Constructor for class org.elasticsearch.action.TaskOperationFailure
-
Read from a stream.
- TaskResult - Class in org.elasticsearch.tasks
-
Information about a running task or a task that stored its result.
- TaskResult(boolean, TaskInfo) - Constructor for class org.elasticsearch.tasks.TaskResult
-
Construct a TaskResult for a task for which we don't have a result or error.
- TaskResult(StreamInput) - Constructor for class org.elasticsearch.tasks.TaskResult
-
Read from a stream.
- TaskResult(TaskInfo, Exception) - Constructor for class org.elasticsearch.tasks.TaskResult
-
Construct a TaskResult for a task that completed with an error.
- TaskResult(TaskInfo, ToXContent) - Constructor for class org.elasticsearch.tasks.TaskResult
-
Construct a TaskResult for a task that completed successfully.
- taskResultIndexMapping() - Method in class org.elasticsearch.tasks.TaskResultsService
- TaskResultsService - Class in org.elasticsearch.tasks
-
Service that can store task results.
- TaskResultsService(Client, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.tasks.TaskResultsService
- tasks() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- TASKS_ORIGIN - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskAction
- TasksRequestBuilder<Request extends BaseTasksRequest<Request>,Response extends BaseTasksResponse,RequestBuilder extends TasksRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.tasks
-
Builder for task-based requests
- TasksRequestBuilder(ElasticsearchClient, Action<Request, Response, RequestBuilder>, Request) - Constructor for class org.elasticsearch.action.support.tasks.TasksRequestBuilder
- TaskTransportChannel - Class in org.elasticsearch.transport
- TB - org.elasticsearch.common.unit.ByteSizeUnit
- TCP_CONNECT_TIMEOUT - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_CONNECT_TIMEOUT - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_ALIVE - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_KEEP_ALIVE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_ALIVE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_NO_DELAY - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_NO_DELAY - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_NO_DELAY_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_RECEIVE_BUFFER_SIZE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_REUSE_ADDRESS - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_REUSE_ADDRESS - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_REUSE_ADDRESS_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_SEND_BUFFER_SIZE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TcpChannel - Interface in org.elasticsearch.transport
-
This is a tcp channel representing a single channel connection to another node.
- TcpChannel.ChannelStats - Class in org.elasticsearch.transport
- TcpHeader - Class in org.elasticsearch.transport
- TcpHeader() - Constructor for class org.elasticsearch.transport.TcpHeader
- tcpKeepAlive - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- tcpNoDelay - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- TcpServerChannel - Interface in org.elasticsearch.transport
-
This is a tcp channel representing a server channel listening for new connections.
- TcpTransport - Class in org.elasticsearch.transport
- TcpTransport(String, Settings, Version, ThreadPool, PageCacheRecycler, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Constructor for class org.elasticsearch.transport.TcpTransport
- TcpTransport.HttpOnTransportException - Exception in org.elasticsearch.transport
-
A helper exception to mark an incoming connection as potentially being HTTP so an appropriate error code can be returned
- TcpTransport.NodeChannels - Class in org.elasticsearch.transport
- TcpTransport.ProfileSettings - Class in org.elasticsearch.transport
-
Representation of a transport profile settings for a
transport.profiles.$profilename.*
- TcpTransportChannel - Class in org.elasticsearch.transport
- TDIGEST - org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
-
The TDigest method for calculating percentiles
- TDigestPercentileRanksAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- TDigestPercentileRanksAggregator(String, ValuesSource.Numeric, SearchContext, Aggregator, double[], double, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregator
- TDigestPercentileRanksAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- TDigestPercentileRanksAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], double, boolean, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregatorFactory
- TDigestPercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- TDigestPercentilesAggregator(String, ValuesSource.Numeric, SearchContext, Aggregator, double[], double, boolean, DocValueFormat, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregator
- TDigestPercentilesAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
- TDigestPercentilesAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], double, boolean, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregatorFactory
- TDigestState - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
-
Extension of
TDigest
with custom serialization. - TDigestState(double) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
- tempBlobName(String) - Static method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- template() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutResponse
- TEMPLATE_NO_WRAPPER_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for query on the inner field. - TEMPLATE_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for outer level of stored script source. - templates() - Method in class org.elasticsearch.cluster.metadata.MetaData
- templates(ImmutableOpenMap<String, IndexTemplateMetaData>) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- TemplateScript - Class in org.elasticsearch.script
-
A string template rendered as a script.
- TemplateScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.TemplateScript
- TemplateScript.Factory - Interface in org.elasticsearch.script
- TemplateUpgradeService - Class in org.elasticsearch.cluster.metadata
-
Upgrades Templates on behalf of installed
Plugin
s when a node joins the cluster - TemplateUpgradeService(Client, ClusterService, ThreadPool, Collection<UnaryOperator<Map<String, IndexTemplateMetaData>>>) - Constructor for class org.elasticsearch.cluster.metadata.TemplateUpgradeService
- TEMPORARY_REDIRECT - org.elasticsearch.rest.RestStatus
-
The requested resource resides temporarily under a different URI.
- tera() - Method in class org.elasticsearch.common.unit.SizeValue
- TERA - org.elasticsearch.common.unit.SizeUnit
- teraFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- term - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- term() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- TERM - org.elasticsearch.common.geo.SpatialStrategy
- terminate(ExecutorService, long, TimeUnit) - Static method in class org.elasticsearch.threadpool.ThreadPool
-
Returns
true
if the given service was terminated successfully. - terminate(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in interface org.elasticsearch.threadpool.Scheduler
- terminate(ThreadPool, long, TimeUnit) - Static method in class org.elasticsearch.threadpool.ThreadPool
-
Returns
true
if the given pool was terminated successfully. - TERMINATE_AFTER_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- terminateAfter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the number of documents to terminate after collecting.
- terminateAfter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- terminateAfter() - Method in class org.elasticsearch.search.internal.SearchContext
- terminateAfter(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
An optional terminate_after to terminate the search after collecting
terminateAfter
documents - terminateAfter(int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- terminateAfter(int) - Method in class org.elasticsearch.search.internal.SearchContext
- terminateAfter(int) - Method in class org.elasticsearch.search.internal.SubSearchContext
- terminated() - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- terminatedEarly - Variable in class org.elasticsearch.action.search.SearchResponseSections
- terminatedEarly() - Method in class org.elasticsearch.action.search.SearchResponseSections
- terminatedEarly() - Method in class org.elasticsearch.search.query.QuerySearchResult
- terminatedEarly(boolean) - Method in class org.elasticsearch.search.query.QuerySearchResult
- termQuery(Object, QueryShardContext) - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- termQuery(Object, QueryShardContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- termQuery(Object, QueryShardContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- termQuery(Object, QueryShardContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- termQuery(Object, QueryShardContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- termQuery(Object, QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Generates a query that will only match documents that contain the given value.
- termQuery(Object, QueryShardContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- termQuery(Object, QueryShardContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- termQuery(String, boolean) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, double) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, float) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, long) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, Object) - Method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- termQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- TermQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents containing a term.
- TermQueryBuilder(String, boolean) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Read from a stream.
- terms - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- terms() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- terms(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsFields
- terms(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Terms
aggregation with the given name. - Terms - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
A
terms
aggregation. - Terms.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
A bucket that is associated with a single term
- termsAggFactory - Variable in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
- termsAggFactory - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
- TermsAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms
- TermsAggregationBuilder(String, ValueType) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- TermsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Read from a stream.
- TermsAggregationBuilder(TermsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- TermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
- TermsAggregator(String, AggregatorFactories, SearchContext, Aggregator, TermsAggregator.BucketCountThresholds, BucketOrder, DocValueFormat, Aggregator.SubAggCollectionMode, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- TermsAggregator.BucketCountThresholds - Class in org.elasticsearch.search.aggregations.bucket.terms
- TermsAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.terms
- TermsAggregatorFactory.ExecutionMode - Enum in org.elasticsearch.search.aggregations.bucket.terms
- termsLookup() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- TermsLookup - Class in org.elasticsearch.indices
-
Encapsulates the parameters needed to fetch terms.
- TermsLookup(String, String, String, String) - Constructor for class org.elasticsearch.indices.TermsLookup
- TermsLookup(StreamInput) - Constructor for class org.elasticsearch.indices.TermsLookup
-
Read from a stream.
- termsLookupQuery(String, TermsLookup) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A terms query that can extract the terms from another doc in an index.
- termsQuery(String, double...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- termsQuery(String, float...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- termsQuery(String, int...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- termsQuery(String, long...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- termsQuery(String, Object...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- termsQuery(String, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- termsQuery(String, Collection<?>) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- termsQuery(String, List<Object>) - Method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- termsQuery(List<?>, QueryShardContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- termsQuery(List<?>, QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Build a constant-scoring query that matches all values.
- termsQuery(List<?>, QueryShardContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- termsQuery(List, QueryShardContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- TermsQueryBuilder - Class in org.elasticsearch.index.query
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, double...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, float...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, int...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, long...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, Iterable<?>) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, Object...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, String...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, TermsLookup) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
- TermsQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
Read from a stream.
- TermsSetQueryBuilder - Class in org.elasticsearch.index.query
- TermsSetQueryBuilder(String, List<?>) - Constructor for class org.elasticsearch.index.query.TermsSetQueryBuilder
- TermsSetQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.TermsSetQueryBuilder
- TermsSetQueryScript - Class in org.elasticsearch.script
- TermsSetQueryScript(Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.TermsSetQueryScript
- TermsSetQueryScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
TermsSetQueryScript
factories for a specific index. - TermsSetQueryScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
TermsSetQueryScript
instances. - TermsSliceQuery - Class in org.elasticsearch.search.slice
-
A
SliceQuery
that uses the terms dictionary of a field to do the slicing. - TermsSliceQuery(String, int, int) - Constructor for class org.elasticsearch.search.slice.TermsSliceQuery
- termsStatistics(Term[], TermStatistics[]) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- termStatistics() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- termStatistics() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
- termStatistics() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- termStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the term statistics for each term in the shard or skip.
- termStatistics(Term, TermContext) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- TermStatistics - org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- TermSuggester - Class in org.elasticsearch.search.suggest.term
- termSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a term suggestion lookup query with the provided
field
- TermSuggestion - Class in org.elasticsearch.search.suggest.term
-
The suggestion responses corresponding with the suggestions in the request.
- TermSuggestion() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion
- TermSuggestion(String, int, SortBy) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion
- TermSuggestion.Entry - Class in org.elasticsearch.search.suggest.term
-
Represents a part from the suggest text with suggested options.
- TermSuggestion.Entry.Option - Class in org.elasticsearch.search.suggest.term
-
Contains the suggested text with its document frequency and score.
- TermSuggestion.Frequency - Class in org.elasticsearch.search.suggest.term
- TermSuggestion.Score - Class in org.elasticsearch.search.suggest.term
- TermSuggestionBuilder - Class in org.elasticsearch.search.suggest.term
-
Defines the actual suggest command.
- TermSuggestionBuilder(String) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- TermSuggestionBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Read from a stream.
- TermSuggestionBuilder.StringDistanceImpl - Enum in org.elasticsearch.search.suggest.term
-
An enum representing the valid string edit distance algorithms for determining suggestions.
- TermSuggestionBuilder.SuggestMode - Enum in org.elasticsearch.search.suggest.term
-
An enum representing the valid suggest modes.
- TermsValuesSourceBuilder - Class in org.elasticsearch.search.aggregations.bucket.composite
- TermsValuesSourceBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- TermsValuesSourceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- termVector(TermVectorsRequest) - Method in interface org.elasticsearch.client.Client
-
Deprecated.
- termVector(TermVectorsRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
Deprecated.
- termVector(TermVectorsRequest, ActionListener<TermVectorsResponse>) - Method in interface org.elasticsearch.client.Client
-
Deprecated.
- termVector(TermVectorsRequest, ActionListener<TermVectorsResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
Deprecated.
- termVectorOptionsToString(FieldType) - Static method in class org.elasticsearch.index.mapper.FieldMapper
- termVectors(TermVectorsRequest) - Method in interface org.elasticsearch.client.Client
-
An action that returns the term vectors for a specific document.
- termVectors(TermVectorsRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- termVectors(TermVectorsRequest, ActionListener<TermVectorsResponse>) - Method in interface org.elasticsearch.client.Client
-
An action that returns the term vectors for a specific document.
- termVectors(TermVectorsRequest, ActionListener<TermVectorsResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- TermVectorsAction - Class in org.elasticsearch.action.termvectors
- TermVectorsFields - Class in org.elasticsearch.action.termvectors
-
This class represents the result of a
TermVectorsRequest
. - TermVectorsFields(BytesReference, BytesReference) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsFields
- TermVectorsFilter - Class in org.elasticsearch.action.termvectors
- TermVectorsFilter(Fields, Fields, Set<String>, AggregatedDfs) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsFilter
- TermVectorsFilter.ScoreTerm - Class in org.elasticsearch.action.termvectors
- TermVectorsRequest - Class in org.elasticsearch.action.termvectors
-
Request returning the term vector (doc frequency, positions, offsets) for a document.
- TermVectorsRequest() - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
- TermVectorsRequest(String, String, String) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Constructs a new term vector request for a document that will be fetch from the provided index.
- TermVectorsRequest(MultiGetRequest.Item) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
- TermVectorsRequest(TermVectorsRequest) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Constructs a new term vector request for a document that will be fetch from the provided index.
- TermVectorsRequest.FilterSettings - Class in org.elasticsearch.action.termvectors
- TermVectorsRequest.Flag - Enum in org.elasticsearch.action.termvectors
- TermVectorsRequestBuilder - Class in org.elasticsearch.action.termvectors
-
The builder class for a term vector request.
- TermVectorsRequestBuilder(ElasticsearchClient, TermVectorsAction) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
- TermVectorsRequestBuilder(ElasticsearchClient, TermVectorsAction, String, String, String) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Constructs a new term vector request builder for a document that will be fetch from the provided index.
- TermVectorsResponse - Class in org.elasticsearch.action.termvectors
- TermVectorsResponse(String, String, String) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsResponse
- TermVectorsService - Class in org.elasticsearch.index.termvectors
- TEST_MOCK_TRANSPORT_THREAD_PREFIX - Static variable in enum org.elasticsearch.transport.Transports
-
threads whose name is prefixed by this string will be considered network threads, even though they aren't
- testBlobPrefix(String) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- text - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- text - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- text() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- text() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the text for this suggestion
- text(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Same as in
SuggestBuilder.setGlobalText(String)
, but in the suggestion scope. - text(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- Text - Class in org.elasticsearch.common.text
-
Both
String
andBytesReference
representation of the text. - Text(String) - Constructor for class org.elasticsearch.common.text.Text
- Text(BytesReference) - Constructor for class org.elasticsearch.common.text.Text
- TEXT - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- TEXT - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- TEXT_CONTENT_TYPE - Static variable in class org.elasticsearch.rest.BytesRestResponse
- TEXT_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- TEXT_PROMPT_VALUE - Static variable in class org.elasticsearch.node.InternalSettingsPreparer
- TextFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for full-text fields. - TextFieldMapper(String, TextFieldMapper.TextFieldType, MappedFieldType, int, Boolean, TextFieldMapper.PrefixFieldMapper, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper
- TextFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- TextFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- TextFieldMapper.TextFieldType - Class in org.elasticsearch.index.mapper
- TextFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- TextFieldType() - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- TextFieldType(TextFieldMapper.TextFieldType) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- THREAD_POOL_TYPES - Static variable in class org.elasticsearch.threadpool.ThreadPool
- threadContext - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Allows processors to read headers set by
ActionFilter
instances that have run prior to in ingest. - threadContext - Variable in class org.elasticsearch.transport.NetworkMessage
- ThreadContext - Class in org.elasticsearch.common.util.concurrent
-
A ThreadContext is a map of string headers and a transient map of keyed objects that are associated with a thread.
- ThreadContext(Settings) - Constructor for class org.elasticsearch.common.util.concurrent.ThreadContext
-
Creates a new ThreadContext instance
- ThreadContext.StoredContext - Interface in org.elasticsearch.common.util.concurrent
- ThreadedActionListener<Response> - Class in org.elasticsearch.action.support
-
An action listener that wraps another action listener and threading its execution.
- ThreadedActionListener(Logger, ThreadPool, String, ActionListener<Response>, boolean) - Constructor for class org.elasticsearch.action.support.ThreadedActionListener
- ThreadedActionListener.Wrapper - Class in org.elasticsearch.action.support
-
Wrapper that can be used to automatically wrap a listener in a threaded listener if needed.
- threadedListener() - Method in enum org.elasticsearch.action.ThreadingModel
-
true
if the invocation of the action result listener will be executed on a different thread (than the calling thread or an "expensive" thread, like the IO thread). - threadedOperation() - Method in enum org.elasticsearch.action.ThreadingModel
-
true
if the actual operation the action represents will be executed on a different thread than the calling thread (assuming it will be executed on the same node). - threadElementsSnapshotCount(int) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- threadElementsSnapshotDelay(TimeValue) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- ThreadingModel - Enum in org.elasticsearch.action
- threadName(String, String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- threadName(Settings, String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- threadName(Settings, String...) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- threadPool - Variable in class org.elasticsearch.action.support.TransportAction
- threadPool - Variable in class org.elasticsearch.cluster.metadata.TemplateUpgradeService
- threadPool - Variable in class org.elasticsearch.cluster.service.ClusterApplierService
- threadPool - Variable in class org.elasticsearch.cluster.service.MasterService
- threadPool - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- threadPool - Variable in class org.elasticsearch.index.reindex.ScrollableHitSource
- threadPool - Variable in class org.elasticsearch.transport.TcpTransport
- threadPool - Variable in class org.elasticsearch.transport.TransportService
- threadPool() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node Thread Pool info be returned.
- threadPool() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node Thread Pool be returned.
- threadPool() - Method in interface org.elasticsearch.client.ElasticsearchClient
-
Returns the threadpool used to execute requests on this client
- threadPool() - Method in class org.elasticsearch.client.support.AbstractClient
- threadPool(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node Thread Pool info be returned.
- threadPool(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node Thread Pool be returned.
- ThreadPool - Class in org.elasticsearch.threadpool
- ThreadPool(Settings, ExecutorBuilder<?>...) - Constructor for class org.elasticsearch.threadpool.ThreadPool
- ThreadPool.Info - Class in org.elasticsearch.threadpool
- ThreadPool.Names - Class in org.elasticsearch.threadpool
- ThreadPool.ThreadPoolType - Enum in org.elasticsearch.threadpool
- ThreadPoolInfo - Class in org.elasticsearch.threadpool
- ThreadPoolInfo(List<ThreadPool.Info>) - Constructor for class org.elasticsearch.threadpool.ThreadPoolInfo
- ThreadPoolInfo(StreamInput) - Constructor for class org.elasticsearch.threadpool.ThreadPoolInfo
- ThreadPoolStats - Class in org.elasticsearch.threadpool
- ThreadPoolStats(List<ThreadPoolStats.Stats>) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats
- ThreadPoolStats(StreamInput) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats
- ThreadPoolStats.Stats - Class in org.elasticsearch.threadpool
- threads() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- threads(int) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- Threads(int, int) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Threads
- Threads(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Threads
- THRESHOLD_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- throttle(List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns a THROTTLE decision, with the individual node-level decisions that comprised the final THROTTLE decision if in explain mode.
- THROTTLE - org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- THROTTLE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- THROTTLED - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The allocation attempt was throttled for the shard.
- THROTTLED_HR_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- THROTTLED_RAW_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- THROTTLED_UNTIL_HR_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- THROTTLED_UNTIL_RAW_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- throttleTime() - Method in class org.elasticsearch.index.recovery.RecoveryStats
-
Total time recoveries waited due to throttling
- throttleWaitTime(TimeValue, TimeValue, int) - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- ThrottlingAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
ThrottlingAllocationDecider
controls the recovery process per node in the cluster. - ThrottlingAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- throwConfigurationExceptionIfErrorsExist() - Method in class org.elasticsearch.common.inject.internal.Errors
- throwCreationExceptionIfErrorsExist() - Method in class org.elasticsearch.common.inject.internal.Errors
- throwIfNewErrors(int) - Method in class org.elasticsearch.common.inject.internal.Errors
- throwParsingExceptionOnMultipleFields(String, XContentLocation, String, String) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
- throwParsingExceptionOnMultipleFields(String, XContentLocation, String, String) - Static method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- throwProvisionExceptionIfErrorsExist() - Method in class org.elasticsearch.common.inject.internal.Errors
- throwUnknownField(String, XContentLocation) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
- throwUnknownToken(XContentParser.Token, XContentLocation) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
- tieBreakActiveMasters(Collection<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
-
selects the best active master to join, where multiple are discovered
- tieBreaker() - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- tieBreaker() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- tieBreaker() - Method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- tieBreaker() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- tieBreaker(float) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
-
The score of each non-maximum disjunct for a document is multiplied by this weight and added into the final score.
- tieBreaker(float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Tie-Breaker for "best-match" disjunction queries (OR-Queries).
- tieBreaker(float) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
When more than one field is used with the query string, and combined queries are using dis max, control the tie breaker for it.
- tieBreaker(Float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Tie-Breaker for "best-match" disjunction queries (OR-Queries).
- time - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- time() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot running time
- time() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
Returns elapsed time in millis, or 0 if timer was not started
- time() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit fraction of second, and time zone offset (HH:mm:ss.SSSZZ).
- TIME - org.elasticsearch.common.time.FormatNames
- TIME_FIELD - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- timedOut - Variable in class org.elasticsearch.action.search.SearchResponseSections
- timedOut() - Method in class org.elasticsearch.action.search.SearchResponseSections
- timeElementParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO time parser.
- timeEstimateCounter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- timeEstimateCounter() - Method in class org.elasticsearch.search.internal.SearchContext
- timeEstimateCounter() - Method in class org.elasticsearch.search.internal.SubSearchContext
- timeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset (HH:mm:ssZZ).
- timeout - Variable in class org.elasticsearch.action.bulk.BulkRequest
- timeout - Variable in class org.elasticsearch.action.support.master.AcknowledgedRequest
- timeout - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
- timeout - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- timeout() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- timeout() - Method in class org.elasticsearch.action.bulk.BulkRequest
- timeout() - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Returns the current timeout
- timeout() - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- timeout() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- timeout() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- timeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- timeout() - Method in class org.elasticsearch.cluster.ClusterStateTaskConfig.Basic
- timeout() - Method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
The timeout for this cluster state update task configuration.
- timeout() - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
If the cluster state update task wasn't processed by the provided timeout, call
ClusterStateTaskListener.onFailure(String, Exception)
. - timeout() - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- timeout() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the timeout to control how long search is allowed to take.
- timeout() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- timeout() - Method in class org.elasticsearch.search.internal.SearchContext
- timeout() - Method in class org.elasticsearch.transport.TransportRequestOptions
- timeout(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- timeout(String) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(String) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Allows to set the timeout
- timeout(String) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- timeout(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(String) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- timeout(TimeValue) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Allows to set the timeout
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Timeout to wait for the shards on to be available for each bulk request.
- timeout(TimeValue) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
An optional timeout to control how long search is allowed to take.
- timeout(TimeValue) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- timeout(TimeValue) - Method in class org.elasticsearch.search.internal.SearchContext
- timeout(TimeValue) - Method in class org.elasticsearch.search.internal.SubSearchContext
- TIMEOUT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- TimeoutClusterStateListener - Interface in org.elasticsearch.cluster
-
An exception to cluster state listener that allows for timeouts and for post added notifications.
- timeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO time parser for parsing times with a possible zone.
- Timer - Class in org.elasticsearch.search.profile
-
Helps measure how much time is spent running some methods.
- Timer() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Timer
- Timer() - Constructor for class org.elasticsearch.search.profile.Timer
- Timer(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Timer
- timeSetting(String, Function<Settings, TimeValue>, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, Setting<TimeValue>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, Setting<TimeValue>, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, TimeValue, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, TimeValue, TimeValue, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timestamp() - Method in exception org.elasticsearch.action.TimestampParsingException
- timestamp() - Method in class org.elasticsearch.index.seqno.RetentionLease
-
The timestamp of when this retention lease was created or renewed.
- TIMESTAMP - Static variable in class org.elasticsearch.common.Table
- TimestampParsingException - Exception in org.elasticsearch.action
- TimestampParsingException(String) - Constructor for exception org.elasticsearch.action.TimestampParsingException
- TimestampParsingException(String, Throwable) - Constructor for exception org.elasticsearch.action.TimestampParsingException
- TimestampParsingException(StreamInput) - Constructor for exception org.elasticsearch.action.TimestampParsingException
- timezone() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- timezone(DateTimeZone) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- timeZone() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- timeZone() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
In case of date field, gets the from/to fields timezone adjustment
- timeZone() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Gets the time zone to use for this aggregation
- timeZone() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the time zone to use for this aggregation
- timeZone() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- timeZone(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
In case of date field, we can adjust the from/to fields using a timezone
- timeZone(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
In case of date field, we can adjust the from/to fields using a timezone
- timeZone(DateTimeZone) - Method in class org.elasticsearch.common.rounding.Rounding.Builder
- timeZone(DateTimeZone) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- timeZone(DateTimeZone) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Sets the time zone to use for this aggregation
- timeZone(DateTimeZone) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the time zone to use for this aggregation
- timings - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
- tmpFile() - Method in class org.elasticsearch.env.Environment
-
Path to the default temp directory used by the JDK
- to - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- to - Variable in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- to - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- to() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the upper range value for this query.
- to(boolean) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(boolean) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(char) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(char) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(double) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(double) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(float) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(float) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(int) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(int) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(long) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(long) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(short) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(short) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(E) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(E) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(Class<?>) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(Class<?>) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(Class<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - to(Class<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- to(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(Object, boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(String) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(String) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(Key<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - to(Key<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- to(TypeLiteral<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - to(TypeLiteral<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- TO - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- TO_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- TO_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- TO_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- toAddrString(InetAddress) - Static method in class org.elasticsearch.common.network.InetAddresses
-
Returns the string representation of an
InetAddress
. - toArray() - Method in class org.elasticsearch.common.blobstore.BlobPath
- toArray() - Method in class org.elasticsearch.common.collect.EvictingQueue
- toArray() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- toArray(E[]) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Copies the content of the underlying atomic array to a normal one.
- toArray(Collection<Integer>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- toArray(T[]) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- toArray(T1[]) - Method in class org.elasticsearch.common.collect.EvictingQueue
- toAsStr - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- toAsString - Variable in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- toBiConsumer(ActionListener<Response>) - Static method in interface org.elasticsearch.action.ActionListener
-
Converts a listener to a
BiConsumer
for compatibility with theCompletableFuture
api. - toBooleanClauseOccur() - Method in enum org.elasticsearch.index.query.Operator
- toByteExact(Number) - Static method in class org.elasticsearch.common.Numbers
-
Return the byte that
n
stores, or throws an exception if the stored value cannot be converted to a byte that stores the exact same value. - toBytes(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
- toBytes(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
- toBytes(BytesReference) - Static method in class org.elasticsearch.common.bytes.BytesReference
-
Returns a compact array from the given BytesReference.
- toBytesRef() - Method in class org.elasticsearch.common.bytes.ByteBufferReference
-
This will return a bytes ref composed of the bytes.
- toBytesRef() - Method in class org.elasticsearch.common.bytes.BytesArray
- toBytesRef() - Method in class org.elasticsearch.common.bytes.BytesReference
-
Converts to Lucene BytesRef.
- toBytesRef() - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- toBytesRef() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- toBytesRef() - Method in class org.elasticsearch.index.mapper.Uid
- toBytesRef(Object) - Static method in class org.elasticsearch.common.lucene.BytesRefs
-
Converts an object value to BytesRef.
- toBytesRef(Object, BytesRefBuilder) - Static method in class org.elasticsearch.common.lucene.BytesRefs
- toConcreteKey(String) - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- toContextQuery(CompletionQuery, Map<String, List<ContextMapping.InternalQueryContext>>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Wraps a
CompletionQuery
with context queries - toDateMathParser() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- toDateMathParser() - Method in interface org.elasticsearch.common.time.DateFormatter
-
Return a
DateMathParser
built from this formatter. - toDelimitedString(char) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the settings as delimited string.
- toException() - Method in class org.elasticsearch.common.inject.internal.Errors
- toFilter(ClusterService, ShardSearchRequest, QueryShardContext, Version) - Method in class org.elasticsearch.search.slice.SliceBuilder
-
Converts this QueryBuilder to a lucene
Query
. - toFilter(QueryBuilder) - Method in class org.elasticsearch.index.query.QueryShardContext
- toFilter(QueryShardContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- toFilter(QueryShardContext) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Converts this QueryBuilder to an unscored lucene
Query
that acts as a filter. - toFilter(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- toFiniteStrings(TokenStream) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
- toFunction(QueryShardContext) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Called on a data node, converts this ScoreFunctionBuilder into its corresponding Lucene function object.
- toGB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
- toGiga(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
- toHexString(byte[]) - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Format a byte array as a hex string.
- toInnerXContent(IndexTemplateMetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchHit
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Implementations should add specific configurations that need to be persisted
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- toInstance(T) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - toInstance(T) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toInstant() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toInternalQueryContexts(List<CategoryQueryContext>) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
-
Parse a list of
CategoryQueryContext
usingparser
. - toInternalQueryContexts(List<GeoQueryContext>) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
-
Parse a list of
GeoQueryContext
usingparser
. - toInternalQueryContexts(List<T>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Convert query contexts to common representation
- toIntExact(Number) - Static method in class org.elasticsearch.common.Numbers
-
Return the int that
n
stores, or throws an exception if the stored value cannot be converted to an int that stores the exact same value. - toJsonString() - Method in exception org.elasticsearch.script.ScriptException
-
Returns a JSON version of this exception for debugging.
- toKB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
- token(XContentParser, String, XContentParser.Token, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsParser
- token(XContentParser, String, XContentParser.Token, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketParser
- TOKEN_FILTERS - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- TOKEN_LIMIT_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- TokenConsumer() - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- TokenFilterFactory - Interface in org.elasticsearch.index.analysis
- tokenfilters() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- tokenfilters(DetailAnalyzeResponse.AnalyzeTokenList[]) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- tokenFilters() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- tokenFilters() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- tokenizeByCommaToSet(String) - Static method in class org.elasticsearch.common.Strings
-
Tokenize the specified string by commas to a set, trimming whitespace and ignoring empty tokens.
- tokenizer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- tokenizer() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- tokenizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- tokenizer(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- tokenizer(DetailAnalyzeResponse.AnalyzeTokenList) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- TOKENIZER - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- tokenizerFactory - Variable in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
-
Deprecated.This filter tokenize synonyms with whatever tokenizer and token filters appear before it in the chain in 6.0.
- tokenizerFactory() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- TokenizerFactory - Interface in org.elasticsearch.index.analysis
- tokenizeToStringArray(String, String) - Static method in class org.elasticsearch.common.Strings
-
Tokenize the given String into a String array via a StringTokenizer.
- tokenLimit() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the
PhraseSuggestionBuilder.tokenLimit(int)
parameter - tokenLimit(int) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.common.lucene.all.AllField
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- tokenStream(Analyzer, BytesRef, CharsRefBuilder, String) - Method in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
- toKilo(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
- TOLERANCE - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
rounding error for quantized latitude and longitude values
- toList() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingCollection
-
serialize current pings to a list.
- toLocalDate() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toLocalDateTime() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toLong(String, boolean) - Static method in class org.elasticsearch.common.Numbers
-
Return the long that
stringValue
stores or throws an exception if the stored value cannot be converted to a long that stores the exact same value andcoerce
is false. - toLongExact(Number) - Static method in class org.elasticsearch.common.Numbers
-
Return the long that
n
stores, or throws an exception if the stored value cannot be converted to a long that stores the exact same value. - toLucene() - Method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
- toLucene() - Method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
- toMap() - Method in class org.elasticsearch.tasks.RawTaskStatus
-
Convert the from XContent to a Map for easy reading.
- toMB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
- TOMBSTONE_NAME - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- tombstoneField - Variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- tombstones() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
-
A copy of the current tombstones in the builder.
- toMega(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
- toMeters(double) - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Convert a value into meters
- toNode() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- TOO_MANY_REQUESTS - org.elasticsearch.rest.RestStatus
-
429 Too Many Requests (RFC6585)
- toOffsetDateTime() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- TOOL - org.elasticsearch.common.inject.Stage
-
We're running in a tool (an IDE plugin for example).
- TooManyBucketsException(String, int) - Constructor for exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- TooManyBucketsException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- tooManyConstructors(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- TOP_TERMS - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- TOP_TERMS_BLENDED_FREQS - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- TOP_TERMS_BOOST - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- toPB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
- topDocs() - Method in class org.elasticsearch.search.query.QuerySearchResult
- topDocs(TopDocs, DocValueFormat[]) - Method in class org.elasticsearch.search.query.QuerySearchResult
- topDocs(SearchHit[]) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- toPeta(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
- topHits(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
TopHits
aggregation with the given name. - TopHits - Interface in org.elasticsearch.search.aggregations.metrics.tophits
-
Accumulation of the most relevant hits for a bucket this aggregation falls into.
- TopHitsAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.tophits
- TopHitsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- TopHitsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Read from a stream.
- TopHitsAggregationBuilder(TopHitsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
- TopHitsAggregator - Class in org.elasticsearch.search.aggregations.metrics.tophits
- TopHitsAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.tophits
- topLeft() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- topLeft() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns the top left corner of the bounding box.
- topLeft() - Method in interface org.elasticsearch.search.aggregations.metrics.geobounds.GeoBounds
-
Get the top-left location of the bounding box.
- topLeft() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
- topLeft() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.ParsedGeoBounds
- topLevelQuery(Term[], TermContext[], int[], int) - Method in class org.apache.lucene.queries.BlendedTermQuery
- topLevelReader() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- toPolygonLucene() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- toPolygonS4J() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- toPolygonS4J(GeometryFactory) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- toProvider(Class<? extends Provider<? extends T>>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - toProvider(Class<? extends Provider<? extends T>>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toProvider(Key<? extends Provider<? extends T>>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - toProvider(Key<? extends Provider<? extends T>>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toProvider(Provider<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - toProvider(Provider<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toQuery(QueryBuilder) - Method in class org.elasticsearch.index.query.QueryShardContext
- toQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- toQuery(QueryShardContext) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Converts this QueryBuilder to a lucene
Query
. - toQuery(QueryShardContext) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- toQueryParserOperator() - Method in enum org.elasticsearch.index.query.Operator
- toShortExact(Number) - Static method in class org.elasticsearch.common.Numbers
-
Return the short that
n
stores, or throws an exception if the stored value cannot be converted to a short that stores the exact same value. - toSingleItemBulkRequest(ReplicatedWriteRequest) - Static method in class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- toSingles(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
- toSortableLongBits(SortedNumericDoubleValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Given a
SortedNumericDoubleValues
, return aSortedNumericDocValues
instance that will translate double values to sortable long bits usingNumericUtils.doubleToSortableLong(double)
. - toString() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- toString() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- toString() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- toString() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- toString() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
- toString() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- toString() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- toString() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- toString() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- toString() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- toString() - Method in class org.elasticsearch.action.delete.DeleteRequest
- toString() - Method in class org.elasticsearch.action.delete.DeleteResponse
- toString() - Method in class org.elasticsearch.action.get.GetRequest
- toString() - Method in class org.elasticsearch.action.get.GetResponse
- toString() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- toString() - Method in class org.elasticsearch.action.index.IndexRequest
- toString() - Method in class org.elasticsearch.action.index.IndexResponse
- toString() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- toString() - Method in class org.elasticsearch.action.OriginalIndices
- toString() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- toString() - Method in class org.elasticsearch.action.search.MultiSearchResponse
- toString() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- toString() - Method in class org.elasticsearch.action.search.SearchRequest
- toString() - Method in class org.elasticsearch.action.search.SearchRequestBuilder
- toString() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- toString() - Method in class org.elasticsearch.action.search.SearchResponse
- toString() - Method in class org.elasticsearch.action.search.SearchScrollRequest
- toString() - Method in class org.elasticsearch.action.search.ShardSearchFailure
- toString() - Method in class org.elasticsearch.action.support.ActiveShardCount
- toString() - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
- toString() - Method in class org.elasticsearch.action.support.IndicesOptions
- toString() - Method in class org.elasticsearch.action.support.replication.BasicReplicationRequest
- toString() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- toString() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- toString() - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- toString() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- toString() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- toString() - Method in class org.elasticsearch.action.TaskOperationFailure
- toString() - Method in class org.elasticsearch.action.update.UpdateRequest
- toString() - Method in class org.elasticsearch.action.update.UpdateResponse
- toString() - Method in class org.elasticsearch.Build
- toString() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- toString() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.StartedShardEntry
- toString() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- toString() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- toString() - Method in class org.elasticsearch.cluster.ClusterName
- toString() - Method in enum org.elasticsearch.cluster.ClusterState.Metric
- toString() - Method in class org.elasticsearch.cluster.ClusterState
- toString() - Method in class org.elasticsearch.cluster.DiskUsage
- toString() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- toString() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- toString() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- toString() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- toString() - Method in class org.elasticsearch.cluster.metadata.AutoExpandReplicas
- toString() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- toString() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
-
Generates a human-readable string for the DiscoverNodeFilters.
- toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- toString() - Method in class org.elasticsearch.cluster.RestoreInProgress
- toString() - Method in enum org.elasticsearch.cluster.routing.allocation.AllocationDecision
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
- toString() - Method in enum org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- toString() - Method in enum org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- toString() - Method in enum org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.StaleShard
- toString() - Method in class org.elasticsearch.cluster.routing.AllocationId
- toString() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.EmptyStoreRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.LocalShardsRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.PeerRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- toString() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- toString() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- toString() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- toString() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- toString() - Method in class org.elasticsearch.cluster.service.SourcePrioritizedRunnable
- toString() - Method in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- toString() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- toString() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- toString() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- toString() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- toString() - Method in class org.elasticsearch.common.blobstore.BlobPath
- toString() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- toString() - Method in class org.elasticsearch.common.blobstore.support.PlainBlobMetaData
- toString() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- toString() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- toString() - Method in class org.elasticsearch.common.component.Lifecycle
- toString() - Method in class org.elasticsearch.common.compress.CompressedXContent
- toString() - Method in class org.elasticsearch.common.document.DocumentField
- toString() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
- toString() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- toString() - Method in class org.elasticsearch.common.geo.GeoPoint
- toString() - Method in enum org.elasticsearch.common.geo.GeoShapeType
- toString() - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toString() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- toString() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.InternalFactory.Instance
- toString() - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ToStringBuilder
- toString() - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.Key
- toString() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- toString() - Method in interface org.elasticsearch.common.inject.Scope
-
A short but useful description of this scope.
- toString() - Method in class org.elasticsearch.common.inject.spi.Dependency
- toString() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
- toString() - Method in class org.elasticsearch.common.inject.spi.Message
- toString() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup.ProviderImpl
- toString() - Method in class org.elasticsearch.common.inject.TypeLiteral
- toString() - Method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- toString() - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- toString() - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
- toString() - Method in class org.elasticsearch.common.settings.SecureString
-
Convert to a
String
. - toString() - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- toString() - Method in class org.elasticsearch.common.settings.Setting.SimpleKey
- toString() - Method in class org.elasticsearch.common.settings.Setting
- toString() - Method in class org.elasticsearch.common.settings.Settings
- toString() - Method in class org.elasticsearch.common.StopWatch
-
Return an informative string describing all tasks performed For custom reporting, call
getTaskInfo()
and use the task info directly. - toString() - Method in class org.elasticsearch.common.text.Text
- toString() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- toString() - Method in class org.elasticsearch.common.transport.PortsRange
- toString() - Method in class org.elasticsearch.common.transport.TransportAddress
- toString() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- toString() - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
- toString() - Method in enum org.elasticsearch.common.unit.DistanceUnit
- toString() - Method in class org.elasticsearch.common.unit.RatioValue
- toString() - Method in class org.elasticsearch.common.unit.SizeValue
- toString() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- toString() - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- toString() - Method in class org.elasticsearch.common.util.URIPattern
- toString() - Method in class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- toString() - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- toString() - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- toString() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.NodeRemovalClusterStateTaskExecutor.Task
- toString() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
- toString() - Method in exception org.elasticsearch.ElasticsearchException
- toString() - Method in class org.elasticsearch.env.NodeEnvironment.NodePath
- toString() - Method in class org.elasticsearch.env.NodeMetaData
- toString() - Method in class org.elasticsearch.env.ShardLock
- toString() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- toString() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- toString() - Method in class org.elasticsearch.index.engine.Engine.CommitId
- toString() - Method in class org.elasticsearch.index.engine.Segment
- toString() - Method in class org.elasticsearch.index.get.GetResult
- toString() - Method in class org.elasticsearch.index.Index
- toString() - Method in class org.elasticsearch.index.mapper.Mapping
- toString() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- toString() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- toString() - Method in class org.elasticsearch.index.mapper.Uid
- toString() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- toString() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- toString() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- toString() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- toString() - Method in class org.elasticsearch.index.recovery.RecoveryStats
- toString() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- toString() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- toString() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- toString() - Method in class org.elasticsearch.index.reindex.ReindexRequest
- toString() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- toString() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- toString() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- toString() - Method in class org.elasticsearch.index.search.stats.SearchStats
- toString() - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction.Request
- toString() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- toString() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- toString() - Method in class org.elasticsearch.index.seqno.RetentionLease
- toString() - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- toString() - Method in class org.elasticsearch.index.seqno.RetentionLeases
- toString() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- toString() - Method in class org.elasticsearch.index.seqno.SeqNoStats
- toString() - Method in class org.elasticsearch.index.seqno.SequenceNumbers.CommitInfo
- toString() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncRequest
- toString() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- toString() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- toString() - Method in class org.elasticsearch.index.shard.ShardId
- toString() - Method in class org.elasticsearch.index.shard.ShardPath
- toString() - Method in class org.elasticsearch.index.shard.ShardStateMetaData
- toString() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity
- toString() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
- toString() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- toString() - Method in class org.elasticsearch.index.store.Store.RecoveryDiff
- toString() - Method in class org.elasticsearch.index.store.StoreFileMetaData
- toString() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- toString() - Method in class org.elasticsearch.index.translog.Translog.Delete
- toString() - Method in class org.elasticsearch.index.translog.Translog.Index
- toString() - Method in class org.elasticsearch.index.translog.Translog.Location
- toString() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- toString() - Method in class org.elasticsearch.index.translog.TranslogStats
- toString() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- toString() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- toString() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- toString() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- toString() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- toString() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- toString() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- toString() - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- toString() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
- toString() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- toString() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- toString() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
- toString() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- toString() - Method in class org.elasticsearch.indices.TermsLookup
- toString() - Method in class org.elasticsearch.ingest.IngestDocument
- toString() - Method in class org.elasticsearch.ingest.PipelineConfiguration
- toString() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
- toString() - Method in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- toString() - Method in class org.elasticsearch.persistent.decider.AssignmentDecision
- toString() - Method in enum org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- toString() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Assignment
- toString() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- toString() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- toString() - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- toString() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- toString() - Method in class org.elasticsearch.plugins.PluginInfo
- toString() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- toString() - Method in class org.elasticsearch.repositories.IndexId
- toString() - Method in class org.elasticsearch.repositories.VerificationFailure
- toString() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toString() - Method in class org.elasticsearch.script.Script
- toString() - Method in class org.elasticsearch.script.ScriptMetaData
- toString() - Method in enum org.elasticsearch.script.ScriptType
- toString() - Method in class org.elasticsearch.script.StoredScriptSource
- toString() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
- toString() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- toString() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- toString() - Method in enum org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
- toString() - Method in enum org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory.ExecutionMode
- toString() - Method in enum org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
- toString() - Method in class org.elasticsearch.search.aggregations.BucketOrder
- toString() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- toString() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
- toString() - Method in enum org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
- toString() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- toString() - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- toString() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- toString() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- toString() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- toString() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- toString() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- toString() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- toString() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- toString() - Method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- toString() - Method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- toString() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- toString() - Method in class org.elasticsearch.search.internal.AliasFilter
- toString() - Method in class org.elasticsearch.search.internal.SearchContext
- toString() - Method in enum org.elasticsearch.search.profile.aggregation.AggregationTimingType
- toString() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- toString() - Method in enum org.elasticsearch.search.profile.query.QueryTimingType
- toString() - Method in enum org.elasticsearch.search.rescore.QueryRescoreMode
- toString() - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- toString() - Method in class org.elasticsearch.search.Scroll
- toString() - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- toString() - Method in class org.elasticsearch.search.SearchHit
- toString() - Method in class org.elasticsearch.search.SearchPhase.SearchContextSourcePrinter
- toString() - Method in class org.elasticsearch.search.SearchShardTarget
- toString() - Method in class org.elasticsearch.search.slice.SliceBuilder
- toString() - Method in enum org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
- toString() - Method in class org.elasticsearch.search.sort.SortBuilder
- toString() - Method in enum org.elasticsearch.search.sort.SortMode
- toString() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- toString() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- toString() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- toString() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- toString() - Method in class org.elasticsearch.search.suggest.phrase.Correction
- toString() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- toString() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- toString() - Method in class org.elasticsearch.search.suggest.Suggest
- toString() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- toString() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- toString() - Method in class org.elasticsearch.snapshots.RestoreInfo
- toString() - Method in class org.elasticsearch.snapshots.Snapshot
- toString() - Method in class org.elasticsearch.snapshots.SnapshotId
- toString() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- toString() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
- toString() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- toString() - Method in class org.elasticsearch.tasks.RawTaskStatus
- toString() - Method in class org.elasticsearch.tasks.TaskId
- toString() - Method in class org.elasticsearch.tasks.TaskInfo
- toString() - Method in class org.elasticsearch.tasks.TaskResult
- toString() - Method in class org.elasticsearch.transport.PlainTransportFuture
- toString() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- toString() - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- toString() - Method in class org.elasticsearch.Version
- toString(boolean) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- toString(double) - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Convert a value to a distance string
- toString(Object) - Static method in class org.elasticsearch.common.lucene.BytesRefs
-
Converts a value to a string, taking special care if its a
BytesRef
to callBytesRef.utf8ToString()
. - toString(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Formats a member as concise string, such as
java.util.ArrayList.size
,java.util.ArrayList<init>()
orjava.util.List.remove()
. - toString(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
- toString(String) - Method in class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- toString(String) - Method in class org.apache.lucene.queries.BlendedTermQuery
- toString(String) - Method in class org.apache.lucene.queries.MinDocQuery
- toString(String) - Method in class org.apache.lucene.queries.SearchAfterSortedDocQuery
- toString(String) - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- toString(String) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
- toString(String) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- toString(String) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- toString(String) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- toString(String) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypesQuery
- toString(String) - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- toString(String) - Method in class org.elasticsearch.plugins.PluginInfo
- toString(String) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- toString(String) - Method in class org.elasticsearch.search.slice.SliceQuery
- toString(String, Locale) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- toString(SortedNumericDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values. - toString(SortedSetDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values. - toString(ToXContent) - Static method in class org.elasticsearch.common.Strings
-
Return a
String
that is the json representation of the providedToXContent
. - toString(ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- toString(ToXContent, boolean, boolean) - Static method in class org.elasticsearch.common.Strings
-
Return a
String
that is the json representation of the providedToXContent
. - toString(XContentBuilder) - Static method in class org.elasticsearch.common.Strings
-
Returns a string representation of the builder (only applicable for text based xcontent).
- toString(MultiGeoPointValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values. - toString(SortedNumericDoubleValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values. - toString(VersionType) - Static method in enum org.elasticsearch.index.VersionType
- toStringArray(Collection<String>) - Static method in class org.elasticsearch.common.Strings
-
Copy the given Collection into a String array.
- ToStringBuilder - Class in org.elasticsearch.common.inject.internal
-
Helps with
toString()
methods. - ToStringBuilder(Class) - Constructor for class org.elasticsearch.common.inject.internal.ToStringBuilder
- ToStringBuilder(String) - Constructor for class org.elasticsearch.common.inject.internal.ToStringBuilder
- total() - Method in class org.elasticsearch.index.warmer.WarmerStats
-
The total number of warmer executed.
- Total - org.elasticsearch.search.rescore.QueryRescoreMode
- TOTAL - Static variable in class org.elasticsearch.search.SearchHits.Fields
- TOTAL_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- TOTAL_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- TOTAL_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- TOTAL_HIT_AS_INT_PARAM - Static variable in class org.elasticsearch.rest.action.search.RestSearchAction
- totalBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of bytes in th shard
- totalFileCount() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns total number of files that are referenced by this snapshot
- totalFileCount() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of files that are part of this recovery, both re-used and recovered
- totalFilesSize() - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- totalHits - Variable in class org.elasticsearch.search.internal.ScrollContext
- totalHits - Variable in class org.elasticsearch.search.SearchHits
- totalOperations() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- totalOperations() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
-
The total estimated number of operations in the snapshot.
- totalOperations() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the number of operations in the translog files
- totalOperations() - Method in class org.elasticsearch.index.translog.TranslogReader
- totalOperations() - Method in class org.elasticsearch.index.translog.TranslogWriter
- totalOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
returns the total number of translog operations needed to be recovered at this moment.
- totalOperations(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- totalOperationsByMinGen(long) - Method in class org.elasticsearch.index.translog.Translog
-
Returns the number of operations in the translog files at least the given generation
- totalOperationsOnStart() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
returns the total number of translog operations to recovered, on the start of the recovery.
- totalOperationsOnStart(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- totalRecoverBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total bytes of files to be recovered (potentially not yet done)
- totalRecoverFiles() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of files to be recovered (potentially not yet done)
- totalReuseBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- totalShards() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
-
total number shards, including replicas, both assigned and unassigned
- totalShards() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- totalShards() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
Number of shards being restored
- totalShards() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns total number of shards that were snapshotted; a value of
0
will be returned ifSnapshotInfo.state()
returnsnull
. - totalSize() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Returns the total number of shards within all groups
- totalSize() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns total size of all files that where snapshotted
- totalSizeWith1ForEmpty() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Returns the total number of shards plus the number of empty groups
- totalTermFreq() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- totalTime() - Method in class org.elasticsearch.common.StopWatch
-
Return the total time for all tasks.
- totalTime() - Method in class org.elasticsearch.index.warmer.WarmerStats
-
The total time warmer have been executed.
- totalTimeInMillis() - Method in class org.elasticsearch.index.warmer.WarmerStats
-
The total time warmer have been executed (in milliseconds).
- totalTranslogOps() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- totalTranslogOps() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- totalTranslogOps() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- toTB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
- toTera(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
- toTimingMap() - Method in class org.elasticsearch.search.profile.AbstractProfileBreakdown
-
Convert this record to a map from timingType to times.
- toUriString(InetAddress) - Static method in class org.elasticsearch.common.network.InetAddresses
-
Returns the string representation of an
InetAddress
suitable for inclusion in a URI. - toUTF8Bytes(CharSequence) - Static method in class org.elasticsearch.common.Strings
- toUTF8Bytes(CharSequence, BytesRefBuilder) - Static method in class org.elasticsearch.common.Strings
- toValuesSource(QueryShardContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Get a value source given its configuration.
- toWKT() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- toWKT() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- toXContent(String, XContentBuilder) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
- toXContent(AliasMetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- toXContent(IndexMetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- toXContent(IndexTemplateMetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- toXContent(MetaData) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- toXContent(MetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- toXContent(RepositoryMetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Serializes information about a single repository
- toXContent(RestoreInProgress.Entry, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.RestoreInProgress
-
Serializes single restore operation
- toXContent(SnapshotsInProgress.Entry, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- toXContent(ToXContent, XContentType, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Returns the bytes that represent the XContent output of the provided
ToXContent
object, using the providedXContentType
. - toXContent(ToXContent, XContentType, ToXContent.Params, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Returns the bytes that represent the XContent output of the provided
ToXContent
object, using the providedXContentType
. - toXContent(XContentBuilder, String, String, String) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Generates x-content into the given builder for each of the fields in this stats instance
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest.NameOrDefinition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.bulk.BulkItemResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.bulk.BulkResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.DocWriteResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.explain.ExplainRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.explain.ExplainResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.GetResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.main.MainResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.ClearScrollResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.MultiSearchResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponseSections
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.ShardSearchFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.IndicesOptions
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.TaskOperationFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.update.UpdateRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.block.ClusterBlock
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.ClusterInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.ClusterState
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.DiskUsage
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.MetaData
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.RestoreInProgress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.AllocationId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.ShardRouting
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.bytes.BytesReference
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.document.DocumentField
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.LineStringBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.MultiPointBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.GeoPoint
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.parsers.CoordinateNode
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.settings.Setting
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.settings.Settings
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.text.Text
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.transport.TransportAddress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.unit.ByteSizeValue
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.unit.Fuzziness
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.discovery.DiscoveryStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.ElasticsearchException
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.http.HttpInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.http.HttpStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.engine.CommitStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.engine.SegmentsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.flush.FlushStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.get.GetResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.get.GetStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.Index
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.AllFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.IdFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.Mapping
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.UidFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.merge.MergeStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.refresh.RefreshStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.ReindexRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.RemoteInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.search.stats.SearchStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.seqno.RetentionLease
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.seqno.RetentionLeases
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
-
Converts the retention lease stats to
XContent
using the specified builder and pararms. - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.seqno.SeqNoStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.DocsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.IndexingStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.ShardId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Serializes shard snapshot metadata info into JSON
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Writes index file for the shard in the following format.
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.store.StoreStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.translog.TranslogStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.warmer.WarmerStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.NodeIndicesStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.TermsLookup
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.IngestInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.IngestMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.IngestStats.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.IngestStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.PipelineConfiguration
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.ProcessorInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.jvm.JvmStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.process.ProcessInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.process.ProcessStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.node.AdaptiveSelectionStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.plugins.PluginInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.repositories.IndexId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.Script
-
This will build scripts into the following XContent structure:
{ "<(id, source)>" : "<idOrCode>", "lang" : "<lang>", "options" : { "option0" : "<option0>", "option1" : "<option1>", ... }, "params" : { "param0" : "<param0>", "param1" : "<param1>", ... } }
Example:{ "source" : "return Math.log(doc.popularity) * params.multiplier;", "lang" : "painless", "params" : { "multiplier" : 100.0 } }
Note that lang, options, and params will only be included if there have been any specified. - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptMetaData
-
This will write XContent from
ScriptMetaData
. - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.StoredScriptSource
-
This will write XContent from a
StoredScriptSource
. - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.Aggregations
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare.ChiSquareBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore.JLHScoreBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation.MutualInformationBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore.PercentageScoreBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.ParsedSignificantTerms.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalOrder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.ParsedAggregation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel.EWMAModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel.HoltLinearModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel.LinearModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel.SimpleModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.ProfileResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.query.CollectorResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.SearchProfileShardResults
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchHit
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchHits
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchSortValues
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.slice.SliceBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Writes a list of objects specified by the defined
ContextMapping
s seeContextMapping.toXContent(XContentBuilder, Params)
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.RestoreInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.tasks.RawTaskStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.tasks.TaskInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.tasks.TaskResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.threadpool.ThreadPoolStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.TransportInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.TransportStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.Version
- toXContent(XContentBuilder, ToXContent.Params, ToXContent) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- toXContent(XContentBuilder, Coordinate) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- toXContent(XContentBuilder, T) - Method in class org.elasticsearch.gateway.MetaDataStateFormat
-
Writes the given state to the given XContentBuilder Subclasses need to implement this class for theirs specific state.
- toXContent(BlobStoreIndexShardSnapshot.FileInfo, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Serializes file info into JSON
- toXContent(CompositeValuesSourceBuilder<?>, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceParserHelper
- toXContentCommon(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- toXContentEmbedded(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.get.GetResult
- toXContentFragment(CompositeAggregation, XContentBuilder, ToXContent.Params) - Static method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
- toXContentGroupedByNode(XContentBuilder, ToXContent.Params, DiscoveryNodes) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Convert this task response to XContent grouping by executing nodes.
- toXContentGroupedByNone(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Presents a flat list of tasks
- toXContentGroupedByParents(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Convert this response to XContent grouping by parent tasks.
- toXContentInternal(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Directly write all the aggregations without their bounding object.
- TRACE - org.elasticsearch.index.SlowLogLevel
- TRACE - org.elasticsearch.rest.RestRequest.Method
- TRACE_LOG_EXCLUDE_SETTING - Static variable in class org.elasticsearch.transport.TransportSettings
- TRACE_LOG_INCLUDE_SETTING - Static variable in class org.elasticsearch.transport.TransportSettings
- traceEnabled() - Method in class org.elasticsearch.transport.TransportService
- traceReceivedRequest(long, String) - Method in class org.elasticsearch.transport.TransportService
- traceReceivedResponse(long, DiscoveryNode, String) - Method in class org.elasticsearch.transport.TransportService
- traceRequestSent(DiscoveryNode, long, String, TransportRequestOptions) - Method in class org.elasticsearch.transport.TransportService
- traceResponseSent(long, String) - Method in class org.elasticsearch.transport.TransportService
- traceResponseSent(long, String, Exception) - Method in class org.elasticsearch.transport.TransportService
- traceUnresolvedResponse(long) - Method in class org.elasticsearch.transport.TransportService
- TRACK_SCORES_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- TRACK_TOTAL_HITS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- TrackingResultProcessor - Class in org.elasticsearch.ingest
-
Processor to be used within Simulate API to keep track of processors executed in pipeline.
- trackScores() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Indicates whether scores will be tracked for this request.
- trackScores() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates whether scores will be tracked for this request.
- trackScores() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- trackScores() - Method in class org.elasticsearch.search.internal.SearchContext
- trackScores() - Method in class org.elasticsearch.search.internal.SubSearchContext
- trackScores(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Applies when sorting, and controls if scores will be tracked as well.
- trackScores(boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Applies when sorting, and controls if scores will be tracked as well.
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
- trackTotalHits() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates if the total hit count for the query should be tracked.
- trackTotalHits() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- trackTotalHits() - Method in class org.elasticsearch.search.internal.SearchContext
-
Indicates if the total hit count for the query should be tracked.
- trackTotalHits(boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- trackTotalHits(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- trackTotalHits(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
- tragedy - Variable in class org.elasticsearch.index.translog.Translog
- TragicExceptionHolder - Class in org.elasticsearch.index.translog
- TragicExceptionHolder() - Constructor for class org.elasticsearch.index.translog.TragicExceptionHolder
- transientSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- transientSettings() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- transientSettings() - Method in class org.elasticsearch.cluster.metadata.MetaData
- transientSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the source containing the transient settings to be updated.
- transientSettings(Map) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the transient settings to be updated.
- transientSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the transient settings to be updated.
- transientSettings(Settings) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- transientSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the transient settings to be updated.
- translog - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- translog() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- translog(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Translog - Class in org.elasticsearch.index.translog
-
A Translog is a per index shard component that records all non-committed index operations in a durable manner.
- Translog - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- Translog() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Translog
- Translog(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Translog
- Translog(TranslogConfig, String, TranslogDeletionPolicy, LongSupplier, LongSupplier) - Constructor for class org.elasticsearch.index.translog.Translog
-
Creates a new Translog instance.
- TRANSLOG - org.elasticsearch.indices.recovery.RecoveryState.Stage
-
starting up the engine, replaying the translog
- TRANSLOG_FILE_PREFIX - Static variable in class org.elasticsearch.index.translog.Translog
- TRANSLOG_FILE_SUFFIX - Static variable in class org.elasticsearch.index.translog.Translog
- TRANSLOG_FOLDER_NAME - Static variable in class org.elasticsearch.index.shard.ShardPath
- TRANSLOG_GENERATION_KEY - Static variable in class org.elasticsearch.index.translog.Translog
- TRANSLOG_OPS - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- TRANSLOG_UUID_KEY - Static variable in class org.elasticsearch.index.translog.Translog
- Translog.Delete - Class in org.elasticsearch.index.translog
- Translog.Durability - Enum in org.elasticsearch.index.translog
- Translog.Index - Class in org.elasticsearch.index.translog
- Translog.Location - Class in org.elasticsearch.index.translog
- Translog.NoOp - Class in org.elasticsearch.index.translog
- Translog.Operation - Interface in org.elasticsearch.index.translog
-
A generic interface representing an operation performed on the transaction log.
- Translog.Operation.Type - Enum in org.elasticsearch.index.translog
- Translog.Snapshot - Interface in org.elasticsearch.index.translog
-
A snapshot of the transaction log, allows to iterate over all the transaction log operations.
- Translog.Source - Class in org.elasticsearch.index.translog
- Translog.TranslogGeneration - Class in org.elasticsearch.index.translog
-
References a transaction log generation
- TranslogConfig - Class in org.elasticsearch.index.translog
- TranslogConfig(ShardId, Path, IndexSettings, BigArrays) - Constructor for class org.elasticsearch.index.translog.TranslogConfig
-
Creates a new TranslogConfig instance
- TranslogCorruptedException - Exception in org.elasticsearch.index.translog
- TranslogCorruptedException(String, String) - Constructor for exception org.elasticsearch.index.translog.TranslogCorruptedException
- TranslogCorruptedException(String, String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TranslogCorruptedException
- TranslogCorruptedException(String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TranslogCorruptedException
- TranslogCorruptedException(StreamInput) - Constructor for exception org.elasticsearch.index.translog.TranslogCorruptedException
- TranslogDeletionPolicy - Class in org.elasticsearch.index.translog
- TranslogDeletionPolicy(long, long) - Constructor for class org.elasticsearch.index.translog.TranslogDeletionPolicy
- TranslogException - Exception in org.elasticsearch.index.translog
- TranslogException(StreamInput) - Constructor for exception org.elasticsearch.index.translog.TranslogException
- TranslogException(ShardId, String) - Constructor for exception org.elasticsearch.index.translog.TranslogException
- TranslogException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TranslogException
- translogFileGeneration - Variable in class org.elasticsearch.index.translog.Translog.TranslogGeneration
- TranslogGeneration(String, long) - Constructor for class org.elasticsearch.index.translog.Translog.TranslogGeneration
- translogLocation - Variable in class org.elasticsearch.index.translog.Translog.Location
- TranslogReader - Class in org.elasticsearch.index.translog
-
an immutable translog filereader
- translogStats() - Method in class org.elasticsearch.index.shard.IndexShard
- TranslogStats - Class in org.elasticsearch.index.translog
- TranslogStats() - Constructor for class org.elasticsearch.index.translog.TranslogStats
- TranslogStats(int, long, int, long, long) - Constructor for class org.elasticsearch.index.translog.TranslogStats
- TranslogToolCli - Class in org.elasticsearch.index.translog
-
Deprecated.
- translogUUID - Variable in class org.elasticsearch.index.translog.Translog.TranslogGeneration
- TranslogWriter - Class in org.elasticsearch.index.translog
- transport - Variable in class org.elasticsearch.transport.TransportService
- transport() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node Transport be returned.
- transport() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node Transport be returned.
- transport(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node Transport be returned.
- transport(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node Transport be returned.
- Transport - Interface in org.elasticsearch.transport
- TRANSPORT_CLIENT_FEATURE - Static variable in class org.elasticsearch.client.transport.TransportClient
- TRANSPORT_COMPRESS - Static variable in class org.elasticsearch.transport.TransportSettings
- TRANSPORT_DEFAULT_TYPE_SETTING - Static variable in class org.elasticsearch.common.network.NetworkModule
- TRANSPORT_TYPE_DEFAULT_KEY - Static variable in class org.elasticsearch.common.network.NetworkModule
- TRANSPORT_TYPE_KEY - Static variable in class org.elasticsearch.common.network.NetworkModule
- TRANSPORT_TYPE_SETTING - Static variable in class org.elasticsearch.common.network.NetworkModule
- TRANSPORT_WORKER_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.TcpTransport
- Transport.Connection - Interface in org.elasticsearch.transport
-
A unidirectional connection to a
DiscoveryNode
- Transport.ResponseContext<T extends TransportResponse> - Class in org.elasticsearch.transport
-
This class represents a response context that encapsulates the actual response handler, the action and the connection it was executed on.
- Transport.ResponseHandlers - Class in org.elasticsearch.transport
-
This class is a registry that allows
- TransportAction<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support
- TransportAction(Settings, String, ThreadPool, ActionFilters, IndexNameExpressionResolver, TaskManager) - Constructor for class org.elasticsearch.action.support.TransportAction
- TransportAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.Add.TransportAction
- TransportAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove.TransportAction
- TransportAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew.TransportAction
- TransportAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, PersistentTasksClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.TransportAction
- TransportAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, PersistentTasksClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.TransportAction
- TransportAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, PersistentTasksClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.TransportAction
- TransportAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, PersistentTasksClusterService, PersistentTasksExecutorRegistry, PersistentTasksService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.TransportAction
- TransportActionNodeProxy<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action
-
A generic proxy that will execute the given action against a specific node.
- TransportActionNodeProxy(Settings, GenericAction<Request, Response>, TransportService) - Constructor for class org.elasticsearch.action.TransportActionNodeProxy
- TransportActionProxy - Class in org.elasticsearch.transport
-
TransportActionProxy allows an arbitrary action to be executed on a defined target node while the initial request is sent to a second node that acts as a request proxy to the target node.
- TransportActions - Class in org.elasticsearch.action.support
- TransportActions() - Constructor for class org.elasticsearch.action.support.TransportActions
- TransportAddress - Class in org.elasticsearch.common.transport
-
A transport address used for IP socket address (wraps
InetSocketAddress
). - TransportAddress(InetAddress, int) - Constructor for class org.elasticsearch.common.transport.TransportAddress
- TransportAddress(InetSocketAddress) - Constructor for class org.elasticsearch.common.transport.TransportAddress
- TransportAddress(StreamInput) - Constructor for class org.elasticsearch.common.transport.TransportAddress
-
Read from a stream.
- TransportAddress(StreamInput, String) - Constructor for class org.elasticsearch.common.transport.TransportAddress
-
Read from a stream and use the
hostString
when creating the InetAddress if the input comes from a version on or priorVersion.V_5_0_2
as the hostString was not serialized - transportAddresses() - Method in class org.elasticsearch.client.transport.TransportClient
-
Returns the current registered transport addresses to use (added using
TransportClient.addTransportAddress(org.elasticsearch.common.transport.TransportAddress)
. - TransportAliasesExistAction - Class in org.elasticsearch.action.admin.indices.alias.exists
- TransportAliasesExistAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
- TransportAnalyzeAction - Class in org.elasticsearch.action.admin.indices.analyze
-
Transport action used to execute analyze requests
- TransportAnalyzeAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver, Environment) - Constructor for class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- TransportAnalyzeAction.DeferredTokenFilterRegistry - Class in org.elasticsearch.action.admin.indices.analyze
- TransportBroadcastAction<Request extends BroadcastRequest<Request>,Response extends BroadcastResponse,ShardRequest extends BroadcastShardRequest,ShardResponse extends BroadcastShardResponse> - Class in org.elasticsearch.action.support.broadcast
- TransportBroadcastAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, Supplier<ShardRequest>, String) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- TransportBroadcastAction.AsyncBroadcastAction - Class in org.elasticsearch.action.support.broadcast
- TransportBroadcastByNodeAction<Request extends BroadcastRequest<Request>,Response extends BroadcastResponse,ShardOperationResult extends Streamable> - Class in org.elasticsearch.action.support.broadcast.node
-
Abstraction for transporting aggregated shard-level operations in a single request (NodeRequest) per-node and executing the shard-level operations serially on the receiving node.
- TransportBroadcastByNodeAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, String) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
- TransportBroadcastByNodeAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, String, boolean) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
- TransportBroadcastByNodeAction.AsyncAction - Class in org.elasticsearch.action.support.broadcast.node
- TransportBroadcastByNodeAction.EmptyResult - Class in org.elasticsearch.action.support.broadcast.node
-
Can be used for implementations of
shardOperation
for which there is no shard-level return value. - TransportBroadcastByNodeAction.NodeRequest - Class in org.elasticsearch.action.support.broadcast.node
- TransportBroadcastReplicationAction<Request extends BroadcastRequest<Request>,Response extends BroadcastResponse,ShardRequest extends ReplicationRequest<ShardRequest>,ShardResponse extends ReplicationResponse> - Class in org.elasticsearch.action.support.replication
-
Base class for requests that should be executed on all shards of an index or several indices.
- TransportBroadcastReplicationAction(String, Supplier<Request>, Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, TransportReplicationAction) - Constructor for class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- TransportBulkAction - Class in org.elasticsearch.action.bulk
-
Groups bulk request items by shard, optionally creating non-existent indices and delegates to
TransportShardBulkAction
for shard-level bulk execution - TransportBulkAction(Settings, ThreadPool, TransportService, ClusterService, IngestService, TransportShardBulkAction, TransportCreateIndexAction, ActionFilters, IndexNameExpressionResolver, AutoCreateIndex) - Constructor for class org.elasticsearch.action.bulk.TransportBulkAction
- TransportBulkAction(Settings, ThreadPool, TransportService, ClusterService, IngestService, TransportShardBulkAction, TransportCreateIndexAction, ActionFilters, IndexNameExpressionResolver, AutoCreateIndex, LongSupplier) - Constructor for class org.elasticsearch.action.bulk.TransportBulkAction
- TransportCancelTasksAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.cancel
-
Transport action that can be used to cancel currently running cancellable tasks.
- TransportCancelTasksAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- TransportChannel - Interface in org.elasticsearch.transport
-
A transport channel allows to send a response to a request on the channel.
- TransportChannelResponseHandler<T extends TransportResponse> - Class in org.elasticsearch.transport
-
Base class for delegating transport response to a transport channel
- TransportChannelResponseHandler(Logger, TransportChannel, String, Writeable.Reader<T>) - Constructor for class org.elasticsearch.transport.TransportChannelResponseHandler
- TransportClearIndicesCacheAction - Class in org.elasticsearch.action.admin.indices.cache.clear
-
Indices clear cache action.
- TransportClearIndicesCacheAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- TransportClearScrollAction - Class in org.elasticsearch.action.search
- TransportClearScrollAction(Settings, TransportService, ThreadPool, ClusterService, ActionFilters, IndexNameExpressionResolver, SearchTransportService) - Constructor for class org.elasticsearch.action.search.TransportClearScrollAction
- TransportClient - Class in org.elasticsearch.client.transport
-
The transport client allows to create a client that is not part of the cluster, but simply connects to one or more nodes directly by adding their respective addresses using
TransportClient.addTransportAddress(org.elasticsearch.common.transport.TransportAddress)
. - TransportClient(Settings, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.client.transport.TransportClient
-
Creates a new TransportClient with the given settings and plugins
- TransportClient(Settings, Settings, Collection<Class<? extends Plugin>>, TransportClient.HostFailureListener) - Constructor for class org.elasticsearch.client.transport.TransportClient
-
Creates a new TransportClient with the given settings, defaults and plugins.
- TransportClient.HostFailureListener - Interface in org.elasticsearch.client.transport
-
Listener that allows to be notified whenever a node failure / disconnect happens
- TransportCloseIndexAction - Class in org.elasticsearch.action.admin.indices.close
-
Close index action
- TransportCloseIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexStateService, ClusterSettings, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- TransportClusterAllocationExplainAction - Class in org.elasticsearch.action.admin.cluster.allocation
-
The
TransportClusterAllocationExplainAction
is responsible for actually executing the explanation of a shard's allocation on the master node in the cluster. - TransportClusterAllocationExplainAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ClusterInfoService, AllocationDeciders, ShardsAllocator, GatewayAllocator) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- TransportClusterHealthAction - Class in org.elasticsearch.action.admin.cluster.health
- TransportClusterHealthAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, GatewayAllocator) - Constructor for class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- TransportClusterInfoAction<Request extends ClusterInfoRequest<Request>,Response extends ActionResponse> - Class in org.elasticsearch.action.support.master.info
- TransportClusterInfoAction(Settings, String, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Supplier<Request>) - Constructor for class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
- TransportClusterRerouteAction - Class in org.elasticsearch.action.admin.cluster.reroute
- TransportClusterRerouteAction(Settings, TransportService, ClusterService, ThreadPool, AllocationService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
- TransportClusterSearchShardsAction - Class in org.elasticsearch.action.admin.cluster.shards
- TransportClusterSearchShardsAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- TransportClusterStateAction - Class in org.elasticsearch.action.admin.cluster.state
- TransportClusterStateAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- TransportClusterStatsAction - Class in org.elasticsearch.action.admin.cluster.stats
- TransportClusterStatsAction(Settings, ThreadPool, ClusterService, TransportService, NodeService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- TransportClusterStatsAction.ClusterStatsNodeRequest - Class in org.elasticsearch.action.admin.cluster.stats
- TransportClusterUpdateSettingsAction - Class in org.elasticsearch.action.admin.cluster.settings
- TransportClusterUpdateSettingsAction(Settings, TransportService, ClusterService, ThreadPool, AllocationService, ActionFilters, IndexNameExpressionResolver, ClusterSettings) - Constructor for class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
- TransportConnectionListener - Interface in org.elasticsearch.transport
-
A listener interface that allows to react on transport events.
- TransportCreateIndexAction - Class in org.elasticsearch.action.admin.indices.create
-
Create index action.
- TransportCreateIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataCreateIndexService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
- TransportCreateSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Transport action for create snapshot operation
- TransportCreateSnapshotAction(Settings, TransportService, ClusterService, ThreadPool, SnapshotsService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
- TransportDeleteAction - Class in org.elasticsearch.action.delete
-
Deprecated.
- TransportDeleteAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver, TransportBulkAction, TransportShardBulkAction) - Constructor for class org.elasticsearch.action.delete.TransportDeleteAction
-
Deprecated.
- TransportDeleteIndexAction - Class in org.elasticsearch.action.admin.indices.delete
-
Delete index action.
- TransportDeleteIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataDeleteIndexService, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- TransportDeleteIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
-
Delete index action.
- TransportDeleteIndexTemplateAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexTemplateService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- TransportDeleteRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.delete
-
Transport action for unregister repository operation
- TransportDeleteRepositoryAction(Settings, TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
- TransportDeleteSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
-
Transport action for delete snapshot operation
- TransportDeleteSnapshotAction(Settings, TransportService, ClusterService, ThreadPool, SnapshotsService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
- TransportDeleteStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- TransportDeleteStoredScriptAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ScriptService) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.TransportDeleteStoredScriptAction
- TransportException - Exception in org.elasticsearch.transport
- TransportException(String) - Constructor for exception org.elasticsearch.transport.TransportException
- TransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.TransportException
- TransportException(Throwable) - Constructor for exception org.elasticsearch.transport.TransportException
- TransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.TransportException
- TransportExplainAction - Class in org.elasticsearch.action.explain
-
Explain transport action.
- TransportExplainAction(Settings, ThreadPool, ClusterService, TransportService, SearchService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.explain.TransportExplainAction
- TransportFieldCapabilitiesAction - Class in org.elasticsearch.action.fieldcaps
- TransportFieldCapabilitiesAction(Settings, TransportService, ClusterService, ThreadPool, TransportFieldCapabilitiesIndexAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesAction
- TransportFieldCapabilitiesIndexAction - Class in org.elasticsearch.action.fieldcaps
- TransportFieldCapabilitiesIndexAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesIndexAction
- TransportFlushAction - Class in org.elasticsearch.action.admin.indices.flush
-
Flush Action.
- TransportFlushAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, TransportShardFlushAction) - Constructor for class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
- TransportForceMergeAction - Class in org.elasticsearch.action.admin.indices.forcemerge
-
ForceMerge index/indices action.
- TransportForceMergeAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- TransportFuture<V> - Interface in org.elasticsearch.transport
- TransportGetAction - Class in org.elasticsearch.action.get
-
Performs the get operation.
- TransportGetAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.get.TransportGetAction
- TransportGetAliasesAction - Class in org.elasticsearch.action.admin.indices.alias.get
- TransportGetAliasesAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
- TransportGetFieldMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
- TransportGetFieldMappingsAction(Settings, TransportService, ClusterService, ThreadPool, TransportGetFieldMappingsIndexAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsAction
- TransportGetFieldMappingsIndexAction - Class in org.elasticsearch.action.admin.indices.mapping.get
-
Transport action used to retrieve the mappings related to fields that belong to a specific index
- TransportGetFieldMappingsIndexAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- TransportGetIndexAction - Class in org.elasticsearch.action.admin.indices.get
-
Get index action.
- TransportGetIndexAction(Settings, TransportService, ClusterService, ThreadPool, SettingsFilter, ActionFilters, IndexNameExpressionResolver, IndicesService, IndexScopedSettings) - Constructor for class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
- TransportGetIndexTemplatesAction - Class in org.elasticsearch.action.admin.indices.template.get
- TransportGetIndexTemplatesAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- TransportGetMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
- TransportGetMappingsAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
- TransportGetRepositoriesAction - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Transport action for get repositories operation
- TransportGetRepositoriesAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- TransportGetSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.get
- TransportGetSettingsAction(Settings, TransportService, ClusterService, ThreadPool, SettingsFilter, ActionFilters, IndexNameExpressionResolver, IndexScopedSettings) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
- TransportGetSnapshotsAction - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Transport Action for get snapshots operation
- TransportGetSnapshotsAction(Settings, TransportService, ClusterService, ThreadPool, SnapshotsService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- TransportGetStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- TransportGetStoredScriptAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ScriptService) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetStoredScriptAction
- TransportGetTaskAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
Action to get a single task.
- TransportGetTaskAction(Settings, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, ClusterService, Client, NamedXContentRegistry) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.TransportGetTaskAction
- TransportIndexAction - Class in org.elasticsearch.action.index
-
Deprecated.
- TransportIndexAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver, TransportBulkAction, TransportShardBulkAction) - Constructor for class org.elasticsearch.action.index.TransportIndexAction
-
Deprecated.
- TransportIndicesAliasesAction - Class in org.elasticsearch.action.admin.indices.alias
-
Add/remove aliases action
- TransportIndicesAliasesAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexAliasesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
- TransportIndicesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.indices
-
Indices exists action.
- TransportIndicesExistsAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
- TransportIndicesSegmentsAction - Class in org.elasticsearch.action.admin.indices.segments
- TransportIndicesSegmentsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- TransportIndicesShardStoresAction - Class in org.elasticsearch.action.admin.indices.shards
-
Transport action that reads the cluster state for shards with the requested criteria (see
ClusterHealthStatus
) of specific indices and fetches store information from all the nodes usingTransportNodesListGatewayStartedShards
- TransportIndicesShardStoresAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, TransportNodesListGatewayStartedShards) - Constructor for class org.elasticsearch.action.admin.indices.shards.TransportIndicesShardStoresAction
- TransportIndicesStatsAction - Class in org.elasticsearch.action.admin.indices.stats
- TransportIndicesStatsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- TransportInfo - Class in org.elasticsearch.transport
- TransportInfo(StreamInput) - Constructor for class org.elasticsearch.transport.TransportInfo
- TransportInfo(BoundTransportAddress, Map<String, BoundTransportAddress>) - Constructor for class org.elasticsearch.transport.TransportInfo
- TransportInstanceSingleOperationAction<Request extends InstanceShardOperationRequest<Request>,Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.instance
- TransportInstanceSingleOperationAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>) - Constructor for class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- TransportInterceptor - Interface in org.elasticsearch.transport
-
This interface allows plugins to intercept requests on both the sender and the receiver side.
- TransportInterceptor.AsyncSender - Interface in org.elasticsearch.transport
- TransportListTasksAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
- TransportListTasksAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- TransportLivenessAction - Class in org.elasticsearch.action.admin.cluster.node.liveness
- TransportLivenessAction(ClusterService, TransportService) - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.TransportLivenessAction
- TransportLogger - Class in org.elasticsearch.transport
- TransportLogger() - Constructor for class org.elasticsearch.transport.TransportLogger
- TransportMainAction - Class in org.elasticsearch.action.main
- TransportMainAction(Settings, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, ClusterService) - Constructor for class org.elasticsearch.action.main.TransportMainAction
- TransportMasterNodeAction<Request extends MasterNodeRequest<Request>,Response extends ActionResponse> - Class in org.elasticsearch.action.support.master
-
A base class for operations that needs to be performed on the master node.
- TransportMasterNodeAction(Settings, String, boolean, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Supplier<Request>) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeAction
- TransportMasterNodeAction(Settings, String, boolean, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeAction
- TransportMasterNodeAction(Settings, String, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Supplier<Request>) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeAction
- TransportMasterNodeAction(Settings, String, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeAction
- TransportMasterNodeReadAction<Request extends MasterNodeReadRequest<Request>,Response extends ActionResponse> - Class in org.elasticsearch.action.support.master
-
A base class for read operations that needs to be performed on the master node.
- TransportMasterNodeReadAction(Settings, String, boolean, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Supplier<Request>) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- TransportMasterNodeReadAction(Settings, String, boolean, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- TransportMasterNodeReadAction(Settings, String, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Supplier<Request>) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- TransportMasterNodeReadAction(Settings, String, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- TransportMessage - Class in org.elasticsearch.transport
- TransportMessage() - Constructor for class org.elasticsearch.transport.TransportMessage
-
Constructs a new empty transport message
- TransportMessage(StreamInput) - Constructor for class org.elasticsearch.transport.TransportMessage
-
Constructs a new transport message with the data from the
StreamInput
. - TransportMessageListener - Interface in org.elasticsearch.transport
- TransportMultiGetAction - Class in org.elasticsearch.action.get
- TransportMultiGetAction(Settings, ThreadPool, TransportService, ClusterService, TransportShardMultiGetAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.get.TransportMultiGetAction
- TransportMultiSearchAction - Class in org.elasticsearch.action.search
- TransportMultiSearchAction(Settings, ThreadPool, TransportService, ClusterService, TransportSearchAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.search.TransportMultiSearchAction
- TransportMultiTermVectorsAction - Class in org.elasticsearch.action.termvectors
- TransportMultiTermVectorsAction(Settings, ThreadPool, TransportService, ClusterService, TransportShardMultiTermsVectorAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.termvectors.TransportMultiTermVectorsAction
- transportNodeAction - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- TransportNodesAction<NodesRequest extends BaseNodesRequest<NodesRequest>,NodesResponse extends BaseNodesResponse,NodeRequest extends BaseNodeRequest,NodeResponse extends BaseNodeResponse> - Class in org.elasticsearch.action.support.nodes
- TransportNodesAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<NodesRequest>, Supplier<NodeRequest>, String, Class<NodeResponse>) - Constructor for class org.elasticsearch.action.support.nodes.TransportNodesAction
- TransportNodesHotThreadsAction - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- TransportNodesHotThreadsAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- TransportNodesHotThreadsAction.NodeRequest - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- TransportNodesInfoAction - Class in org.elasticsearch.action.admin.cluster.node.info
- TransportNodesInfoAction(Settings, ThreadPool, ClusterService, TransportService, NodeService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- TransportNodesInfoAction.NodeInfoRequest - Class in org.elasticsearch.action.admin.cluster.node.info
- TransportNodesListGatewayMetaState - Class in org.elasticsearch.gateway
- TransportNodesListGatewayMetaState(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, GatewayMetaState) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- TransportNodesListGatewayMetaState.NodeGatewayMetaState - Class in org.elasticsearch.gateway
- TransportNodesListGatewayMetaState.NodeRequest - Class in org.elasticsearch.gateway
- TransportNodesListGatewayMetaState.NodesGatewayMetaState - Class in org.elasticsearch.gateway
- TransportNodesListGatewayMetaState.Request - Class in org.elasticsearch.gateway
- TransportNodesListGatewayStartedShards - Class in org.elasticsearch.gateway
-
This transport action is used to fetch the shard version from each node during primary allocation in
GatewayAllocator
. - TransportNodesListGatewayStartedShards(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, NodeEnvironment, IndicesService, NamedXContentRegistry) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- TransportNodesListGatewayStartedShards.NodeGatewayStartedShards - Class in org.elasticsearch.gateway
- TransportNodesListGatewayStartedShards.NodeRequest - Class in org.elasticsearch.gateway
- TransportNodesListGatewayStartedShards.NodesGatewayStartedShards - Class in org.elasticsearch.gateway
- TransportNodesListGatewayStartedShards.Request - Class in org.elasticsearch.gateway
- TransportNodesListShardStoreMetaData - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetaData(Settings, ThreadPool, ClusterService, TransportService, IndicesService, NodeEnvironment, ActionFilters, IndexNameExpressionResolver, NamedXContentRegistry) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
- TransportNodesListShardStoreMetaData.NodeRequest - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetaData.Request - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetaData.StoreFilesMetaData - Class in org.elasticsearch.indices.store
- TransportNodesReloadSecureSettingsAction - Class in org.elasticsearch.action.admin.cluster.node.reload
- TransportNodesReloadSecureSettingsAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Environment, PluginsService) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- TransportNodesReloadSecureSettingsAction.NodeRequest - Class in org.elasticsearch.action.admin.cluster.node.reload
- TransportNodesSnapshotsStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Transport client that collects snapshot shard statuses from data nodes
- TransportNodesSnapshotsStatus(Settings, ThreadPool, ClusterService, TransportService, SnapshotShardsService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- TransportNodesSnapshotsStatus.NodeRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportNodesSnapshotsStatus.NodeSnapshotStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportNodesSnapshotsStatus.NodesSnapshotStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportNodesSnapshotsStatus.Request - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportNodesStatsAction - Class in org.elasticsearch.action.admin.cluster.node.stats
- TransportNodesStatsAction(Settings, ThreadPool, ClusterService, TransportService, NodeService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- TransportNodesStatsAction.NodeStatsRequest - Class in org.elasticsearch.action.admin.cluster.node.stats
- TransportNodesUsageAction - Class in org.elasticsearch.action.admin.cluster.node.usage
- TransportNodesUsageAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, UsageService) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- TransportNodesUsageAction.NodeUsageRequest - Class in org.elasticsearch.action.admin.cluster.node.usage
- TransportOpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
-
Open index action
- TransportOpenIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexStateService, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- transportOptions - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- transportOptions() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- transportOptions(Settings) - Method in class org.elasticsearch.action.bulk.BulkAction
- transportOptions(Settings) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- transportOptions(Settings) - Method in class org.elasticsearch.action.GenericAction
-
Optional request options for the action.
- transportOptions(Settings) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportPendingClusterTasksAction - Class in org.elasticsearch.action.admin.cluster.tasks
- TransportPendingClusterTasksAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
- transportPrimaryAction - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportPutIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
-
Put index template action.
- TransportPutIndexTemplateAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexTemplateService, ActionFilters, IndexNameExpressionResolver, IndexScopedSettings) - Constructor for class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
- TransportPutMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Put mapping action.
- TransportPutMappingAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataMappingService, ActionFilters, IndexNameExpressionResolver, TransportPutMappingAction.RequestValidators) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
- TransportPutMappingAction.RequestValidators - Class in org.elasticsearch.action.admin.indices.mapping.put
- TransportPutRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Transport action for register repository operation
- TransportPutRepositoryAction(Settings, TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
- TransportPutStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- TransportPutStoredScriptAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ScriptService) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.TransportPutStoredScriptAction
- TransportRecoveryAction - Class in org.elasticsearch.action.admin.indices.recovery
-
Transport action for shard recovery operation.
- TransportRecoveryAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- TransportRefreshAction - Class in org.elasticsearch.action.admin.indices.refresh
-
Refresh action.
- TransportRefreshAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, TransportShardRefreshAction) - Constructor for class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
- TransportRemoteInfoAction - Class in org.elasticsearch.action.admin.cluster.remote
- TransportRemoteInfoAction(Settings, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, SearchTransportService) - Constructor for class org.elasticsearch.action.admin.cluster.remote.TransportRemoteInfoAction
- transportReplicaAction - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportReplicationAction<Request extends ReplicationRequest<Request>,ReplicaRequest extends ReplicationRequest<ReplicaRequest>,Response extends ReplicationResponse> - Class in org.elasticsearch.action.support.replication
-
Base class for requests that should be executed on a primary copy followed by replica copies.
- TransportReplicationAction(Settings, String, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, Supplier<ReplicaRequest>, String) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportReplicationAction(Settings, String, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, Supplier<ReplicaRequest>, String, boolean) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportReplicationAction.ConcreteReplicaRequest<R extends TransportRequest> - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.ConcreteShardRequest<R extends TransportRequest> - Class in org.elasticsearch.action.support.replication
-
a wrapper class to encapsulate a request when being sent to a specific allocation id
- TransportReplicationAction.OperationTransportHandler - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.PrimaryOperationTransportHandler - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.PrimaryResult<ReplicaRequest extends ReplicationRequest<ReplicaRequest>,Response extends ReplicationResponse> - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.ReplicaOperationTransportHandler - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.ReplicaResponse - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.ReplicaResult - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.ReplicasProxy - Class in org.elasticsearch.action.support.replication
-
The
ReplicasProxy
is an implementation of theReplicas
interface that performs the actualReplicaRequest
on the replica shards. - TransportReplicationAction.RetryOnReplicaException - Exception in org.elasticsearch.action.support.replication
- TransportRequest - Class in org.elasticsearch.transport
- TransportRequest() - Constructor for class org.elasticsearch.transport.TransportRequest
- TransportRequest(StreamInput) - Constructor for class org.elasticsearch.transport.TransportRequest
- TransportRequest.Empty - Class in org.elasticsearch.transport
- TransportRequestDeduplicator<T extends TransportRequest> - Class in org.elasticsearch.transport
-
Deduplicator for
TransportRequest
s that keeps track ofTransportRequest
s that should not be sent in parallel. - TransportRequestDeduplicator() - Constructor for class org.elasticsearch.transport.TransportRequestDeduplicator
- TransportRequestHandler<T extends TransportRequest> - Interface in org.elasticsearch.transport
- TransportRequestOptions - Class in org.elasticsearch.transport
- TransportRequestOptions.Builder - Class in org.elasticsearch.transport
- TransportRequestOptions.Type - Enum in org.elasticsearch.transport
- TransportResizeAction - Class in org.elasticsearch.action.admin.indices.shrink
-
Main class to initiate resizing (shrink / split) an index into a new index
- TransportResizeAction(Settings, String, TransportService, ClusterService, ThreadPool, MetaDataCreateIndexService, ActionFilters, IndexNameExpressionResolver, Client) - Constructor for class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- TransportResizeAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataCreateIndexService, ActionFilters, IndexNameExpressionResolver, Client) - Constructor for class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- TransportResponse - Class in org.elasticsearch.transport
- TransportResponse() - Constructor for class org.elasticsearch.transport.TransportResponse
-
Constructs a new empty transport response
- TransportResponse(StreamInput) - Constructor for class org.elasticsearch.transport.TransportResponse
-
Constructs a new transport response with the data from the
StreamInput
. - TransportResponse.Empty - Class in org.elasticsearch.transport
- TransportResponseHandler<T extends TransportResponse> - Interface in org.elasticsearch.transport
- TransportRestoreSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Transport action for restore snapshot operation
- TransportRestoreSnapshotAction(Settings, TransportService, ClusterService, ThreadPool, RestoreService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
- TransportResyncReplicationAction - Class in org.elasticsearch.action.resync
- TransportResyncReplicationAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.resync.TransportResyncReplicationAction
- TransportRolloverAction - Class in org.elasticsearch.action.admin.indices.rollover
-
Main class to swap the index pointed to by an alias, given some conditions
- TransportRolloverAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataCreateIndexService, ActionFilters, IndexNameExpressionResolver, MetaDataIndexAliasesService, Client) - Constructor for class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- Transports - Enum in org.elasticsearch.transport
- TransportSearchAction - Class in org.elasticsearch.action.search
- TransportSearchAction(Settings, ThreadPool, TransportService, SearchService, SearchTransportService, SearchPhaseController, ClusterService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.search.TransportSearchAction
- TransportSearchScrollAction - Class in org.elasticsearch.action.search
- TransportSearchScrollAction(Settings, ThreadPool, TransportService, ClusterService, ActionFilters, IndexNameExpressionResolver, SearchTransportService, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.TransportSearchScrollAction
- TransportSerializationException - Exception in org.elasticsearch.transport
- TransportSerializationException(String, Throwable) - Constructor for exception org.elasticsearch.transport.TransportSerializationException
- TransportSerializationException(StreamInput) - Constructor for exception org.elasticsearch.transport.TransportSerializationException
- transportService - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- transportService - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- transportService - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
- transportService - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- transportService - Variable in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- transportService - Variable in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- transportService - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- transportService - Variable in class org.elasticsearch.discovery.single.SingleNodeDiscovery
- transportService - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- TransportService - Class in org.elasticsearch.transport
- TransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Constructor for class org.elasticsearch.transport.TransportService
-
Build the service.
- TransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>, ConnectionManager) - Constructor for class org.elasticsearch.transport.TransportService
- TransportService.ContextRestoreResponseHandler<T extends TransportResponse> - Class in org.elasticsearch.transport
-
This handler wrapper ensures that the response thread executes with the correct thread context.
- TransportService.HandshakeResponse - Class in org.elasticsearch.transport
- TransportSettings - Class in org.elasticsearch.transport
- TransportShardBulkAction - Class in org.elasticsearch.action.bulk
-
Performs shard-level bulk (index, delete or update) operations
- TransportShardBulkAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, MappingUpdatedAction, UpdateHelper, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.bulk.TransportShardBulkAction
- TransportShardBulkAction.ReplicaItemExecutionMode - Enum in org.elasticsearch.action.bulk
-
Modes for executing item request on replica depending on corresponding primary execution result
- TransportShardFlushAction - Class in org.elasticsearch.action.admin.indices.flush
- TransportShardFlushAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- TransportShardMultiGetAction - Class in org.elasticsearch.action.get
- TransportShardMultiGetAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.get.TransportShardMultiGetAction
- TransportShardMultiTermsVectorAction - Class in org.elasticsearch.action.termvectors
- TransportShardMultiTermsVectorAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- TransportShardRefreshAction - Class in org.elasticsearch.action.admin.indices.refresh
- TransportShardRefreshAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- TransportShrinkAction - Class in org.elasticsearch.action.admin.indices.shrink
-
Main class to initiate shrinking an index into a new index This class is only here for backwards compatibility.
- TransportShrinkAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataCreateIndexService, ActionFilters, IndexNameExpressionResolver, Client) - Constructor for class org.elasticsearch.action.admin.indices.shrink.TransportShrinkAction
- TransportSingleItemBulkWriteAction<Request extends ReplicatedWriteRequest<Request>,Response extends ReplicationResponse & WriteResponse> - Class in org.elasticsearch.action.bulk
-
Deprecated.
- TransportSingleItemBulkWriteAction(Settings, String, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, Supplier<Request>, String, TransportBulkAction, TransportShardBulkAction) - Constructor for class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- TransportSingleShardAction<Request extends SingleShardRequest<Request>,Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.shard
-
A base class for operations that need to perform a read operation on a single shard copy.
- TransportSingleShardAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, String) - Constructor for class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- TransportSingleShardAction.InternalRequest - Class in org.elasticsearch.action.support.single.shard
-
Internal request class that gets built on each node.
- TransportSnapshotsStatusAction - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportSnapshotsStatusAction(Settings, TransportService, ClusterService, ThreadPool, SnapshotsService, TransportNodesSnapshotsStatus, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
- TransportStats - Class in org.elasticsearch.transport
- TransportStats(long, long, long, long, long) - Constructor for class org.elasticsearch.transport.TransportStats
- TransportStats(StreamInput) - Constructor for class org.elasticsearch.transport.TransportStats
- TransportStatus - Class in org.elasticsearch.transport
- TransportStatus() - Constructor for class org.elasticsearch.transport.TransportStatus
- TransportSyncedFlushAction - Class in org.elasticsearch.action.admin.indices.flush
-
Synced flush Action.
- TransportSyncedFlushAction(Settings, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, SyncedFlushService) - Constructor for class org.elasticsearch.action.admin.indices.flush.TransportSyncedFlushAction
- TransportTasksAction<OperationTask extends Task,TasksRequest extends BaseTasksRequest<TasksRequest>,TasksResponse extends BaseTasksResponse,TaskResponse extends Writeable> - Class in org.elasticsearch.action.support.tasks
-
The base class for transport actions that are interacting with currently running tasks.
- TransportTasksAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Writeable.Reader<TasksRequest>, Supplier<TasksResponse>, String) - Constructor for class org.elasticsearch.action.support.tasks.TransportTasksAction
- TransportTermVectorsAction - Class in org.elasticsearch.action.termvectors
-
Performs the get operation.
- TransportTermVectorsAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- TransportTypesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.types
-
Types exists transport action.
- TransportTypesExistsAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
- TransportUpdateAction - Class in org.elasticsearch.action.update
- TransportUpdateAction(Settings, ThreadPool, ClusterService, TransportService, TransportBulkAction, TransportCreateIndexAction, UpdateHelper, ActionFilters, IndexNameExpressionResolver, IndicesService, AutoCreateIndex) - Constructor for class org.elasticsearch.action.update.TransportUpdateAction
- TransportUpdateSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.put
- TransportUpdateSettingsAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataUpdateSettingsService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
- TransportUpgradeAction - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Upgrade index/indices action.
- TransportUpgradeAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver, TransportUpgradeSettingsAction) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- TransportUpgradeSettingsAction - Class in org.elasticsearch.action.admin.indices.upgrade.post
- TransportUpgradeSettingsAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataUpdateSettingsService, IndexNameExpressionResolver, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeSettingsAction
- TransportUpgradeStatusAction - Class in org.elasticsearch.action.admin.indices.upgrade.get
- TransportUpgradeStatusAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- TransportValidateQueryAction - Class in org.elasticsearch.action.admin.indices.validate.query
- TransportValidateQueryAction(Settings, ThreadPool, ClusterService, TransportService, SearchService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- TransportVerifyRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Transport action for verifying repository operation
- TransportVerifyRepositoryAction(Settings, TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
- TransportVerifyShardBeforeCloseAction - Class in org.elasticsearch.action.admin.indices.close
- TransportVerifyShardBeforeCloseAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- TransportVerifyShardBeforeCloseAction.ShardRequest - Class in org.elasticsearch.action.admin.indices.close
- TransportWriteAction<Request extends ReplicatedWriteRequest<Request>,ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>,Response extends ReplicationResponse & WriteResponse> - Class in org.elasticsearch.action.support.replication
-
Base class for transport actions that modify data in some shard like index, delete, and shardBulk.
- TransportWriteAction(Settings, String, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexNameExpressionResolver, Supplier<Request>, Supplier<ReplicaRequest>, String) - Constructor for class org.elasticsearch.action.support.replication.TransportWriteAction
- TransportWriteAction.WritePrimaryResult<ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>,Response extends ReplicationResponse & WriteResponse> - Class in org.elasticsearch.action.support.replication
-
Result of taking the action on the primary.
- TransportWriteAction.WriteReplicaResult<ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>> - Class in org.elasticsearch.action.support.replication
-
Result of taking the action on the replica.
- transpositions - Variable in class org.elasticsearch.index.search.MatchQuery
- transpositions() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- transpositions(boolean) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- tree - Variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- tree - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
Maps the Query to it's list of children.
- tree() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- TREE - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults
-
Deprecated.
- TREE - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Names
-
Deprecated.
- TREE_DEPTH - Static variable in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- TREE_LEVELS - Static variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters.Names
-
Deprecated.
- treeLevels - Variable in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.DeprecatedParameters
-
Deprecated.
- treeLevels() - Method in class org.elasticsearch.index.mapper.LegacyGeoShapeFieldMapper.GeoShapeFieldType
-
Deprecated.
- TrieNode(String, T, String) - Constructor for class org.elasticsearch.common.path.PathTrie.TrieNode
- TriFunction<S,T,U,R> - Interface in org.elasticsearch.common
-
Represents a function that accepts three arguments and produces a result.
- trim() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
Trims the number of options per suggest text term to the requested size.
- trimLeadingCharacter(String, char) - Static method in class org.elasticsearch.common.Strings
-
Trim all occurrences of the supplied leading character from the given String.
- trimOperationOfPreviousPrimaryTerms(long) - Method in class org.elasticsearch.index.shard.IndexShard
- trimOperations(long, long) - Method in class org.elasticsearch.index.translog.Translog
-
Trims translog for terms of files below
belowTerm
and seq# aboveaboveSeqNo
. - trimOperationsFromTranslog(long, long) - Method in class org.elasticsearch.index.engine.Engine
-
Trims translog for terms below
belowTerm
and seq# aboveaboveSeqNo
- trimOperationsFromTranslog(long, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- trimOperationsFromTranslog(long, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- trimTranslog() - Method in class org.elasticsearch.index.shard.IndexShard
-
checks and removes translog files that no longer need to be retained.
- trimUnreferencedReaders() - Method in class org.elasticsearch.index.translog.Translog
-
Trims unreferenced translog generations by asking
TranslogDeletionPolicy
for the minimum required generation - trimUnreferencedTranslogFiles() - Method in class org.elasticsearch.index.engine.Engine
-
checks and removes translog files that no longer need to be retained.
- trimUnreferencedTranslogFiles() - Method in class org.elasticsearch.index.engine.InternalEngine
- trimUnreferencedTranslogFiles() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- trimUnsafeCommits(long, long, Version) - Method in class org.elasticsearch.index.store.Store
-
Keeping existing unsafe commits when opening an engine can be problematic because these commits are not safe at the recovering time but they can suddenly become safe in the future.
- TRUE - org.elasticsearch.index.mapper.ObjectMapper.Dynamic
- TRUE - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper.Values
- truncatedTo(TemporalUnit) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- TruncatedTranslogException - Exception in org.elasticsearch.index.translog
- TruncatedTranslogException(String, String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TruncatedTranslogException
- TruncatedTranslogException(StreamInput) - Constructor for exception org.elasticsearch.index.translog.TruncatedTranslogException
- TruncateTranslogAction - Class in org.elasticsearch.index.translog
- TruncateTranslogAction(NamedXContentRegistry) - Constructor for class org.elasticsearch.index.translog.TruncateTranslogAction
- tryAcquire(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Tries to acquire the lock for the given key and returns it.
- tryIncRef() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
- tryIncRef() - Method in interface org.elasticsearch.common.util.concurrent.RefCounted
-
Tries to increment the refCount of this instance.
- tryIncRef() - Method in class org.elasticsearch.index.store.Store
-
Tries to increment the refCount of this Store instance.
- tryLock() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- tryLock(long, TimeUnit) - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- tryOpenIndex(Path, ShardId, NodeEnvironment.ShardLocker, Logger) - Static method in class org.elasticsearch.index.store.Store
-
Tries to open an index for the given location.
- tTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit fraction of second, and time zone offset prefixed by 'T' ('T'HH:mm:ss.SSSZZ).
- tTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset prefixed by 'T' ('T'HH:mm:ssZZ).
- TWO - Static variable in class org.elasticsearch.common.unit.Fuzziness
- txCount() - Method in class org.elasticsearch.transport.TransportStats
- txGet() - Method in class org.elasticsearch.transport.PlainTransportFuture
- txGet() - Method in interface org.elasticsearch.transport.TransportFuture
-
Waits if necessary for the computation to complete, and then retrieves its result.
- txGet(long, TimeUnit) - Method in class org.elasticsearch.transport.PlainTransportFuture
- txGet(long, TimeUnit) - Method in interface org.elasticsearch.transport.TransportFuture
-
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
- txSize() - Method in class org.elasticsearch.transport.TransportStats
- type - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- type - Variable in class org.elasticsearch.gateway.AsyncShardFetch
- type - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- type - Variable in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- type - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- type() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- type() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Returns repository type
- type() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- type() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping type.
- type() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
The type of the document to delete.
- type() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the type that this request operates on
- type() - Method in class org.elasticsearch.action.explain.ExplainRequest
- type() - Method in class org.elasticsearch.action.get.GetRequest
- type() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- type() - Method in class org.elasticsearch.action.index.IndexRequest
-
The type of the indexed document.
- type() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Returns the type of document to get the term vector for.
- type() - Method in class org.elasticsearch.action.update.UpdateRequest
-
The type of the indexed document.
- type() - Method in class org.elasticsearch.Build
- type() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
- type() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
-
Returns repository type
- type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Get the
Decision.Type
of this decision - type() - Method in enum org.elasticsearch.cluster.routing.Preference
- type() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.LineStringBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.MultiPointBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- type() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
get the shapes type
- type() - Method in class org.elasticsearch.index.engine.Engine.Delete
- type() - Method in class org.elasticsearch.index.engine.Engine.Get
- type() - Method in class org.elasticsearch.index.engine.Engine.Index
- type() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- type() - Method in class org.elasticsearch.index.engine.Engine.Operation
- type() - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
-
Deprecated.
- type() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- type() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- type() - Method in class org.elasticsearch.index.mapper.ParentFieldMapper
- type() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- type() - Method in class org.elasticsearch.index.mapper.SourceToParse
- type() - Method in class org.elasticsearch.index.mapper.Uid
- type() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns the execution type of the geo bounding box.
- type() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- type() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- type() - Method in class org.elasticsearch.index.query.TypeQueryBuilder
- type() - Method in class org.elasticsearch.index.translog.Translog.Delete
- type() - Method in class org.elasticsearch.index.translog.Translog.Index
- type() - Method in class org.elasticsearch.indices.TermsLookup
- type() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- type() - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- type() - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- type() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Get the type used in this sort.
- type() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- type() - Method in class org.elasticsearch.transport.TransportRequestOptions
- type(Object) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the type of the text query.
- type(String) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- type(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
The type of the repository "fs" - shared filesystem repository
- type(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- type(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The type of the mappings.
- type(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Sets the type of the document to delete.
- type(String) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Set the type for this request
- type(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
- type(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the type of the document to fetch.
- type(String) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- type(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the type of the indexed document.
- type(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets the type of document to get the term vector for.
- type(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the type of the indexed document.
- type(String) - Method in class org.elasticsearch.index.mapper.ParentFieldMapper.Builder
- type(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
For BWC: Parse type from type name.
- type(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- type(String) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- type(GeoExecType) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Sets the type of executing of the geo bounding box.
- type(MultiMatchQueryBuilder.Type) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the type of the text query.
- type(MultiMatchQueryBuilder.Type) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- TYPE - org.elasticsearch.ingest.IngestDocument.MetaData
- TYPE - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.IndexGraveyard
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- TYPE - Static variable in class org.elasticsearch.cluster.RestoreInProgress
- TYPE - Static variable in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- TYPE - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.CircleBuilder
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.LineStringBuilder
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.MultiPointBuilder
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.PointBuilder
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.PolygonBuilder
- TYPE - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- TYPE - Static variable in class org.elasticsearch.index.mapper.CustomDocValuesField
- TYPE - Static variable in class org.elasticsearch.ingest.DropProcessor
- TYPE - Static variable in class org.elasticsearch.ingest.IngestMetadata
- TYPE - Static variable in class org.elasticsearch.ingest.PipelineProcessor
- TYPE - Static variable in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- TYPE - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- TYPE - Static variable in class org.elasticsearch.script.ScriptMetaData
-
The type of
ClusterState
data. - TYPE - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- TYPE - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- TYPE - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
- TYPE - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion
- TYPE_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- TYPE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- TYPE_FIELD - Static variable in class org.elasticsearch.search.sort.ScriptSortBuilder
- TYPE_NAME - Static variable in interface org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanks
- TYPE_NAME - Static variable in interface org.elasticsearch.search.aggregations.metrics.percentiles.Percentiles
- TYPE_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- TypeConverter - Interface in org.elasticsearch.common.inject.spi
-
Converts constant string values to a different type.
- TypeConverterBinding - Class in org.elasticsearch.common.inject.spi
-
Registration of type converters for matching target types.
- TYPED_KEYS_DELIMITER - Static variable in interface org.elasticsearch.search.aggregations.Aggregation
-
Delimiter used when prefixing aggregation names with their type using the typed_keys parameter
- TYPED_KEYS_PARAM - Static variable in class org.elasticsearch.rest.action.search.RestSearchAction
- TypeEncounter<I> - Interface in org.elasticsearch.common.inject.spi
-
Context of an injectable type encounter.
- TypeFieldMapper - Class in org.elasticsearch.index.mapper
- TypeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- TypeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- TypeFieldMapper.TypesQuery - Class in org.elasticsearch.index.mapper
-
Specialization for a disjunction over many _type
- typeFilter(QueryShardContext) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- TypeListener - Interface in org.elasticsearch.common.inject.spi
-
Listens for Guice to encounter injectable types.
- TypeListenerBinding - Class in org.elasticsearch.common.inject.spi
-
Binds types (picked using a Matcher) to an type listener.
- TypeLiteral<T> - Class in org.elasticsearch.common.inject
-
Represents a generic type
T
. - TypeLiteral() - Constructor for class org.elasticsearch.common.inject.TypeLiteral
-
Constructs a new type literal.
- typeMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- TypeMissingException - Exception in org.elasticsearch.indices
- TypeMissingException(String, String...) - Constructor for exception org.elasticsearch.indices.TypeMissingException
- TypeMissingException(StreamInput) - Constructor for exception org.elasticsearch.indices.TypeMissingException
- TypeMissingException(Index, String...) - Constructor for exception org.elasticsearch.indices.TypeMissingException
- TypeMissingException(Index, Throwable, String...) - Constructor for exception org.elasticsearch.indices.TypeMissingException
- typeName() - Method in class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.BaseGeoShapeFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- typeName() - Method in class org.elasticsearch.index.mapper.FieldMapper
- typeName() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the name of this type, as would be specified in mapping properties
- typeName() - Method in class org.elasticsearch.index.mapper.Mapper
-
Returns a name representing the the type of this mapper.
- typeName() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- typeName() - Method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Get the associated type name.
- typeName() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- typeName() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- typeName() - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
-
Get the associated type name.
- typeName() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- typeParser(String) - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.AllFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.BaseGeoShapeFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.FieldAliasMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.FieldNamesFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.IdFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.IgnoredFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.IndexFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.ParentFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.RootObjectMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.RoutingFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.SeqNoFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.SourceFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.TypeFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.UidFieldMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.VersionFieldMapper.TypeParser
- TypeParser(NumberFieldMapper.NumberType) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.TypeParser
- TypeParser(RangeFieldMapper.RangeType) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.TypeParser
- typeParsers() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
- TypeParsers - Class in org.elasticsearch.index.mapper
- TypeParsers() - Constructor for class org.elasticsearch.index.mapper.TypeParsers
- typeQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter based on doc/mapping type.
- TypeQueryBuilder - Class in org.elasticsearch.index.query
- TypeQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.TypeQueryBuilder
- TypeQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.TypeQueryBuilder
-
Read from a stream.
- types() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- types() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- types() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- types() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Document types to return stats for.
- types() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Document types to return stats for.
- types() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- types() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The types of documents the query will run against.
- types() - Method in class org.elasticsearch.action.search.SearchRequest
-
The document types to execute the search against.
- types() - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- types() - Method in class org.elasticsearch.index.mapper.MapperService
-
Return the set of concrete types that have a mapping.
- types() - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Returns the types used in this query
- types() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- types() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
- types() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
- types() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- types(String[]) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- types(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- types(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Document types to return stats for.
- types(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Document types to return stats for.
- types(String...) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The types of documents the query will run against.
- types(String...) - Method in class org.elasticsearch.action.search.SearchRequest
-
The document types to execute the search against.
- types(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- types(String...) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Add types to query
- types(String...) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- Types - Class in org.elasticsearch.common.inject.util
-
Static methods for working with types.
- TYPES_ALLOWED_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- typesExists(TypesExistsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Types Exists.
- typesExists(TypesExistsRequest, ActionListener<TypesExistsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Types exists
- TypesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.types
- TypesExistsRequest - Class in org.elasticsearch.action.admin.indices.exists.types
- TypesExistsRequest() - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- TypesExistsRequest(String[], String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- TypesExistsRequestBuilder - Class in org.elasticsearch.action.admin.indices.exists.types
-
A builder for
TypesExistsRequest
. - TypesExistsRequestBuilder(ElasticsearchClient, TypesExistsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
- TypesExistsResponse - Class in org.elasticsearch.action.admin.indices.exists.types
-
Whether all of the existed types exist.
- TypesExistsResponse(boolean) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsResponse
- TypesQuery(BytesRef...) - Constructor for class org.elasticsearch.index.mapper.TypeFieldMapper.TypesQuery
- typeText() - Method in class org.elasticsearch.index.mapper.DocumentMapper
U
- uid() - Method in class org.elasticsearch.index.engine.Engine.Get
- uid() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- uid() - Method in class org.elasticsearch.index.engine.Engine.Operation
- uid() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- uid() - Method in class org.elasticsearch.index.translog.Translog.Delete
- Uid - Class in org.elasticsearch.index.mapper
- Uid(String, String) - Constructor for class org.elasticsearch.index.mapper.Uid
- UidFieldMapper - Class in org.elasticsearch.index.mapper
- UidFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- UidFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- UidIndexFieldData - Class in org.elasticsearch.index.fielddata
-
Fielddata view of the _uid field on indices that do not index _uid but _id.
- UidIndexFieldData(Index, String, IndexFieldData<?>) - Constructor for class org.elasticsearch.index.fielddata.UidIndexFieldData
- uidMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- unassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- unassigned() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard is unassigned (not allocated to any node).
- UNASSIGNED - org.elasticsearch.cluster.routing.ShardRoutingState
-
The shard is not assigned to any node.
- UNASSIGNED_PRIMARY_TERM - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
-
Represents an unassigned primary term (e.g., when a primary shard was not yet allocated)
- UNASSIGNED_SEQ_NO - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
-
Represents an unassigned sequence number (e.g., can be used on primary operations before they are executed).
- unassignedInfo() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Additional metadata on why the shard is/was unassigned.
- UnassignedInfo - Class in org.elasticsearch.cluster.routing
-
Holds additional information as to why the shard is in unassigned state.
- UnassignedInfo(UnassignedInfo.Reason, String) - Constructor for class org.elasticsearch.cluster.routing.UnassignedInfo
-
creates an UnassignedInfo object based on **current** time
- UnassignedInfo(UnassignedInfo.Reason, String, Exception, int, long, long, boolean, UnassignedInfo.AllocationStatus) - Constructor for class org.elasticsearch.cluster.routing.UnassignedInfo
- UnassignedInfo(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.UnassignedInfo
- UnassignedInfo.AllocationStatus - Enum in org.elasticsearch.cluster.routing
-
Captures the status of an unsuccessful allocation attempt for the shard, causing it to remain in the unassigned state.
- UnassignedInfo.Reason - Enum in org.elasticsearch.cluster.routing
-
Reason why the shard is in unassigned state.
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when an unassigned shard's unassigned information was updated
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- UnassignedIterator() - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
- UnassignedShards(RoutingNodes) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- unassignPersistentTask(String, long, String, ActionListener<PersistentTasksCustomMetaData.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
This unassigns a task from any node, i.e.
- UNAUTHORIZED - org.elasticsearch.rest.RestStatus
-
The request requires user authentication.
- UNAVAILABLE_EXPECTED_SHARD_SIZE - Static variable in class org.elasticsearch.cluster.routing.ShardRouting
-
Used if shard size is not available
- UnavailableShardsException - Exception in org.elasticsearch.action
- UnavailableShardsException(String, int, String, Object...) - Constructor for exception org.elasticsearch.action.UnavailableShardsException
- UnavailableShardsException(StreamInput) - Constructor for exception org.elasticsearch.action.UnavailableShardsException
- UnavailableShardsException(ShardId, String, Object...) - Constructor for exception org.elasticsearch.action.UnavailableShardsException
- UncategorizedExecutionException - Exception in org.elasticsearch.common.util.concurrent
- UncategorizedExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.common.util.concurrent.UncategorizedExecutionException
- UncategorizedExecutionException(StreamInput) - Constructor for exception org.elasticsearch.common.util.concurrent.UncategorizedExecutionException
- unchanged() - Static method in class org.elasticsearch.cluster.LocalClusterUpdateTask
-
no changes were made to the cluster state.
- uncompress(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
Decompress the provided
BytesReference
. - uncompressed() - Method in class org.elasticsearch.common.compress.CompressedXContent
-
Return the uncompressed bytes.
- uncompressIfNeeded(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
Uncompress the provided data, data can be detected as compressed using
CompressorFactory.isCompressed(BytesReference)
. - UNDEFINED_REPOSITORY_STATE_ID - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress
- UNICAST_HOSTS_FILE - Static variable in class org.elasticsearch.discovery.zen.FileBasedUnicastHostsProvider
- UnicastHostsProvider - Interface in org.elasticsearch.discovery.zen
-
A pluggable provider of the list of unicast hosts to use for unicast discovery.
- UnicastHostsProvider.HostsResolver - Interface in org.elasticsearch.discovery.zen
-
Helper object that allows to resolve a list of hosts to a list of transport addresses.
- UnicastZenPing - Class in org.elasticsearch.discovery.zen
- UnicastZenPing(Settings, ThreadPool, TransportService, UnicastHostsProvider, PingContextProvider) - Constructor for class org.elasticsearch.discovery.zen.UnicastZenPing
- UnicastZenPing.PingingRound - Class in org.elasticsearch.discovery.zen
- unicastZenPingExecutorService - Variable in class org.elasticsearch.discovery.zen.UnicastZenPing
- UNICODE_CHARACTER_CLASS - Static variable in class org.elasticsearch.common.regex.Regex
-
This Regex /
Pattern
flag is supported from Java 7 on. - UnifiedHighlighter - Class in org.elasticsearch.search.fetch.subphase.highlight
- UnifiedHighlighter() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- union(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- UniqueAnnotations - Class in org.elasticsearch.common.inject.internal
- unit - Variable in class org.elasticsearch.common.unit.DistanceUnit.Distance
- unit() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Get the radius unit of the circle
- unit() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- unit() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- unit() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the distance unit to use.
- unit(String) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- unit(DistanceUnit) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- unit(DistanceUnit) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The distance unit to use.
- unit(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregationBuilder
- UNKNOWN - org.elasticsearch.Build.Flavor
- UNKNOWN - org.elasticsearch.Build.Type
- UNKNOWN - Static variable in class org.elasticsearch.indices.recovery.RecoveryState.Index
- UNKNOWN - Static variable in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- UNKNOWN_POSITION - Static variable in exception org.elasticsearch.common.ParsingException
- UNKNOWN_POSITION - Static variable in exception org.elasticsearch.search.SearchParseException
- UNKNOWN_SOURCE - Static variable in class org.elasticsearch.common.inject.internal.SourceProvider
-
Indicates that the source is unknown.
- UNKNOWN_UUID - Static variable in class org.elasticsearch.cluster.ClusterState
- UNKNOWN_VERSION - Static variable in class org.elasticsearch.cluster.ClusterState
- UnknownNamedObjectException - Exception in org.elasticsearch.common.xcontent
-
Thrown when
NamedXContentRegistry.parseNamedObject(Class, String, XContentParser, Object)
is called with an unregistered name. - UnknownNamedObjectException(StreamInput) - Constructor for exception org.elasticsearch.common.xcontent.UnknownNamedObjectException
-
Read from a stream.
- UnknownNamedObjectException(XContentLocation, Class<?>, String) - Constructor for exception org.elasticsearch.common.xcontent.UnknownNamedObjectException
- unlike(String[]) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the text from which the terms should not be selected from.
- unlike(MoreLikeThisQueryBuilder.Item[]) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the documents from which the terms should not be selected from.
- unlikeItems() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- unlikeTexts() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- unlock() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- unmapped() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- unmapped(boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- Unmapped(String, R[], boolean, DocValueFormat, SearchContext, Aggregator, InternalRange.Factory, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Unmapped
- UNMAPPED_TYPE - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- unmappedFieldType(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Given a type (eg.
- UnmappedSampler - Class in org.elasticsearch.search.aggregations.bucket.sampler
- UnmappedSampler(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
-
Read from a stream.
- UnmappedSignificantTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
-
Result of the running the significant terms aggregation on an unmapped field.
- UnmappedSignificantTerms(String, int, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- UnmappedSignificantTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
-
Read from a stream.
- UnmappedSignificantTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.significant
-
Concrete type that can't be built because Java needs a concrete type so
InternalTerms.Bucket
can have a self type but UnmappedTerms doesn't ever need to build it because it never returns any buckets. - UnmappedTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the
TermsAggregator
when the field is unmapped. - UnmappedTerms(String, BucketOrder, int, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- UnmappedTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
Read from a stream.
- UnmappedTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Concrete type that can't be built because Java needs a concrete type so
InternalTerms.Bucket
can have a self type but UnmappedTerms doesn't ever need to build it because it never returns any buckets. - unmappedType() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the type to use in case the current field is not mapped in an index.
- unmappedType(String) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Set the type to use in case the current field is not mapped in an index.
- UNPROCESSABLE_ENTITY - org.elasticsearch.rest.RestStatus
-
The 422 (Unprocessable Entity) status code means the server understands the content type of the request entity (hence a 415(Unsupported Media Type) status code is inappropriate), and the syntax of the request entity is correct (thus a 400 (Bad Request) status code is inappropriate) but was unable to process the contained instructions.
- unrecognized(RestRequest, Set<String>, Set<String>, String) - Method in class org.elasticsearch.rest.BaseRestHandler
- UNRECOVERABLE - org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- UNRECOVERED_CLUSTER_VERSION - Static variable in class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- unregister(Task) - Method in class org.elasticsearch.tasks.TaskManager
-
Unregister the task
- unregisterInternalRepository(String) - Method in class org.elasticsearch.repositories.RepositoriesService
- unregisterRepository(RepositoriesService.UnregisterRepositoryRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Unregisters repository in the cluster
- UnregisterRepositoryRequest(String, String) - Constructor for class org.elasticsearch.repositories.RepositoriesService.UnregisterRepositoryRequest
-
Creates a new unregister repository request
- UNSCOPED - Static variable in class org.elasticsearch.common.inject.internal.Scoping
-
No scoping annotation has been applied.
- unset() - Method in enum org.elasticsearch.index.mapper.EnabledAttributeMapper
- UNSET_AUTO_GENERATED_TIMESTAMP - Static variable in class org.elasticsearch.action.index.IndexRequest
-
Value for
IndexRequest.getAutoGeneratedTimestamp()
if the document has an external provided ID. - UNSET_DISABLED - org.elasticsearch.index.mapper.EnabledAttributeMapper
- UNSET_ENABLED - org.elasticsearch.index.mapper.EnabledAttributeMapper
- UNSUPPORTED_MEDIA_TYPE - org.elasticsearch.rest.RestStatus
-
The server is refusing to service the request because the entity of the request is in a format not supported by the requested resource for the requested method.
- UntargettedBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
An untargetted binding.
- UntargettedBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- UntargettedBindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- UntargettedBindingImpl(Injector, Key<T>, Object) - Constructor for class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- UNTRUSTED_CODEBASE - Static variable in class org.elasticsearch.bootstrap.BootstrapInfo
-
codebase location for untrusted scripts (provide some additional safety)
- UNUSED - org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Not allocated
- unweightedAvg(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.movfn.MovingFunctions
-
Calculate a simple unweighted (arithmetic) moving average.
- unwrap() - Method in class org.elasticsearch.client.ParentTaskAssigningClient
-
Fetch the wrapped client.
- unwrap() - Method in interface org.elasticsearch.common.util.concurrent.WrappedRunnable
- unwrap(Runnable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- unwrap(Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- unwrap(Runnable) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- unwrap(Runnable) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Unwraps a command that was previously wrapped by
ThreadContext.preserveContext(Runnable)
. - unwrap(Throwable, Class<?>...) - Static method in class org.elasticsearch.ExceptionsHelper
- unwrap(Aggregator) - Static method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- unwrapAction(String) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Unwraps a proxy action and returns the underlying action
- unwrapCause() - Method in exception org.elasticsearch.ElasticsearchException
-
Unwraps the actual cause from the exception for cases when the exception is a
ElasticsearchWrapperException
. - unwrapCause(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
- unwrapCorruption(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
- unwrapRequest(TransportRequest) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Unwraps a proxy request and returns the original request
- unwrapSingleton(MultiGeoPointValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a single-valued view of the
MultiGeoPointValues
, if it was previously wrapped withFieldData.singleton(GeoPointValues)
, or null. - unwrapSingleton(SortedBinaryDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a single-valued view of the
SortedBinaryDocValues
, if it was previously wrapped withFieldData.singleton(BinaryDocValues)
, or null. - unwrapSingleton(SortedNumericDoubleValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a single-valued view of the
SortedNumericDoubleValues
, if it was previously wrapped withDocValues.singleton(NumericDocValues)
, or null. - update(Map<String, Object>, Map<String, Object>, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Updates the provided changes into the source.
- update(UpdateRequest) - Method in interface org.elasticsearch.client.Client
-
Updates a document based on a script.
- update(UpdateRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- update(UpdateRequest, ActionListener<UpdateResponse>) - Method in interface org.elasticsearch.client.Client
-
Updates a document based on a script.
- update(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- UPDATE - org.elasticsearch.action.DocWriteRequest.OpType
-
Updates a document
- UPDATE_SNAPSHOT_STATUS_ACTION_NAME - Static variable in class org.elasticsearch.snapshots.SnapshotShardsService
- UPDATE_SNAPSHOT_STATUS_ACTION_NAME_V6 - Static variable in class org.elasticsearch.snapshots.SnapshotShardsService
- UpdateAction - Class in org.elasticsearch.action.update
- updateAllTypes() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
True if all fields that span multiple types should be updated, false otherwise
- updateAllTypes() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
True if all fields that span multiple types should be updated, false otherwise
- updateAllTypes() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- updateAllTypes() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
True if all fields that span multiple types should be updated, false otherwise
- updateAllTypes(boolean) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Deprecated.useless with 6.x indices which may only have one type
- updateAllTypes(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- updateAllTypes(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Deprecated.useless with 6.x indices which may only have one type
- updateBlocks(IndexMetaData) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- UpdateByQueryAction - Class in org.elasticsearch.index.reindex
- UpdateByQueryRequest - Class in org.elasticsearch.index.reindex
-
Request to update some documents.
- UpdateByQueryRequest() - Constructor for class org.elasticsearch.index.reindex.UpdateByQueryRequest
- UpdateByQueryRequest(String...) - Constructor for class org.elasticsearch.index.reindex.UpdateByQueryRequest
- UpdateByQueryRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.UpdateByQueryRequest
- UpdateByQueryRequestBuilder - Class in org.elasticsearch.index.reindex
- UpdateByQueryRequestBuilder(ElasticsearchClient, Action<UpdateByQueryRequest, BulkByScrollResponse, UpdateByQueryRequestBuilder>) - Constructor for class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- UPDATED - org.elasticsearch.action.DocWriteResponse.Result
- UPDATED_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- updatedSettings() - Method in class org.elasticsearch.plugins.PluginsService
- updatedSourceAsMap() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- updateDynamicSettings(Settings, Settings.Builder, Settings.Builder, String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Updates a target settings builder with new, updated or deleted settings from a given settings builder.
- updateFieldType(Map<String, MappedFieldType>) - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
Recursively update sub field types.
- updateFieldType(Map<String, MappedFieldType>) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
-
Note: this method is a no-op because field aliases cannot be specified on indexes with more than one type.
- updateFieldType(Map<String, MappedFieldType>) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- updateFieldType(Map<String, MappedFieldType>) - Method in class org.elasticsearch.index.mapper.FieldMapper
- updateFieldType(Map<String, MappedFieldType>) - Method in class org.elasticsearch.index.mapper.Mapper
-
Update the field type of this mapper.
- updateFieldType(Map<String, MappedFieldType>) - Method in class org.elasticsearch.index.mapper.Mapping
-
Recursively update sub field types.
- updateFieldType(Map<String, MappedFieldType>) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- updateFieldType(Map<String, MappedFieldType>) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- updateFromMaster(long, Set<String>, IndexShardRoutingTable, Set<String>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Notifies the tracker of the current allocation IDs in the cluster state.
- updateGlobalCheckpointForShard(String, long) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Update the local knowledge of the global checkpoint for the specified allocation ID.
- updateGlobalCheckpointForShard(String, long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Update the local knowledge of the global checkpoint for the specified allocation ID.
- updateGlobalCheckpointForShard(String, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Update the local knowledge of the global checkpoint for the specified allocation ID.
- updateGlobalCheckpointForShard(ShardId) - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- updateGlobalCheckpointOnReplica(long, String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Updates the global checkpoint on a replica shard after it has been updated by the primary.
- updateGlobalCheckpointOnReplica(long, String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Updates the global checkpoint on a replica shard after it has been updated by the primary.
- UpdateHelper - Class in org.elasticsearch.action.update
-
Helper for translating an update request to an index, delete request or update response.
- UpdateHelper(ScriptService) - Constructor for class org.elasticsearch.action.update.UpdateHelper
- UpdateHelper.ContextFields - Class in org.elasticsearch.action.update
-
Field names used to populate the script context
- UpdateHelper.Result - Class in org.elasticsearch.action.update
- updateIndexMetaData(IndexMetaData) - Method in class org.elasticsearch.index.IndexSettings
-
Updates the settings and index metadata and notifies all registered settings consumers with the new settings iff at least one setting has changed.
- UpdateIndexShardSnapshotStatusRequest() - Constructor for class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- UpdateIndexShardSnapshotStatusRequest(Snapshot, ShardId, SnapshotsInProgress.ShardSnapshotStatus) - Constructor for class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- updateIndicesStats(ActionListener<IndicesStatsResponse>) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
-
Retrieve the latest indices stats, calling the listener when complete
- updateKeyWithNamedWildcard(String) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
- updateLocalCheckpoint(String, long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Notifies the service to update the local checkpoint for the shard with the provided allocation ID.
- updateLocalCheckpointForShard(String, long) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Notifies the primary of a local checkpoint for the given allocation.
- updateLocalCheckpointForShard(String, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Notifies the service to update the local checkpoint for the shard with the provided allocation ID.
- updateMapping(IndexMetaData, IndexMetaData) - Method in class org.elasticsearch.index.IndexService
- updateMapping(IndexMetaData, IndexMetaData) - Method in class org.elasticsearch.index.mapper.MapperService
-
Update mapping by only merging the metadata that is different between received and stored entries
- updateMapping(IndexMetaData, IndexMetaData) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Checks if index requires refresh from master.
- updateMappingOnMaster(Index, String, Mapping) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
-
Same as
MappingUpdatedAction.updateMappingOnMaster(Index, String, Mapping, TimeValue)
using the default timeout. - updateMappingOnMaster(Index, String, Mapping, TimeValue) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
-
Update mappings on the master node, waiting for the change to be committed, but not for the mapping update to be applied on all nodes.
- updateMappings(Mapping, ShardId, String) - Method in interface org.elasticsearch.action.bulk.MappingUpdatePerformer
-
Update the mappings on the master.
- updateMaxUnsafeAutoIdTimestamp(long) - Method in class org.elasticsearch.index.engine.Engine
-
Forces this engine to advance its max_unsafe_auto_id_timestamp marker to at least the given timestamp.
- updateMaxUnsafeAutoIdTimestamp(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- updateMaxUnsafeAutoIdTimestamp(long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- updateMaxUnsafeAutoIdTimestamp(long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Since operations stored in soft-deletes do not have max_auto_id_timestamp, the primary has to propagate its max_auto_id_timestamp (via
IndexShard.getMaxSeenAutoIdTimestamp()
of all processed append-only requests to replicas at the beginning of a peer-recovery or a primary-replica resync to force a replica to disable optimization for all append-only requests which are replicated via replication while its retry variants are replicated via recovery without auto_id_timestamp. - updateMetaData(IndexMetaData, IndexMetaData) - Method in class org.elasticsearch.index.IndexService
- updateMetaData(IndexMetaData, IndexMetaData) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Updates the metadata of this index.
- updateMetaDataWithRoutingChanges(RoutingTable) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns updated
MetaData
based on the changes that were made to the routing nodes - updateNodes(long, RoutingNodes) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- updateNodesAndPing(ClusterState) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
-
make sure that nodes in clusterState are pinged.
- updateNodeStats(ActionListener<NodesStatsResponse>) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
-
Retrieve the latest nodes stats, calling the listener when complete
- updateNumberOfReplicas(int, String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
Update the number of replicas for the specified indices.
- updateNumberOfReplicas(int, String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
Update the number of replicas for the specified indices.
- updatePersistentTaskState(String, long, PersistentTaskState, ActionListener<PersistentTasksCustomMetaData.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Update the state of a persistent task
- updatePersistentTaskState(PersistentTaskState, ActionListener<PersistentTasksCustomMetaData.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
-
Updates the persistent state for the corresponding persistent task.
- UpdatePersistentTaskStatusAction - Class in org.elasticsearch.persistent
- UpdatePersistentTaskStatusAction.Request - Class in org.elasticsearch.persistent
- UpdatePersistentTaskStatusAction.RequestBuilder - Class in org.elasticsearch.persistent
- UpdatePersistentTaskStatusAction.TransportAction - Class in org.elasticsearch.persistent
- updater(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Returns a callable runnable that calls
AbstractScopedSettings.SettingUpdater.apply(Object, Settings, Settings)
if the settings actually changed. - updateRemoteCluster(String, List<String>, String, boolean, TimeValue) - Method in class org.elasticsearch.transport.RemoteClusterAware
-
Subclasses must implement this to receive information about updated cluster aliases.
- updateRemoteCluster(String, List<String>, String, boolean, TimeValue) - Method in class org.elasticsearch.transport.RemoteClusterService
- UpdateRequest - Class in org.elasticsearch.action.update
- UpdateRequest() - Constructor for class org.elasticsearch.action.update.UpdateRequest
- UpdateRequest(String, String, String) - Constructor for class org.elasticsearch.action.update.UpdateRequest
- UpdateRequestBuilder - Class in org.elasticsearch.action.update
- UpdateRequestBuilder(ElasticsearchClient, UpdateAction) - Constructor for class org.elasticsearch.action.update.UpdateRequestBuilder
- UpdateRequestBuilder(ElasticsearchClient, UpdateAction, String, String, String) - Constructor for class org.elasticsearch.action.update.UpdateRequestBuilder
- UpdateResponse - Class in org.elasticsearch.action.update
- UpdateResponse() - Constructor for class org.elasticsearch.action.update.UpdateResponse
- UpdateResponse(ReplicationResponse.ShardInfo, ShardId, String, String, long, long, long, DocWriteResponse.Result) - Constructor for class org.elasticsearch.action.update.UpdateResponse
- UpdateResponse(ShardId, String, String, long, DocWriteResponse.Result) - Constructor for class org.elasticsearch.action.update.UpdateResponse
-
Constructor to be used when a update didn't translate in a write.
- UpdateResponse.Builder - Class in org.elasticsearch.action.update
-
Builder class for
UpdateResponse
. - updateRestoreInfoWithRoutingChanges(RestoreInProgress) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns updated
RestoreInProgress
based on the changes that were made to the routing nodes - updateRestoreStateWithDeletedIndices(RestoreInProgress, Set<Index>) - Static method in class org.elasticsearch.snapshots.RestoreService
- updateRetentionLeasesOnReplica(RetentionLeases) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Updates retention leases on a replica.
- updateRetentionLeasesOnReplica(RetentionLeases) - Method in class org.elasticsearch.index.shard.IndexShard
-
Updates retention leases on a replica.
- UpdateScript - Class in org.elasticsearch.script
-
An update script.
- UpdateScript(Map<String, Object>, Map<String, Object>) - Constructor for class org.elasticsearch.script.UpdateScript
- UpdateScript.Factory - Interface in org.elasticsearch.script
- updateSeqID(long, long) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- updateSettings(ClusterUpdateSettingsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Updates settings in the cluster.
- updateSettings(ClusterUpdateSettingsRequest, ActionListener<ClusterUpdateSettingsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Update settings in the cluster.
- updateSettings(UpdateSettingsClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService
- updateSettings(UpdateSettingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Updates settings of one or more indices.
- updateSettings(UpdateSettingsRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Updates settings of one or more indices.
- updateSettings(Settings, String...) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- updateSettings(Settings, Settings.Builder, Settings.Builder, String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Updates a target settings builder with new, updated or deleted settings from a given settings builder.
- UpdateSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.put
- UpdateSettingsClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.settings.put
-
Cluster state update request that allows to update settings for some indices
- UpdateSettingsClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
- updateSettingsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
A request to update indices settings.
- UpdateSettingsRequest - Class in org.elasticsearch.action.admin.indices.settings.put
-
Request for an update index settings action
- UpdateSettingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- UpdateSettingsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Constructs a new request to update settings for one or more indices
- UpdateSettingsRequest(Settings, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Constructs a new request to update settings for one or more indices
- UpdateSettingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.settings.put
-
Builder for an update index settings request
- UpdateSettingsRequestBuilder(ElasticsearchClient, UpdateSettingsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
- updateShardState(ShardRouting, long, BiConsumer<IndexShard, ActionListener<PrimaryReplicaSyncer.ResyncTask>>, long, Set<String>, IndexShardRoutingTable, Set<String>) - Method in class org.elasticsearch.index.shard.IndexShard
- updateShardState(ShardRouting, long, BiConsumer<IndexShard, ActionListener<PrimaryReplicaSyncer.ResyncTask>>, long, Set<String>, IndexShardRoutingTable, Set<String>) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Updates the shard state based on an incoming cluster state: - Updates and persists the new routing value.
- updateSourceContentType() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- updateTasks - Variable in class org.elasticsearch.cluster.service.MasterService.TaskInputs
- updateTaskState(String, PersistentTaskState) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
-
Updates the task state
- updateUnassigned(UnassignedInfo, RecoverySource) - Method in class org.elasticsearch.cluster.routing.ShardRouting
- updateUnassigned(UnassignedInfo, RecoverySource, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
updates the unassigned info and recovery source on the current unassigned shard
- updateVersion(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- updateVersion(long, long) - Method in enum org.elasticsearch.index.VersionType
-
Returns the new version for a document, based on its current one and the specified in the request
- upgrade(UpgradeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly upgrade one or more indices
- upgrade(UpgradeRequest) - Method in class org.elasticsearch.index.shard.IndexShard
-
Upgrades the shard to the current version of Lucene and returns the minimum segment version
- upgrade(UpgradeRequest, ActionListener<UpgradeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly upgrade one or more indices
- upgrade(KeyStoreWrapper, Path, char[]) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Upgrades the format of the keystore, if necessary.
- UPGRADE_ONLY_ANCIENT_SEGMENTS - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest.Defaults
- UpgradeAction - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Upgrade index/indices action.
- upgradeIndexMetaData(IndexMetaData, Version) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexUpgradeService
-
Checks that the index can be upgraded to the current version of the master node.
- upgradeIndexSettings(UpgradeSettingsClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService
- UpgradeKeyStoreCommand - Class in org.elasticsearch.common.settings
-
A sub-command for the keystore CLI that enables upgrading the keystore format.
- upgradeOnlyAncientSegments() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
-
Should the upgrade only the ancient (older major version of Lucene) segments? Defaults to
false
. - upgradeOnlyAncientSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- upgradeRequest() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.ShardUpgradeRequest
- upgradeRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates an upgrade request.
- UpgradeRequest - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
A request to upgrade one or more indices.
- UpgradeRequest() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- UpgradeRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
-
Constructs an optimization request over one or more indices.
- UpgradeRequest.Defaults - Class in org.elasticsearch.action.admin.indices.upgrade.post
- UpgradeRequestBuilder - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
A request to upgrade one or more indices.
- UpgradeRequestBuilder(ElasticsearchClient, UpgradeAction) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequestBuilder
- UpgradeResponse - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
A response for the upgrade action.
- upgradeSettings(Settings) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Upgrade all settings eligible for upgrade in the specified settings instance.
- UpgradeSettingsAction - Class in org.elasticsearch.action.admin.indices.upgrade.post
- UpgradeSettingsClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Cluster state update request that allows to change minimum compatibility settings for some indices
- UpgradeSettingsClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsClusterStateUpdateRequest
- UpgradeSettingsRequest - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Request for an update index settings action
- UpgradeSettingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
- UpgradeSettingsRequest(Map<String, Tuple<Version, String>>) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
-
Constructs a new request to update minimum compatible version settings for one or more indices
- UpgradeSettingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Builder for an update index settings request
- UpgradeSettingsRequestBuilder(ElasticsearchClient, UpgradeSettingsAction) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequestBuilder
- upgradeStatus(UpgradeStatusRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check upgrade status of one or more indices
- upgradeStatus(UpgradeStatusRequest, ActionListener<UpgradeStatusResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check upgrade status of one or more indices
- UpgradeStatusAction - Class in org.elasticsearch.action.admin.indices.upgrade.get
- UpgradeStatusRequest - Class in org.elasticsearch.action.admin.indices.upgrade.get
- UpgradeStatusRequest() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusRequest
- UpgradeStatusRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusRequest
- UpgradeStatusRequestBuilder - Class in org.elasticsearch.action.admin.indices.upgrade.get
- UpgradeStatusRequestBuilder(ElasticsearchClient, UpgradeStatusAction) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusRequestBuilder
- UpgradeStatusResponse - Class in org.elasticsearch.action.admin.indices.upgrade.get
- UPPER - org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats.Bounds
- upsert(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(byte[], XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(Object...) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(String, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(Map) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(Map, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the index request to be used if the document does not exists.
- upsert(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(XContentType, Object...) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsertRequest() - Method in class org.elasticsearch.action.update.UpdateRequest
- upserts - Variable in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- URGENT - org.elasticsearch.common.Priority
- uri() - Method in class org.elasticsearch.rest.RestRequest
-
The uri of the rest request, with the query string.
- URIPattern - Class in org.elasticsearch.common.util
-
URI Pattern matcher The pattern is URI in which authority, path, query and fragment can be replace with simple pattern.
- URIPattern(String) - Constructor for class org.elasticsearch.common.util.URIPattern
-
Constructs uri pattern
- urlParamsToQueryBuilder(RestRequest) - Static method in class org.elasticsearch.rest.action.RestActions
- UsageService - Class in org.elasticsearch.usage
-
A service to monitor usage of Elasticsearch features.
- UsageService() - Constructor for class org.elasticsearch.usage.UsageService
- USE_ADAPTIVE_REPLICA_SELECTION_SETTING - Static variable in class org.elasticsearch.cluster.routing.OperationRouting
- USE_DEFAULT_FORMAT - Static variable in class org.elasticsearch.search.fetch.subphase.DocValueFieldsContext
- USE_PREFIX_8_WARNING - Static variable in class org.elasticsearch.common.joda.JodaDeprecationPatterns
- USE_PROXY - org.elasticsearch.rest.RestStatus
-
The requested resource MUST be accessed through the proxy given by the Location field.
- useAllFields() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Deprecated.
- useAllFields() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Deprecated.
- useAllFields(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Deprecated.
- useAllFields(Boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Deprecated.
- useAnyUnassignedShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns
true
iff the first unassigned shard is to be used - useAnyUnassignedShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Signal that the first unassigned shard should be used
- useCompressedOops() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
The value of the JVM flag UseCompressedOops, if available otherwise "unknown".
- used(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- usedDeprecatedField(String, String) - Method in class org.elasticsearch.common.xcontent.LoggingDeprecationHandler
- usedDeprecatedName(String, String) - Method in class org.elasticsearch.common.xcontent.LoggingDeprecationHandler
- useDisMax() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- useDisMax() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Deprecated.
- useDisMax(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Deprecated.
- useDisMax(Boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Deprecated.use a tieBreaker of 1.0f to disable "dis-max" query or select the appropriate
MultiMatchQueryBuilder.Type
- useExplicitFieldOrder() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Gets value set with
HighlightBuilder.useExplicitFieldOrder(boolean)
- useExplicitFieldOrder(boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Send the fields to be highlighted using a syntax that is specific about the order in which they should be highlighted.
- useG1GC() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- useOrSuppress(T, T) - Static method in class org.elasticsearch.ExceptionsHelper
- USER_DEFINED_META_DATA - Static variable in class org.elasticsearch.cluster.service.ClusterService
- userInput - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- useSerialGC() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- UTF8StreamWriter - Class in org.elasticsearch.common.io
- UTF8StreamWriter() - Constructor for class org.elasticsearch.common.io.UTF8StreamWriter
-
Creates a UTF-8 writer having a byte buffer of moderate capacity (2048).
- UTF8StreamWriter(int) - Constructor for class org.elasticsearch.common.io.UTF8StreamWriter
-
Creates a UTF-8 writer having a byte buffer of specified capacity.
- utf8ToString() - Method in class org.elasticsearch.common.bytes.BytesReference
-
Interprets the referenced bytes as UTF8 bytes, returning the resulting string
- uuid() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- uuid() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns restore uuid
- UUIDs - Class in org.elasticsearch.common
- UUIDs() - Constructor for class org.elasticsearch.common.UUIDs
V
- v() - Method in class org.elasticsearch.common.recycler.NoneRecycler.NV
- v() - Method in interface org.elasticsearch.common.recycler.Recycler.V
-
Reference to the value.
- V_5_0_0 - Static variable in class org.elasticsearch.Version
- V_5_0_0_alpha1 - Static variable in class org.elasticsearch.Version
- V_5_0_0_alpha2 - Static variable in class org.elasticsearch.Version
- V_5_0_0_alpha3 - Static variable in class org.elasticsearch.Version
- V_5_0_0_alpha4 - Static variable in class org.elasticsearch.Version
- V_5_0_0_alpha4_ID - Static variable in class org.elasticsearch.Version
- V_5_0_0_alpha5 - Static variable in class org.elasticsearch.Version
- V_5_0_0_beta1 - Static variable in class org.elasticsearch.Version
- V_5_0_0_ID - Static variable in class org.elasticsearch.Version
- V_5_0_0_rc1 - Static variable in class org.elasticsearch.Version
- V_5_0_1 - Static variable in class org.elasticsearch.Version
- V_5_0_2 - Static variable in class org.elasticsearch.Version
- V_5_1_1 - Static variable in class org.elasticsearch.Version
- V_5_1_2 - Static variable in class org.elasticsearch.Version
- V_5_2_0 - Static variable in class org.elasticsearch.Version
- V_5_2_0_ID - Static variable in class org.elasticsearch.Version
- V_5_2_1 - Static variable in class org.elasticsearch.Version
- V_5_2_2 - Static variable in class org.elasticsearch.Version
- V_5_3_0 - Static variable in class org.elasticsearch.Version
- V_5_3_1 - Static variable in class org.elasticsearch.Version
- V_5_3_2 - Static variable in class org.elasticsearch.Version
- V_5_3_3 - Static variable in class org.elasticsearch.Version
- V_5_4_0 - Static variable in class org.elasticsearch.Version
- V_5_4_0_ID - Static variable in class org.elasticsearch.Version
- V_5_4_1 - Static variable in class org.elasticsearch.Version
- V_5_4_2 - Static variable in class org.elasticsearch.Version
- V_5_4_3 - Static variable in class org.elasticsearch.Version
- V_5_5_0 - Static variable in class org.elasticsearch.Version
- V_5_5_1 - Static variable in class org.elasticsearch.Version
- V_5_5_2 - Static variable in class org.elasticsearch.Version
- V_5_5_3 - Static variable in class org.elasticsearch.Version
- V_5_6_0 - Static variable in class org.elasticsearch.Version
- V_5_6_0_ID - Static variable in class org.elasticsearch.Version
- V_5_6_1 - Static variable in class org.elasticsearch.Version
- V_5_6_10 - Static variable in class org.elasticsearch.Version
- V_5_6_11 - Static variable in class org.elasticsearch.Version
- V_5_6_12 - Static variable in class org.elasticsearch.Version
- V_5_6_13 - Static variable in class org.elasticsearch.Version
- V_5_6_14 - Static variable in class org.elasticsearch.Version
- V_5_6_15 - Static variable in class org.elasticsearch.Version
- V_5_6_16 - Static variable in class org.elasticsearch.Version
- V_5_6_17 - Static variable in class org.elasticsearch.Version
- V_5_6_2 - Static variable in class org.elasticsearch.Version
- V_5_6_3 - Static variable in class org.elasticsearch.Version
- V_5_6_4 - Static variable in class org.elasticsearch.Version
- V_5_6_5 - Static variable in class org.elasticsearch.Version
- V_5_6_6 - Static variable in class org.elasticsearch.Version
- V_5_6_7 - Static variable in class org.elasticsearch.Version
- V_5_6_8 - Static variable in class org.elasticsearch.Version
- V_5_6_9 - Static variable in class org.elasticsearch.Version
- V_6_0_0 - Static variable in class org.elasticsearch.Version
- V_6_0_0_alpha1 - Static variable in class org.elasticsearch.Version
- V_6_0_0_alpha2 - Static variable in class org.elasticsearch.Version
- V_6_0_0_beta1 - Static variable in class org.elasticsearch.Version
- V_6_0_0_beta2 - Static variable in class org.elasticsearch.Version
- V_6_0_0_rc1 - Static variable in class org.elasticsearch.Version
- V_6_0_0_rc2 - Static variable in class org.elasticsearch.Version
- V_6_0_1 - Static variable in class org.elasticsearch.Version
- V_6_1_0 - Static variable in class org.elasticsearch.Version
- V_6_1_1 - Static variable in class org.elasticsearch.Version
- V_6_1_2 - Static variable in class org.elasticsearch.Version
- V_6_1_3 - Static variable in class org.elasticsearch.Version
- V_6_1_4 - Static variable in class org.elasticsearch.Version
- V_6_2_0 - Static variable in class org.elasticsearch.Version
- V_6_2_1 - Static variable in class org.elasticsearch.Version
- V_6_2_2 - Static variable in class org.elasticsearch.Version
- V_6_2_3 - Static variable in class org.elasticsearch.Version
- V_6_2_4 - Static variable in class org.elasticsearch.Version
- V_6_3_0 - Static variable in class org.elasticsearch.Version
- V_6_3_1 - Static variable in class org.elasticsearch.Version
- V_6_3_2 - Static variable in class org.elasticsearch.Version
- V_6_4_0 - Static variable in class org.elasticsearch.Version
- V_6_4_1 - Static variable in class org.elasticsearch.Version
- V_6_4_2 - Static variable in class org.elasticsearch.Version
- V_6_4_3 - Static variable in class org.elasticsearch.Version
- V_6_5_0 - Static variable in class org.elasticsearch.Version
- V_6_5_1 - Static variable in class org.elasticsearch.Version
- V_6_5_2 - Static variable in class org.elasticsearch.Version
- V_6_5_3 - Static variable in class org.elasticsearch.Version
- V_6_5_4 - Static variable in class org.elasticsearch.Version
- V_6_6_0 - Static variable in class org.elasticsearch.Version
- V_6_6_1 - Static variable in class org.elasticsearch.Version
- V_6_6_2 - Static variable in class org.elasticsearch.Version
- V_6_7_0 - Static variable in class org.elasticsearch.Version
- V_6_7_1 - Static variable in class org.elasticsearch.Version
- V_6_7_2 - Static variable in class org.elasticsearch.Version
- V_6_8_0 - Static variable in class org.elasticsearch.Version
- V_6_8_1 - Static variable in class org.elasticsearch.Version
- V_6_8_2 - Static variable in class org.elasticsearch.Version
- V_EMPTY - Static variable in class org.elasticsearch.Version
- V_EMPTY_ID - Static variable in class org.elasticsearch.Version
- valid() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- VALID_ACTION_PREFIXES - Static variable in class org.elasticsearch.transport.TransportService
-
A set of all valid action prefixes.
- VALID_AGG_NAME - Static variable in class org.elasticsearch.search.aggregations.AggregatorFactories
- VALID_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- VALID_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- validate() - Method in class org.elasticsearch.action.ActionRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- validate() - Method in class org.elasticsearch.action.bulk.BulkRequest
- validate() - Method in class org.elasticsearch.action.delete.DeleteRequest
- validate() - Method in class org.elasticsearch.action.explain.ExplainRequest
- validate() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- validate() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- validate() - Method in class org.elasticsearch.action.get.GetRequest
- validate() - Method in class org.elasticsearch.action.get.MultiGetRequest
- validate() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- validate() - Method in class org.elasticsearch.action.index.IndexRequest
- validate() - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- validate() - Method in class org.elasticsearch.action.ingest.GetPipelineRequest
- validate() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- validate() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- validate() - Method in class org.elasticsearch.action.main.MainRequest
- validate() - Method in class org.elasticsearch.action.search.ClearScrollRequest
- validate() - Method in class org.elasticsearch.action.search.MultiSearchRequest
- validate() - Method in class org.elasticsearch.action.search.SearchRequest
- validate() - Method in class org.elasticsearch.action.search.SearchScrollRequest
- validate() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- validate() - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- validate() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- validate() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- validate() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- validate() - Method in interface org.elasticsearch.action.support.WriteRequest
- validate() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- validate() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- validate() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- validate() - Method in class org.elasticsearch.action.update.UpdateRequest
- validate() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- validate() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- validate() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- validate() - Method in class org.elasticsearch.index.reindex.ReindexRequest
- validate() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncRequest
- validate() - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- validate() - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- validate() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- validate() - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- validate() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- validate(int) - Method in class org.elasticsearch.action.support.ActiveShardCount
-
Validates that the instance is valid for the given number of replicas in an index.
- validate(String, String, String, Boolean) - Method in interface org.elasticsearch.cluster.metadata.AliasAction.NewAliasValidator
- validate(MetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- validate(Settings, boolean) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates that all settings are registered and valid.
- validate(Settings, boolean, boolean) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates that all settings are registered and valid.
- validate(Settings, boolean, boolean, boolean) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates that all settings are registered and valid.
- validate(Settings, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates that all settings are registered and valid.
- validate(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Validates this path over the given aggregator as a point of reference.
- validate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
-
Validates the state of this factory (makes sure the factory is properly configured)
- validate(AggregatorFactory<?>, Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Internal: Validates the state of this factory (makes sure the factory is properly configured)
- validate(BucketOrder, Aggregator) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Validate a bucket ordering strategy for an
Aggregator
. - validate(Params, ClusterState) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Checks the current cluster state for compatibility with the params
- validate(T) - Method in interface org.elasticsearch.common.settings.Setting.Validator
-
Validate this setting's value in isolation.
- validate(T, Map<Setting<T>, T>) - Method in interface org.elasticsearch.common.settings.Setting.Validator
-
Validate this setting against its dependencies, specified by
Setting.Validator.settings()
. - ValidateActions - Class in org.elasticsearch.action
- ValidateActions() - Constructor for class org.elasticsearch.action.ValidateActions
- validateAlias(String, String, String, Function<String, IndexMetaData>) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Validate a proposed alias.
- validateAlias(Alias, String, MetaData) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Allows to validate an
Alias
and make sure it's valid before it gets added to the index metadata. - validateAliasFilter(String, byte[], QueryShardContext, NamedXContentRegistry) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Validates an alias filter by parsing it using the provided
QueryShardContext
- validateAliasFilter(String, String, QueryShardContext, NamedXContentRegistry) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Validates an alias filter by parsing it using the provided
QueryShardContext
- validateAliasMetaData(AliasMetaData, String, MetaData) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Allows to validate an
AliasMetaData
and make sure it's valid before it gets added to the index metadata. - validateAliasStandalone(Alias) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Allows to partially validate an alias, without knowing which index it'll get applied to.
- validateContextPaths(Version, List<FieldMapper>, Function<String, MappedFieldType>) - Static method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Verifies that all field paths specified in contexts point to the fields with correct mappings
- validateHole(LineStringBuilder, LineStringBuilder) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
-
Validates only 1 vertex is tangential (shared) between the interior and exterior of a polygon
- validateIndexName(String, ClusterState) - Static method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
-
Validate the name for an index against some static rules and a cluster state.
- validateIndexOrAliasName(String, BiFunction<String, String, ? extends RuntimeException>) - Static method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
-
Validate the name for an index or alias against some static rules.
- validateIndexSettings(String, Settings, ClusterState, boolean) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
- validateNodeBeforeAcceptingRequests(BootstrapContext, BoundTransportAddress, List<BootstrapCheck>) - Method in class org.elasticsearch.node.Node
-
Hook for validating the node after network services are started but before the cluster service is started and before the network service starts accepting incoming network requests.
- validateNonNullIndex() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- validateQuery(ValidateQueryRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Validate a query for correctness.
- validateQuery(ValidateQueryRequest, ActionListener<ValidateQueryResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Validate a query for correctness.
- ValidateQueryAction - Class in org.elasticsearch.action.admin.indices.validate.query
- ValidateQueryRequest - Class in org.elasticsearch.action.admin.indices.validate.query
-
A request to validate a specific query.
- ValidateQueryRequest() - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- ValidateQueryRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Constructs a new validate request against the provided indices.
- ValidateQueryRequestBuilder - Class in org.elasticsearch.action.admin.indices.validate.query
- ValidateQueryRequestBuilder(ElasticsearchClient, ValidateQueryAction) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
- ValidateQueryResponse - Class in org.elasticsearch.action.admin.indices.validate.query
-
The response of the validate action.
- validateReferences(Version, Function<String, MappedFieldType>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Checks if the current context is consistent with the rest of the fields.
- validateReferences(Version, Function<String, MappedFieldType>) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- validateRequest(PutMappingRequest, ClusterState, Index[]) - Method in interface org.elasticsearch.action.admin.indices.mapping.put.MappingRequestValidator
-
Validates a given put mapping request with its associated concrete indices and the current state.
- validateRequest(StreamInput, long, String) - Method in class org.elasticsearch.transport.TcpTransport
- validateSearchContext(SearchContext, TransportRequest) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- validateSearchContext(SearchContext, TransportRequest) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed prior to using a
SearchContext
that has been retrieved from the active contexts. - validateSeqNoBasedCASParams(DocWriteRequest, ActionRequestValidationException) - Static method in interface org.elasticsearch.action.DocWriteRequest
- validateSequentiallyOrderedParentAggs(AggregatorFactory<?>, String, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
-
Validates pipeline aggregations that need sequentially ordered data.
- validateSettingKey(Setting) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
- validateSettingKey(Setting) - Method in class org.elasticsearch.common.settings.IndexScopedSettings
- validateSettingName(String) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Ensure the given setting name is allowed.
- validateSettings(BreakerSettings[]) - Static method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
-
Validate that child settings are valid
- validateStateIsFromCurrentMaster(Logger, DiscoveryNodes, ClusterState) - Static method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
In the case we follow an elected master the new cluster state needs to have the same elected master This method checks for this and throws an exception if needed
- validateTmpFile() - Method in class org.elasticsearch.env.Environment
-
Ensure the configured temp directory is a valid directory
- validateUpdate(Settings) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates the given settings by running it through all update listeners without applying it.
- validateVersionForReads(long) - Method in enum org.elasticsearch.index.VersionType
-
validate the version is a valid value for this type when reading.
- validateVersionForWrites(long) - Method in enum org.elasticsearch.index.VersionType
-
validate the version is a valid value for this type when writing.
- validation() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the validation method to use for this sort builder.
- validation(GeoValidationMethod) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Sets validation method for this sort builder.
- validationErrors() - Method in exception org.elasticsearch.common.ValidationException
-
Returns the validation errors accumulated
- ValidationException - Exception in org.elasticsearch.common
-
Encapsulates an accumulation of validation errors
- ValidationException() - Constructor for exception org.elasticsearch.common.ValidationException
- validFileName(String) - Static method in class org.elasticsearch.common.Strings
- validFileNameExcludingAstrix(String) - Static method in class org.elasticsearch.common.Strings
- validHeaderValue(String) - Static method in class org.elasticsearch.rest.DeprecationRestHandler
-
This does a very basic pass at validating that a header's value contains only expected characters according to RFC-5987, and those that it references.
- value - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition
- value - Variable in class org.elasticsearch.common.Table.Cell
- value - Variable in class org.elasticsearch.common.unit.DistanceUnit.Distance
- value - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
- value - Variable in class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Value to find matches for.
- value - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
- value - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- value - Variable in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- value() - Method in enum org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Returns code that represents the snapshot state
- value() - Method in enum org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- value() - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- value() - Method in enum org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
- value() - Method in class org.elasticsearch.cluster.ClusterName
- value() - Method in enum org.elasticsearch.cluster.health.ClusterHealthStatus
- value() - Method in enum org.elasticsearch.cluster.RestoreInProgress.State
-
Returns state code
- value() - Method in enum org.elasticsearch.cluster.routing.ShardRoutingState
-
Byte value of this
ShardRoutingState
- value() - Method in enum org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
- value() - Method in enum org.elasticsearch.cluster.SnapshotsInProgress.State
- value() - Method in class org.elasticsearch.common.Explicit
- value() - Method in annotation type org.elasticsearch.common.inject.assistedinject.Assisted
-
The unique name for this parameter.
- value() - Method in annotation type org.elasticsearch.common.inject.ImplementedBy
-
The implementation type.
- value() - Method in annotation type org.elasticsearch.common.inject.name.Named
- value() - Method in annotation type org.elasticsearch.common.inject.ProvidedBy
-
The implementation type.
- value() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
- value() - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- value() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- value() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- value() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- value() - Method in enum org.elasticsearch.index.query.RegexpFlag
- value() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the text to parse the query from.
- value() - Method in enum org.elasticsearch.index.query.SimpleQueryStringFlag
- value() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- value() - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
- value() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
- value() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.ParsedCardinality
- value() - Method in class org.elasticsearch.search.aggregations.metrics.mad.InternalMedianAbsoluteDeviation
- value() - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
- value() - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
- value() - Method in interface org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregation.SingleValue
- value() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- value() - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
- value() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
- value() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ParsedValueCount
- value() - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.InternalWeightedAvg
- value() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
- value() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- value() - Method in enum org.elasticsearch.search.aggregations.support.ValuesSourceType
- value() - Method in enum org.elasticsearch.snapshots.SnapshotState
-
Returns code that represents the snapshot state
- value(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
- value(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
- value(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
- value(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- value(String) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
- value(MultiValuesSourceFieldConfig) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- Value(BitSet, ShardId) - Constructor for class org.elasticsearch.index.cache.bitset.BitsetFilterCache.Value
- VALUE - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- VALUE_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- VALUE_FIELD - Static variable in class org.elasticsearch.index.query.BaseTermQueryBuilder
- VALUE_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- VALUE_SOURCE_TYPE - Static variable in enum org.elasticsearch.search.aggregations.support.ValuesSourceType
- VALUE_TYPE - Static variable in class org.elasticsearch.search.aggregations.AggregationBuilder.CommonFields
- VALUE_TYPE - Static variable in enum org.elasticsearch.search.aggregations.support.ValueType
- valueAsString - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- valueAsString - Variable in class org.elasticsearch.search.aggregations.metrics.stats.ParsedStats
- valueAsString(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- valueCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- ValueCount - Interface in org.elasticsearch.search.aggregations.metrics.valuecount
-
An get that holds the number of values that the current document set has for a specific field.
- ValueCountAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.valuecount
- ValueCountAggregationBuilder(String, ValueType) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- ValueCountAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
-
Read from a stream.
- ValueCountAggregationBuilder(ValueCountAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregationBuilder
- ValueCountAggregator - Class in org.elasticsearch.search.aggregations.metrics.valuecount
-
A field data based aggregator that counts the number of values a specific field has within the aggregation context.
- ValueCountAggregator(String, ValuesSource, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
- ValueCountAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.valuecount
- ValueCountAggregatorFactory(String, ValuesSourceConfig<ValuesSource>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregatorFactory
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Given a value that comes from the stored fields API, convert it to the expected type.
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- valueOf(String) - Static method in enum org.apache.lucene.queries.BinaryDocValuesRangeQuery.LengthType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.admin.indices.shrink.ResizeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.bulk.TransportShardBulkAction.ReplicaItemExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.DocWriteRequest.OpType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.DocWriteResponse.Result
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.search.SearchType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.support.IndicesOptions.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.support.IndicesOptions.WildcardStates
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.ThreadingModel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.Build.Flavor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.Build.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.block.ClusterBlockLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.ClusterState.Metric
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.health.ClusterHealthStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.metadata.IndexMetaData.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.metadata.MetaData.XContentContext
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.node.DiscoveryNode.Role
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.RestoreInProgress.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.Preference
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.RecoverySource.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.ShardRoutingState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cluster.SnapshotsInProgress.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.breaker.CircuitBreaker.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.cache.RemovalNotification.RemovalReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.component.Lifecycle.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.geo.GeoDistance
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.geo.GeoShapeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.geo.ShapeRelation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.geo.SpatialStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.hash.MurmurHash3
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.inject.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.Priority
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.rounding.DateTimeUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.settings.Setting.Property
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.time.FormatNames
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.unit.ByteSizeUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.unit.MemorySizeValue
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.unit.SizeUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.util.Comparators
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.util.PageCacheRecycler.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.analysis.AnalyzerScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.engine.Engine.Operation.Origin
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.engine.Engine.Operation.TYPE
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.engine.Engine.Result.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.engine.Engine.SearcherScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.engine.Engine.SyncedFlushResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.IndexModule.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.DynamicTemplate.MatchType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.EnabledAttributeMapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.MappedFieldType.Relation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.MapperService.MergeReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.ObjectMapper.Dynamic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.SourceToParse.Origin
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.GeoExecType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.GeoValidationMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.RegexpFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.SimpleQueryStringFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.search.MatchQuery.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.search.MatchQuery.ZeroTermsQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.shard.IndexShardState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.SlowLogLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.translog.Translog.Durability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.translog.Translog.Operation.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.VersionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.indices.recovery.RecoveryState.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.ingest.IngestDocument.MetaData
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.persistent.AllocatedPersistentTask.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.persistent.decider.AssignmentDecision.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.rest.RestRequest.Method
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.rest.RestStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.script.ScriptType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats.Bounds
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.SeasonalityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.support.MissingValues
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.support.ValuesSourceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.support.ValueType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.internal.SearchContext.Lifetime
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.MultiValueMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.profile.aggregation.AggregationTimingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.profile.query.QueryTimingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.rescore.QueryRescoreMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.sort.SortMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.sort.SortOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.suggest.completion.context.ContextMapping.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.suggest.SortBy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.snapshots.SnapshotState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.transport.TransportRequestOptions.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.transport.Transports
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Returns the enum constant of this type with the specified name.
- values - Variable in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- values - Variable in class org.elasticsearch.index.fielddata.SortingNumericDocValues
- values - Variable in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
- values - Variable in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- values() - Static method in enum org.apache.lucene.queries.BinaryDocValuesRangeQuery.LengthType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.admin.indices.shrink.ResizeType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.bulk.TransportShardBulkAction.ReplicaItemExecutionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.DocWriteRequest.OpType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.DocWriteResponse.Result
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.search.SearchType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.support.IndicesOptions.Option
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.support.IndicesOptions.WildcardStates
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.action.ThreadingModel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.Build.Flavor
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.Build.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.block.ClusterBlockLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.ClusterState.Metric
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.health.ClusterHealthStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.metadata.IndexMetaData.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.metadata.MetaData.XContentContext
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.node.DiscoveryNode.Role
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.RestoreInProgress.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.Preference
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.RecoverySource.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.ShardRoutingState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.cluster.SnapshotsInProgress.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.breaker.CircuitBreaker.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.elasticsearch.common.cache.Cache
-
An LRU sequencing of the values in the cache.
- values() - Static method in enum org.elasticsearch.common.cache.RemovalNotification.RemovalReason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- values() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- values() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- values() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- values() - Static method in enum org.elasticsearch.common.component.Lifecycle.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.geo.GeoDistance
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.geo.GeoShapeType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.geo.ShapeRelation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.geo.SpatialStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.hash.MurmurHash3
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.inject.Stage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.lease.Releasables
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.Priority
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.rounding.DateTimeUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.settings.Setting.Property
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.time.FormatNames
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.unit.ByteSizeUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.unit.DistanceUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.unit.MemorySizeValue
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.unit.SizeUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.common.util.Comparators
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
- values() - Static method in enum org.elasticsearch.common.util.PageCacheRecycler.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.analysis.AnalyzerScope
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.engine.Engine.Operation.Origin
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.engine.Engine.Operation.TYPE
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.engine.Engine.Result.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.engine.Engine.SearcherScope
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.engine.Engine.SyncedFlushResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.IndexModule.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.DynamicTemplate.MatchType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.EnabledAttributeMapper
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.MappedFieldType.Relation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.MapperService.MergeReason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.ObjectMapper.Dynamic
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.mapper.SourceToParse.Origin
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.query.GeoExecType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.query.GeoValidationMethod
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.query.Operator
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.query.RegexpFlag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.query.SimpleQueryStringFlag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- values() - Static method in enum org.elasticsearch.index.search.MatchQuery.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.search.MatchQuery.ZeroTermsQuery
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.shard.IndexShardState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.SlowLogLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.translog.Translog.Durability
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.translog.Translog.Operation.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.index.VersionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in interface org.elasticsearch.indices.analysis.PreBuiltCacheFactory.PreBuiltCache
- values() - Static method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.indices.recovery.RecoveryState.Stage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.ingest.IngestDocument.MetaData
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.persistent.AllocatedPersistentTask.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.persistent.decider.AssignmentDecision.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.rest.RestRequest.Method
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.rest.RestStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.elasticsearch.script.DeprecationMap
- values() - Static method in enum org.elasticsearch.script.ScriptType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory.ExecutionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
-
Get the values to compute percentiles from.
- values() - Static method in enum org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats.Bounds
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.SeasonalityType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.support.MissingValues
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.support.ValuesSourceType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.aggregations.support.ValueType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.internal.SearchContext.Lifetime
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- values() - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
- values() - Method in class org.elasticsearch.search.lookup.SourceLookup
- values() - Static method in enum org.elasticsearch.search.MultiValueMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.profile.aggregation.AggregationTimingType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.profile.query.QueryTimingType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.rescore.QueryRescoreMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.sort.SortMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.sort.SortOrder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.suggest.completion.context.ContextMapping.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.suggest.SortBy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.snapshots.SnapshotState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.transport.TransportRequestOptions.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.transport.Transports
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Returns an array containing the constants of this enum type, in the order they are declared.
- Values() - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.Values
- VALUES - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- VALUES_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregationBuilder
- valuesCursor - Variable in class org.elasticsearch.index.fielddata.SortingNumericDocValues
- valueSerializer - Variable in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- valuesIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns a direct iterator over the keys.
- valuesIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a direct iterator over the keys.
- ValueSource - Interface in org.elasticsearch.ingest
-
Holds a value.
- ValueSource.ByteValue - Class in org.elasticsearch.ingest
- ValueSource.ListValue - Class in org.elasticsearch.ingest
- ValueSource.MapValue - Class in org.elasticsearch.ingest
- ValueSource.ObjectValue - Class in org.elasticsearch.ingest
- ValueSource.TemplatedValue - Class in org.elasticsearch.ingest
- valueSourceType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- valuesSource - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- valuesSource - Variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- valuesSource - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
- valuesSource - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
- ValuesSource - Class in org.elasticsearch.search.aggregations.support
- ValuesSource() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource
- ValuesSource.Bytes - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Bytes.FieldData - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Bytes.Script - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Bytes.WithOrdinals - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Bytes.WithOrdinals.FieldData - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.GeoPoint - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.GeoPoint.Fielddata - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Numeric - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Numeric.FieldData - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Numeric.Script - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Numeric.WithScript - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.WithScript - Class in org.elasticsearch.search.aggregations.support
- ValuesSourceAggregationBuilder<VS extends ValuesSource,AB extends ValuesSourceAggregationBuilder<VS,AB>> - Class in org.elasticsearch.search.aggregations.support
- ValuesSourceAggregationBuilder(String, ValuesSourceType, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- ValuesSourceAggregationBuilder(StreamInput, ValuesSourceType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Read an aggregation from a stream that serializes its targetValueType.
- ValuesSourceAggregationBuilder(StreamInput, ValuesSourceType, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Read an aggregation from a stream that does not serialize its targetValueType.
- ValuesSourceAggregationBuilder(ValuesSourceAggregationBuilder<VS, AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- ValuesSourceAggregationBuilder.LeafOnly<VS extends ValuesSource,AB extends ValuesSourceAggregationBuilder<VS,AB>> - Class in org.elasticsearch.search.aggregations.support
- ValuesSourceAggregatorFactory<VS extends ValuesSource,AF extends ValuesSourceAggregatorFactory<VS,AF>> - Class in org.elasticsearch.search.aggregations.support
- ValuesSourceAggregatorFactory(String, ValuesSourceConfig<VS>, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- ValuesSourceConfig<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.support
-
A configuration that tells aggregations how to retrieve data from the index in order to run a specific aggregation.
- ValuesSourceConfig(ValuesSourceType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- ValuesSourceParserHelper - Class in org.elasticsearch.search.aggregations.support
- ValuesSourceType - Enum in org.elasticsearch.search.aggregations.support
- valueType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the
ValueType
for the value produced by this source - valueType() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Gets the
ValueType
for the value produced by this aggregation - valueType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the
ValueType
for the value produced by this aggregation - valueType(ValueType) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the
ValueType
for the value produced by this source - valueType(ValueType) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Sets the
ValueType
for the value produced by this aggregation - valueType(ValueType) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the
ValueType
for the value produced by this aggregation - ValueType - Enum in org.elasticsearch.search.aggregations.support
- VARIABLE - org.apache.lucene.queries.BinaryDocValuesRangeQuery.LengthType
- variance - Variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.ParsedExtendedStats
- verbose - Variable in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- verbose() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns whether the request will return a verbose response.
- verbose() - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
-
true
if detailed information about each segment should be returned,false
otherwise. - verbose(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Set to
false
to only show the snapshot names and the indices they contain. - verbose(boolean) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
-
Sets the
verbose
option. - VERBOSE_INTRODUCED - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- VerificationFailure - Class in org.elasticsearch.repositories
- VerificationFailure(String, Exception) - Constructor for class org.elasticsearch.repositories.VerificationFailure
- verify() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Returns true if repository should be verified after creation
- verify() - Method in class org.elasticsearch.index.store.VerifyingIndexOutput
-
Verifies the checksum and compares the written length with the expected file length.
- verify(boolean) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets whether or not the repository should be verified after creation
- verify(String, boolean, String, ActionListener<RepositoriesService.VerifyResponse>) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
- verify(String, DiscoveryNode) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- verify(String, DiscoveryNode) - Method in class org.elasticsearch.repositories.FilterRepository
- verify(String, DiscoveryNode) - Method in interface org.elasticsearch.repositories.Repository
-
Verifies repository settings on data node.
- verify(IndexInput) - Static method in class org.elasticsearch.index.store.Store
- verify(IndexOutput) - Static method in class org.elasticsearch.index.store.Store
- VERIFY_INDEX - org.elasticsearch.indices.recovery.RecoveryState.Stage
-
potentially running check index
- verifyActive() - Method in class org.elasticsearch.index.shard.IndexShard
- verifyEngineBeforeIndexClosing() - Method in class org.elasticsearch.index.engine.Engine
-
Performs the pre-closing checks on the
Engine
. - verifyEngineBeforeIndexClosing() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- VerifyIndex() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- VerifyIndex(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- verifyIndexIsDeleted(Index, ClusterState) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Verify that the contents on disk for the given index is deleted; if not, delete the contents.
- verifyIndexIsDeleted(Index, ClusterState) - Method in class org.elasticsearch.indices.IndicesService
-
Verify that the contents on disk for the given index is deleted; if not, delete the contents.
- verifyIndexMetadata(IndexMetaData, IndexMetaData) - Method in class org.elasticsearch.indices.IndicesService
-
This method verifies that the given
metaData
holds sane values to create anIndexService
. - VerifyingIndexOutput - Class in org.elasticsearch.index.store
-
abstract class for verifying what was written.
- VerifyNodeRepositoryAction - Class in org.elasticsearch.repositories
- VerifyNodeRepositoryAction(TransportService, ClusterService, RepositoriesService) - Constructor for class org.elasticsearch.repositories.VerifyNodeRepositoryAction
- VerifyNodeRepositoryAction.VerifyNodeRepositoryRequest - Class in org.elasticsearch.repositories
- VerifyNodeRepositoryRequest() - Constructor for class org.elasticsearch.repositories.VerifyNodeRepositoryAction.VerifyNodeRepositoryRequest
- verifyRepository(String, ActionListener<RepositoriesService.VerifyResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
- verifyRepository(VerifyRepositoryRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Verifies a repository.
- verifyRepository(VerifyRepositoryRequest, ActionListener<VerifyRepositoryResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Verifies a repository.
- VerifyRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Unregister repository action
- verifyRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Verifies snapshot repository
- VerifyRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Unregister repository request.
- VerifyRepositoryRequest() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
- VerifyRepositoryRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
-
Constructs a new unregister repository request with the provided name.
- VerifyRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Builder for unregister repository request
- VerifyRepositoryRequestBuilder(ElasticsearchClient, VerifyRepositoryAction) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequestBuilder
-
Constructs unregister repository request builder
- VerifyRepositoryRequestBuilder(ElasticsearchClient, VerifyRepositoryAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequestBuilder
-
Constructs unregister repository request builder with specified repository name
- VerifyRepositoryResponse - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Verify repository response
- VerifyRepositoryResponse(List<VerifyRepositoryResponse.NodeView>) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- VerifyRepositoryResponse(ClusterName, DiscoveryNode[]) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- VerifyRepositoryResponse.NodeView - Class in org.elasticsearch.action.admin.cluster.repositories.verify
- VerifyResponse(DiscoveryNode[], VerificationFailure[]) - Constructor for class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
- verifyShardBeforeIndexClosing() - Method in class org.elasticsearch.index.shard.IndexShard
-
Performs the pre-closing checks on the
IndexShard
. - version - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- version - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- version - Variable in class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
- version - Variable in class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
- version - Variable in class org.elasticsearch.index.analysis.AbstractTokenizerFactory
- version - Variable in class org.elasticsearch.index.engine.Segment
- version - Variable in class org.elasticsearch.transport.NetworkMessage
- version() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- version() - Method in class org.elasticsearch.action.delete.DeleteRequest
- version() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the document version for this request
- version() - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the version, which will cause the get operation to only be performed if a matching version exists and no changes happened on the doc since then.
- version() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- version() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns stored version.
- version() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- version() - Method in class org.elasticsearch.action.update.UpdateRequest
- version() - Method in class org.elasticsearch.cluster.ClusterState
- version() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- version() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- version() - Method in class org.elasticsearch.cluster.metadata.MetaData
- version() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- version() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
Returns the version of the
RoutingTable
. - version() - Method in class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
- version() - Method in class org.elasticsearch.index.analysis.AbstractTokenizerFactory
- version() - Method in class org.elasticsearch.index.engine.Engine.Get
- version() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- version() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- version() - Method in class org.elasticsearch.index.engine.Engine.Operation
- version() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- version() - Method in class org.elasticsearch.index.mapper.ParseContext
- version() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- version() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- version() - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
The version of this retention lease collection.
- version() - Method in class org.elasticsearch.index.translog.Translog.Delete
- version() - Method in class org.elasticsearch.index.translog.Translog.Index
- version() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- version() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- version() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Indicates whether the document's version will be included in the search hits.
- version() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates whether the document's version will be included in the search hits.
- version() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- version() - Method in class org.elasticsearch.search.internal.SearchContext
- version() - Method in class org.elasticsearch.search.internal.SubSearchContext
- version() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns the version of elasticsearch that the snapshot was created with.
- version() - Method in class org.elasticsearch.transport.BytesTransportRequest
- version(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregationBuilder
-
Should each
SearchHit
be returned with a version associated with it. - version(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- version(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
- version(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
- version(long) - Method in class org.elasticsearch.action.delete.DeleteRequest
- version(long) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Sets the version, which will perform the operation only if a matching version exists and no changes happened on the doc since then.
- version(long) - Method in class org.elasticsearch.action.get.GetRequest
- version(long) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- version(long) - Method in class org.elasticsearch.action.index.IndexRequest
- version(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- version(long) - Method in class org.elasticsearch.action.update.UpdateRequest
- version(long) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- version(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- version(long) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- version(long) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- version(long) - Method in class org.elasticsearch.index.engine.Engine.Get
- version(long) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- version(long) - Method in class org.elasticsearch.search.SearchHit
- version(Boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should each
SearchHit
be returned with a version associated with it. - version(Integer) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- version(Integer) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- version(Integer) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- version(Field) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- version(Field) - Method in class org.elasticsearch.index.mapper.ParseContext
- Version - Class in org.elasticsearch
- VERSION - org.elasticsearch.cluster.ClusterState.Metric
- VERSION - org.elasticsearch.ingest.IngestDocument.MetaData
- VERSION - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- VERSION - Static variable in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- VERSION_CONFLICTS_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- VERSION_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- VERSION_ID_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- VERSION_INTRODUCED - Static variable in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- VERSION_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- VERSION_TYPE - org.elasticsearch.ingest.IngestDocument.MetaData
- versionAsInteger() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- VersionConflictEngineException - Exception in org.elasticsearch.index.engine
- VersionConflictEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, String, String, long, long, long, long) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, String, String, String) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, Throwable, String, String, String) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, Engine.Operation, long, boolean) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionedNamedWriteable - Interface in org.elasticsearch.common.io.stream
-
A
NamedWriteable
that has a minimum version associated with it. - VersionFetchSubPhase - Class in org.elasticsearch.search.fetch.subphase
- VersionFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.VersionFetchSubPhase
- VersionFieldMapper - Class in org.elasticsearch.index.mapper
-
Mapper for the _version field.
- VersionFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- VersionFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- versions() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
-
Returns the highest upgrade version of the node that performed metadata upgrade and the the version of the oldest lucene segment for each index that was upgraded.
- versions() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsClusterStateUpdateRequest
-
Returns the index to version map for indices that should be updated
- versions(Map<String, Tuple<Version, String>>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsClusterStateUpdateRequest
-
Sets the index to version map for indices that should be updated
- versions(Map<String, Tuple<Version, String>>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
-
Sets the index versions to be updated
- Versions - Class in org.elasticsearch.common.lucene.uid
- Versions() - Constructor for class org.elasticsearch.common.lucene.uid.Versions
- VersionsAndSeqNoResolver - Class in org.elasticsearch.common.lucene.uid
-
Utility class to resolve the Lucene doc ID, version, seqNo and primaryTerms for a given uid.
- VersionsAndSeqNoResolver.DocIdAndSeqNo - Class in org.elasticsearch.common.lucene.uid
-
Wraps an
LeafReaderContext
, a doc ID relative to the context doc base and a seqNo. - VersionsAndSeqNoResolver.DocIdAndVersion - Class in org.elasticsearch.common.lucene.uid
-
Wraps an
LeafReaderContext
, a doc ID relative to the context doc base and a version. - versionSetting(String, Version, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- versionType() - Method in class org.elasticsearch.action.delete.DeleteRequest
- versionType() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the document version type for this request
- versionType() - Method in class org.elasticsearch.action.get.GetRequest
- versionType() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- versionType() - Method in class org.elasticsearch.action.index.IndexRequest
- versionType() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- versionType() - Method in class org.elasticsearch.action.update.UpdateRequest
- versionType() - Method in class org.elasticsearch.index.engine.Engine.Get
- versionType() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- versionType() - Method in class org.elasticsearch.index.engine.Engine.Operation
- versionType() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- versionType() - Method in class org.elasticsearch.index.translog.Translog.Delete
- versionType() - Method in class org.elasticsearch.index.translog.Translog.Index
- versionType(VersionType) - Method in class org.elasticsearch.action.delete.DeleteRequest
- versionType(VersionType) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Sets the versioning type.
- versionType(VersionType) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the versioning type.
- versionType(VersionType) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- versionType(VersionType) - Method in class org.elasticsearch.action.index.IndexRequest
- versionType(VersionType) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- versionType(VersionType) - Method in class org.elasticsearch.action.update.UpdateRequest
- versionType(VersionType) - Method in class org.elasticsearch.index.engine.Engine.Get
- versionType(VersionType) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- VersionType - Enum in org.elasticsearch.index
- versionTypeForReplicationAndRecovery() - Method in enum org.elasticsearch.index.VersionType
-
Some version types require different semantics for primary and replicas.
- versionUpdatePack() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- visit(Binding<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(Binding<T>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a mapping from a key (type and optional annotation) to the strategy for getting instances of the type.
- visit(ConstructorBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a constructor binding.
- visit(ConstructorBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ConvertedConstantBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a binding created from converting a bound instance to a new type.
- visit(ConvertedConstantBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ExposedBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a binding to a key exposed from an enclosed private environment.
- visit(ExposedBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(InjectionRequest) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(InjectionRequest) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a request to inject the instance fields and methods of an instance.
- visit(InstanceBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a instance binding.
- visit(InstanceBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(LinkedKeyBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a linked key binding.
- visit(LinkedKeyBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(MembersInjectorLookup<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(MembersInjectorLookup<T>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a lookup of the members injector.
- visit(Message) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(Message) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit an error message and the context in which it occurred.
- visit(PrivateElements) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(PrivateElements) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a collection of configuration elements for a private binder.
- visit(ProviderBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a binding to a
Provider
that delegates to the binding for the provided type. - visit(ProviderBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ProviderInstanceBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a provider instance binding.
- visit(ProviderInstanceBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ProviderKeyBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a provider key binding.
- visit(ProviderKeyBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ProviderLookup<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(ProviderLookup<T>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a lookup of the provider for a type.
- visit(ScopeBinding) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(ScopeBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a registration of a scope annotation with the scope that implements it.
- visit(StaticInjectionRequest) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(StaticInjectionRequest) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a request to inject the static fields and methods of type.
- visit(TypeConverterBinding) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(TypeConverterBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a registration of type converters for matching target types.
- visit(TypeListenerBinding) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(TypeListenerBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit an injectable type listener binding.
- visit(UntargettedBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit an untargetted binding.
- visit(UntargettedBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visitEagerSingleton() - Method in interface org.elasticsearch.common.inject.spi.BindingScopingVisitor
-
Visit an eager singleton or single instance.
- visitEagerSingleton() - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- visitNoScoping() - Method in interface org.elasticsearch.common.inject.spi.BindingScopingVisitor
-
Visit an unspecified or unscoped strategy.
- visitNoScoping() - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- visitOther() - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
-
Default visit implementation.
- visitOther(Binding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
Default visit implementation.
- visitOther(Element) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
Default visit implementation.
- visitScope(Scope) - Method in interface org.elasticsearch.common.inject.spi.BindingScopingVisitor
-
Visit a scope instance.
- visitScope(Scope) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- visitScopeAnnotation(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.spi.BindingScopingVisitor
-
Visit a scope annotation.
- visitScopeAnnotation(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- visualizeKeyDistribution(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- visualizeKeyDistribution(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- vocabluarySize - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- voidProviderMethod() - Method in class org.elasticsearch.common.inject.internal.Errors
W
- WAIT_CLUSTERSTATE - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- WAIT_UNTIL - org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Leave this request open until a refresh has made the contents of this request visible to search.
- waitForActiveShards - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
-
The number of shard copies that must be active before proceeding with the replication action.
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexClusterStateUpdateRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.bulk.BulkRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.update.UpdateRequest
- waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
A shortcut for
ClusterHealthRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
A shortcut for
CreateIndexRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
A shortcut for
OpenIndexRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
-
A shortcut for
RolloverRequestBuilder.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
A shortcut for
BulkRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
A shortcut for
ReplicationRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.update.UpdateRequest
-
A shortcut for
UpdateRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(String[], ActiveShardCount, TimeValue, Consumer<Boolean>, Consumer<Exception>) - Method in class org.elasticsearch.action.support.ActiveShardsObserver
-
Waits on the specified number of active shards to be started before executing the
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Sets the number of shard copies that must be active across all indices before getting the health status.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the number of shard copies that should be active for index creation to return.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexClusterStateUpdateRequest
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Sets the number of shard copies that should be active for indices opening to return.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
-
Sets the number of shard copies that should be active for creation of the new rollover index to return.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Sets the number of shard copies that must be active before proceeding with the write.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Sets the number of shard copies that must be active before proceeding with the replication operation.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the number of shard copies that must be active before proceeding with the write.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
The number of shard copies that must be active before proceeding with the write.
- waitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns true if the request should wait for the snapshot completion before returning
- waitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns wait for completion setting
- waitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
If set to true the operation should wait for the snapshot completion before returning.
- waitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
If this parameter is set to true the operation will wait for completion of restore process before returning.
- waitForCompletionTimeout(TimeValue) - Static method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- waitForEvents() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForEvents(Priority) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForGreenStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForIndex(Directory, long) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Wait for an index to exist for up to
timeLimitMillis
. - waitForMetaDataVersion() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- waitForMetaDataVersion(long) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- waitForNewMasterAndRetry(String, ClusterStateObserver, TransportRequest, ActionListener<Void>, Predicate<ClusterState>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
- waitForNextChange(ClusterStateObserver.Listener) - Method in class org.elasticsearch.cluster.ClusterStateObserver
- waitForNextChange(ClusterStateObserver.Listener, Predicate<ClusterState>) - Method in class org.elasticsearch.cluster.ClusterStateObserver
- waitForNextChange(ClusterStateObserver.Listener, Predicate<ClusterState>, TimeValue) - Method in class org.elasticsearch.cluster.ClusterStateObserver
-
Wait for the next cluster state which satisfies statePredicate
- waitForNextChange(ClusterStateObserver.Listener, TimeValue) - Method in class org.elasticsearch.cluster.ClusterStateObserver
- waitForNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForNodes(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Waits for N number of nodes.
- waitForNoInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForNoInitializingShards(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Sets whether the request should wait for there to be no initializing shards before retrieving the cluster health status.
- waitForNoRelocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForNoRelocatingShards(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Sets whether the request should wait for there to be no relocating shards before retrieving the cluster health status.
- waitForOpsToComplete(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Waits for all operations up to the provided sequence number to complete.
- waitForPersistentTask(Predicate<PersistentTasksCustomMetaData.PersistentTask<?>>, TimeValue, PersistentTasksService.WaitForPersistentTaskListener<?>) - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
-
Waits for a given persistent task to comply with a given predicate, then call back the listener accordingly.
- waitForPersistentTaskCondition(String, Predicate<PersistentTasksCustomMetaData.PersistentTask<?>>, TimeValue, PersistentTasksService.WaitForPersistentTaskListener<?>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Waits for a given persistent task to comply with a given predicate, then call back the listener accordingly.
- waitForPersistentTasksCondition(Predicate<PersistentTasksCustomMetaData>, TimeValue, ActionListener<Boolean>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Waits for persistent tasks to comply with a given predicate, then call back the listener accordingly.
- waitForStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForStatus(ClusterHealthStatus) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForTaskCompletion(Task, long) - Method in class org.elasticsearch.tasks.TaskManager
-
Blocks the calling thread, waiting for the task to vanish from the TaskManager.
- waitForTimeout() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- waitForTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- waitForYellowStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitIfOngoing() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
Returns
true
iff a flush should block if a another flush operation is already running. - waitIfOngoing(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
if set to
true
the flush will block if a another flush operation is already running until the flush can be performed. - WAITING - org.elasticsearch.cluster.SnapshotsInProgress.State
- waitingIndices() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- waitToBeElectedAsMaster(int, TimeValue, NodeJoinController.ElectionCallback) - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
waits for enough incoming joins from master eligible nodes to complete the master election
- warm(Engine.Searcher) - Method in interface org.elasticsearch.index.engine.Engine.Warmer
-
Called once a new Searcher is opened on the top-level searcher.
- warmer - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- warmer() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- warmer(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Warmer - org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- WARMER - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- warmerService() - Method in class org.elasticsearch.index.shard.IndexShard
- warmerStats() - Method in class org.elasticsearch.index.shard.IndexShard
- WarmerStats - Class in org.elasticsearch.index.warmer
- WarmerStats() - Constructor for class org.elasticsearch.index.warmer.WarmerStats
- WarmerStats(long, long, long) - Constructor for class org.elasticsearch.index.warmer.WarmerStats
- warmReader(IndexShard, Engine.Searcher) - Method in interface org.elasticsearch.index.IndexWarmer.Listener
-
Queue tasks to warm-up the given segments and return handles that allow to wait for termination of the execution of those tasks.
- WARN - org.elasticsearch.index.SlowLogLevel
- warnAboutSlowTaskIfNeeded(TimeValue, String) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- warnAboutSlowTaskIfNeeded(TimeValue, String) - Method in class org.elasticsearch.cluster.service.MasterService
- WARNING_HEADER_PATTERN - Static variable in class org.elasticsearch.common.logging.DeprecationLogger
-
Regular expression to test if a string matches the RFC7234 specification for warning headers.
- wasReadFromDiff() - Method in class org.elasticsearch.cluster.ClusterState
- watcher() - Method in class org.elasticsearch.watcher.WatcherHandle
- WatcherHandle<W extends ResourceWatcher> - Class in org.elasticsearch.watcher
- WEEK - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- WEEK_DATE - org.elasticsearch.common.time.FormatNames
- WEEK_DATE_TIME - org.elasticsearch.common.time.FormatNames
- WEEK_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- WEEK_OF_WEEKYEAR - org.elasticsearch.common.rounding.DateTimeUnit
- WEEK_YEAR - org.elasticsearch.common.time.FormatNames
- WEEK_YEAR_WEEK - org.elasticsearch.common.time.FormatNames
- weekDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full date as four digit weekyear, two digit week of weekyear, and one digit day of week (xxxx-'W'ww-e).
- weekDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full weekyear date and time, separated by a 'T' (xxxx-'W'ww-e'T'HH:mm:ss.SSSZZ).
- weekDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full weekyear date and time without millis, separated by a 'T' (xxxx-'W'ww-e'T'HH:mm:ssZZ).
- weeks(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- weekyear() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit weekyear.
- WEEKYEAR_WEEK_DAY - org.elasticsearch.common.time.FormatNames
- weekyearWeek() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit weekyear and two digit week of weekyear.
- weekyearWeekDay() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit weekyear, two digit week of weekyear, and one digit day of week.
- weigher(ToLongBiFunction<K, V>) - Method in class org.elasticsearch.common.cache.CacheBuilder
- weighShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
- weight() - Method in class org.elasticsearch.common.cache.Cache
-
The weight of the entries in the cache.
- weight(BalancedShardsAllocator.Balancer, BalancedShardsAllocator.ModelNode, String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.WeightFunction
- weight(MultiValuesSourceFieldConfig) - Method in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- WEIGHT_BYTES_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- WEIGHT_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- WEIGHT_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- WEIGHT_INT_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- WEIGHT_LONG_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- WEIGHT_OBJECTS_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- WeightBuilder - Class in org.elasticsearch.index.query.functionscore
-
A query that multiplies the weight to the score.
- WeightBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.WeightBuilder
-
Standard constructor.
- WeightBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.WeightBuilder
-
Read from a stream.
- weightedAvg(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Avg
aggregation with the given name. - WeightedAvg - Interface in org.elasticsearch.search.aggregations.metrics.weighted_avg
-
An aggregation that computes the average of the values in the current bucket.
- WeightedAvgAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics.weighted_avg
- WeightedAvgAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- WeightedAvgAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
-
Read from a stream.
- WeightedAvgAggregationBuilder(WeightedAvgAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregationBuilder
- WeightedAvgAggregator - Class in org.elasticsearch.search.aggregations.metrics.weighted_avg
- WeightedAvgAggregator(String, MultiValuesSource.NumericMultiValuesSource, DocValueFormat, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregator
- WeightedAvgAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics.weighted_avg
- WeightedAvgAggregatorFactory(String, Map<String, ValuesSourceConfig<ValuesSource.Numeric>>, DocValueFormat, SearchContext, AggregatorFactory<?>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.weighted_avg.WeightedAvgAggregatorFactory
- weightFactorFunction(float) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- WeightFactorFunction - Class in org.elasticsearch.common.lucene.search.function
- WeightFactorFunction(float) - Constructor for class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- WeightFactorFunction(float, ScoreFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- WeightFunction(float, float) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.WeightFunction
- weightShardAdded(BalancedShardsAllocator.Balancer, BalancedShardsAllocator.ModelNode, String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.WeightFunction
- weightShardRemoved(BalancedShardsAllocator.Balancer, BalancedShardsAllocator.ModelNode, String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.WeightFunction
- whenComplete(CheckedConsumer<Response, Exception>, Consumer<Exception>) - Method in class org.elasticsearch.action.StepListener
-
Registers the given actions which are called when this step is completed.
- WHITESPACE - org.elasticsearch.index.query.SimpleQueryStringFlag
- WHITESPACE - org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- WhitespaceAnalyzerProvider - Class in org.elasticsearch.index.analysis
- WhitespaceAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.WhitespaceAnalyzerProvider
- width() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- wildcardQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Implements the wildcard search query.
- wildcardQuery(String, MultiTermQuery.RewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- wildcardQuery(String, MultiTermQuery.RewriteMethod, QueryShardContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- WildcardQueryBuilder - Class in org.elasticsearch.index.query
-
Implements the wildcard search query.
- WildcardQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.WildcardQueryBuilder
-
Implements the wildcard search query.
- WildcardQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.WildcardQueryBuilder
-
Read from a stream.
- WildcardTypeImpl(Type[], Type[]) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- window() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Gets the window size for the moving average.
- window(int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregationBuilder
-
Sets the window size for the moving average.
- windowSize - Variable in class org.elasticsearch.search.rescore.RescorerBuilder
- windowSize() - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- windowSize(int) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- with(Iterable<? extends Module>) - Method in interface org.elasticsearch.common.inject.util.Modules.OverriddenModuleBuilder
-
See the EDSL example at
override()
. - with(TemporalAdjuster) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- with(TemporalField, long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- with(Module...) - Method in interface org.elasticsearch.common.inject.util.Modules.OverriddenModuleBuilder
-
See the EDSL example at
override()
. - withAddedEntry(SnapshotDeletionsInProgress.Entry) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns a new instance of
SnapshotDeletionsInProgress
which adds the givenSnapshotDeletionsInProgress.Entry
to the invoking instance. - withBackoff(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkRequest) - Method in class org.elasticsearch.action.bulk.Retry
-
Invokes #accept(BulkRequest, ActionListener).
- withBackoff(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.Retry
-
Invokes #accept(BulkRequest, ActionListener).
- withBackoff(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkRequest, ActionListener<BulkResponse>, Settings) - Method in class org.elasticsearch.action.bulk.Retry
-
Deprecated.Prefer
Retry.withBackoff(BiConsumer, BulkRequest, ActionListener)
. TheSettings
isn't used. - withBackoff(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkRequest, Settings) - Method in class org.elasticsearch.action.bulk.Retry
-
Deprecated.prefer
Retry.withBackoff(BiConsumer, BulkRequest)
. TheSettings
isn't used. - withCircuitBreaking() - Method in class org.elasticsearch.common.util.BigArrays
-
Return an instance of this BigArrays class with circuit breaking explicitly enabled, instead of only accounting enabled
- withContentOrSourceParamParserOrNull(CheckedConsumer<XContentParser, IOException>) - Method in class org.elasticsearch.rest.RestRequest
-
Call a consumer with the parser for the contents of this request if it has contents, otherwise with a parser for the
source
parameter if there is one, otherwise withnull
. - withDayOfMonth(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withDayOfYear(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withEarlierOffsetAtOverlap() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withFixedOffsetZone() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withHour(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- WITHIN - org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- WITHIN - org.elasticsearch.common.geo.ShapeRelation
- WITHIN - org.elasticsearch.index.mapper.MappedFieldType.Relation
- withinQuery(String, Object, Object, boolean, boolean) - Method in enum org.elasticsearch.index.mapper.RangeFieldMapper.RangeType
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- withKeyRemoved(K) - Method in class org.elasticsearch.cluster.DiffableUtils.ImmutableOpenMapDiff
-
Returns a new diff map with the given key removed, does not modify the invoking instance.
- withLaterOffsetAtOverlap() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withLocale(Locale) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- withLocale(Locale) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Create a copy of this formatter that is configured to parse dates in the specified locale
- withMinute(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withMonth(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withNano(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- WithOrdinals() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
- withPartialValue(Object) - Method in exception org.elasticsearch.common.inject.ConfigurationException
-
Returns a copy of this configuration exception with the specified partial value.
- withRemainDecision(Decision) - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Creates a new move decision from this decision, plus adding a remain decision.
- withRemovedEntry(SnapshotDeletionsInProgress.Entry) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns a new instance of
SnapshotDeletionsInProgress
which removes the given entry from the invoking instance. - withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- WithScript(ValuesSource.Numeric, SearchScript.LeafFactory) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- WithScript(ValuesSource, SearchScript.LeafFactory) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.WithScript
- withSecond(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withSource(Object) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns a binder that uses
source
as the reference location for configuration errors. - withSource(Object) - Method in class org.elasticsearch.common.inject.internal.Errors
-
Returns an instance that uses
source
as a reference point for newly added errors. - withSource(Object) - Method in interface org.elasticsearch.common.inject.PrivateBinder
- withTimeout(long) - Method in class org.elasticsearch.transport.TransportRequestOptions.Builder
- withTimeout(TimeValue) - Method in class org.elasticsearch.transport.TransportRequestOptions.Builder
- withType(TransportRequestOptions.Type) - Method in class org.elasticsearch.transport.TransportRequestOptions.Builder
- withYear(int) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- withYear(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withZone(ZoneId) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- withZone(ZoneId) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Create a copy of this formatter that is configured to parse dates in the specified time zone
- withZoneSameInstant(ZoneId) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withZoneSameLocal(ZoneId) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- wktName() - Method in enum org.elasticsearch.common.geo.GeoShapeType
-
wkt shape name
- word - Variable in class org.elasticsearch.action.termvectors.TermVectorsFilter.ScoreTerm
- WORD - org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- WordScorer - Class in org.elasticsearch.search.suggest.phrase
- WordScorer(IndexReader, String, double, BytesRef) - Constructor for class org.elasticsearch.search.suggest.phrase.WordScorer
- WordScorer(IndexReader, Terms, String, double, BytesRef) - Constructor for class org.elasticsearch.search.suggest.phrase.WordScorer
- WordScorer.WordScorerFactory - Interface in org.elasticsearch.search.suggest.phrase
- WorkerBulkByScrollTaskState - Class in org.elasticsearch.index.reindex
-
Task behavior for
BulkByScrollTask
that does the actual work of querying and indexing - WorkerBulkByScrollTaskState(BulkByScrollTask, Integer, float) - Constructor for class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- WORSE_BALANCE - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The shard could not be rebalanced to another node despite rebalancing being allowed, because moving the shard to the other node would not form a better cluster balance.
- wrap(byte[]) - Static method in class org.elasticsearch.common.io.stream.StreamInput
- wrap(byte[], int, int) - Static method in class org.elasticsearch.common.io.stream.StreamInput
- wrap(Iterable<? extends BucketCollector>) - Static method in class org.elasticsearch.search.aggregations.MultiBucketCollector
-
Wraps a list of
BucketCollector
s with aMultiBucketCollector
. - wrap(Iterable<Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Wrap several releasables into a single one.
- wrap(Iterable<LeafBucketCollector>) - Static method in class org.elasticsearch.search.aggregations.LeafBucketCollector
- wrap(Object, ScriptService) - Static method in interface org.elasticsearch.ingest.ValueSource
- wrap(Runnable) - Static method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that listens for a response (or failure) and executes the corresponding runnable when the response (or failure) is received.
- wrap(Runnable, Priority) - Static method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
- wrap(Callable<T>, Priority) - Static method in class org.elasticsearch.common.util.concurrent.PrioritizedCallable
- wrap(DirectoryReader) - Method in class org.elasticsearch.index.shard.IndexSearcherWrapper
-
Wraps the given
DirectoryReader
. - wrap(DirectoryReader, ShardId) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Wraps the given reader in a
ElasticsearchDirectoryReader
as well as all it's sub-readers inElasticsearchLeafReader
to expose the given shard Id. - wrap(IndexSearcher) - Method in class org.elasticsearch.index.shard.IndexSearcherWrapper
- wrap(ActionListener<Response>) - Method in class org.elasticsearch.action.support.ThreadedActionListener.Wrapper
- wrap(BackoffPolicy, Runnable) - Static method in class org.elasticsearch.action.bulk.BackoffPolicy
-
Wraps the backoff policy in one that calls a method every time a new backoff is taken from the policy.
- wrap(CheckedConsumer<Response, ? extends Exception>, Consumer<Exception>) - Static method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that listens for a response (or failure) and executes the corresponding consumer when the response (or failure) is received.
- wrap(Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
- wrap(Engine.Searcher) - Method in class org.elasticsearch.index.shard.IndexSearcherWrapper
-
If there are configured
IndexSearcherWrapper
instances, theIndexSearcher
of the provided engine searcher gets wrapped and a newEngine.Searcher
instances is returned, otherwise the providedEngine.Searcher
is returned. - wrap(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Wrap the provided aggregator so that it behaves (almost) as if it had been collected directly.
- wrap(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
Wrap the provided aggregator so that it behaves (almost) as if it had been collected directly.
- wrap(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.MergingBucketsDeferringCollector
-
Wrap the provided aggregator so that it behaves (almost) as if it had been collected directly.
- wrap(BucketCollector...) - Static method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- wrapAllDocsLive(DirectoryReader) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Wraps a directory reader to make all documents live except those were rolled back or hard-deleted due to non-aborting exceptions during indexing.
- wrapAsCancellable(Future<?>) - Static method in interface org.elasticsearch.threadpool.Scheduler
-
Utility method to wrap a
Future
as aCancellable
- wrapAsScheduledCancellable(ScheduledFuture<?>) - Static method in interface org.elasticsearch.threadpool.Scheduler
-
Utility method to wrap a
ScheduledFuture
as aScheduledCancellable
- wrapBulkResponse(ActionListener<Response>) - Static method in class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- wrapdateline - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
We're expecting some geometries might cross the dateline.
- wrapLongitude() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
-
Get whether to wrap longitudes.
- wrapLongitude(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregationBuilder
-
Set whether to wrap longitudes.
- WrappedRunnable - Interface in org.elasticsearch.common.util.concurrent
- Wrapper(Logger, Settings, ThreadPool) - Constructor for class org.elasticsearch.action.support.ThreadedActionListener.Wrapper
- wrapperQuery(byte[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query builder which allows building a query thanks to a JSON string or binary data.
- wrapperQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query builder which allows building a query thanks to a JSON string or binary data.
- wrapperQuery(BytesReference) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query builder which allows building a query thanks to a JSON string or binary data.
- WrapperQueryBuilder - Class in org.elasticsearch.index.query
-
A Query builder which allows building a query given JSON string or binary data provided as input.
- WrapperQueryBuilder(byte[]) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
-
Creates a query builder given a query provided as a bytes array
- WrapperQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
-
Creates a query builder given a query provided as a string
- WrapperQueryBuilder(BytesReference) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
-
Creates a query builder given a query provided as a
BytesReference
- WrapperQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
-
Read from a stream.
- wrapPreservingContext(ActionListener<R>, ThreadContext) - Static method in class org.elasticsearch.action.support.ContextPreservingActionListener
-
Wraps the provided action listener in a
ContextPreservingActionListener
that will also copy the response headers when theThreadContext.StoredContext
is closed - wrapReader(DirectoryReader, Function<DirectoryReader, DirectoryReader>) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- wrapRequest(DiscoveryNode, TransportRequest) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Wraps the actual request in a proxy request object that encodes the target node.
- wrapRestorable(ThreadContext.StoredContext) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Same as
ThreadContext.newRestorableContext(boolean)
but wraps an existing context to restore. - wrapRunnable(Runnable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- wrapRunnable(Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- wrapRunnable(Runnable) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- wrapWithTimeout(ThreadPool, ActionListener<Response>, TimeValue, String, String) - Static method in class org.elasticsearch.action.support.ListenerTimeouts
-
Wraps a listener with a listener that can timeout.
- write(byte[]) - Method in class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- write(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- write(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- write(char) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes a single character.
- write(char[], int, int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes a portion of an array of characters.
- write(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- write(int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes a character given its 31-bits Unicode.
- write(int) - Method in class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- write(CharSequence) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes the specified character sequence.
- write(String, int, int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes a portion of a string.
- write(List<Tuple<Item, Consumer<Exception>>>) - Method in class org.elasticsearch.common.util.concurrent.AsyncIOProcessor
-
Writes or processes the items out or to disk.
- write(Set<String>, StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.StringSetValueSerializer
- write(StreamOutput, V) - Method in interface org.elasticsearch.common.io.stream.Writeable.Writer
-
Write
V
-typevalue
to theout
put stream. - write(Rounding, StreamOutput) - Static method in class org.elasticsearch.common.rounding.Rounding.Streams
- write(TDigestState, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
- write(T) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- write(T, Path...) - Method in class org.elasticsearch.gateway.MetaDataStateFormat
-
Writes the given state to the given directories.
- write(T, BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
Writes blob with resolving the blob name using
BlobStoreFormat.blobName(java.lang.String)
method. - write(T, StreamOutput) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- write(V, StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueSerializer
- write(V, StreamOutput) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Writes value to stream
- WRITE - org.elasticsearch.cluster.block.ClusterBlockLevel
- WRITE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- WRITE_PORTS_FILE_SETTING - Static variable in class org.elasticsearch.node.Node
- Writeable - Interface in org.elasticsearch.common.io.stream
-
Implementers can be written to a StreamOutput and read from a StreamInput.
- Writeable.Reader<V> - Interface in org.elasticsearch.common.io.stream
-
Reference to a method that can read some object from a stream.
- Writeable.Writer<V> - Interface in org.elasticsearch.common.io.stream
-
Reference to a method that can write some object to a
StreamOutput
. - writeAdditionalFields(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- writeAdditionalFields(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- writeAdditionalFields(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RecoverySource
-
to be overridden by subclasses
- writeArray(Writeable.Writer<T>, T[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes the specified array to the stream using the specified
Writeable.Writer
for each element in the array. - writeArray(T[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes the specified array of
Writeable
s. - writeAtomic(T, BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
Writes blob in atomic manner with resolving the blob name using
BlobStoreFormat.blobName(java.lang.String)
method. - writeBlob(String, InputStream, long, boolean) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Reads blob content from the input stream and writes it to the container in a new blob with the given name.
- writeBlob(String, InputStream, long, boolean) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- writeBlobAtomic(String, InputStream, long, boolean) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Reads blob content from the input stream and writes it to the container in a new blob with the given name, using an atomic write operation if the implementation supports it.
- writeBlobAtomic(String, InputStream, long, boolean) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- writeBoolean(boolean) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a boolean.
- writeBuild(Build, StreamOutput) - Static method in class org.elasticsearch.Build
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a single byte.
- writeByte(byte) - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- writeByte(byte) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- writeByteArray(byte[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an array of bytes.
- writeBytes(byte[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an array of bytes.
- writeBytes(byte[], int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an array of bytes.
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an array of bytes.
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- writeBytesRef(BytesRef) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeBytesReference(BytesReference) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes the bytes reference, including a length header.
- writeCollection(Collection<? extends Writeable>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a collection to this stream.
- writeCollection(Collection<T>, Writeable.Writer<T>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a collection of objects via a
Writeable.Writer
. - writeCoordinateTo(Coordinate, StreamOutput) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- writeDiff(Diff<V>, StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueSerializer
- writeDiff(Diff<V>, StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- writeDiff(Diff<V>, StreamOutput) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Writes value as diff to stream if this serializer supports diffable values
- writeDocumentRequest(StreamOutput, DocWriteRequest) - Static method in interface org.elasticsearch.action.DocWriteRequest
-
write a document write (index/delete/update) request
- writeDouble(double) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeDoubleArray(double[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeDoubleLE(double, byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Write a double in little-endian format.
- writeEnum(E) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an enum with type E that by serialized it based on it's ordinal value
- writeEnumSet(EnumSet<E>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an EnumSet with type E that by serialized it based on it's ordinal value
- writeException(Throwable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeExplanation(StreamOutput, Explanation) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeFieldDoc(StreamOutput, FieldDoc) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeFieldStats(StreamOutput, ObjectObjectHashMap<String, CollectionStatistics>) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- writeFileChunk(StoreFileMetaData, long, BytesReference, boolean) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
- writeFileChunk(StoreFileMetaData, long, BytesReference, boolean, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- writeFileChunk(StoreFileMetaData, long, BytesReference, boolean, int, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
writes a partial file chunk to the target store
- writeFileChunk(StoreFileMetaData, long, BytesReference, boolean, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- writeFloat(float) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeFloatArray(float[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeFloatLE(float, byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Write a float in little-endian format.
- writeGenericValue(Object) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Notice: when serialization a map, the stream out map with the stream in map maybe have the different key-value orders, they will maybe have different stream order.
- writeGeoPoint(GeoPoint) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes the given
GeoPoint
to the stream - writeHeader(StreamOutput, long, byte, Version, int) - Static method in class org.elasticsearch.transport.TcpHeader
- writeHistogramOrder(BucketOrder, StreamOutput, boolean) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Streams
-
ONLY FOR HISTOGRAM ORDER: Backwards compatibility logic to write a
BucketOrder
to a stream. - writeIndex() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- writeIndex() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- writeIndex() - Method in class org.elasticsearch.cluster.metadata.AliasAction.Add
- writeIndex() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- writeIndex(Boolean) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Sets whether an alias is pointing to a write-index
- writeIndex(Boolean) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- writeIndex(Boolean) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- writeIndex(String, IndexMetaData) - Method in class org.elasticsearch.gateway.MetaStateService
-
Writes the index state.
- writeIndexGen(RepositoryData, long) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- writeIndexingBuffer() - Method in class org.elasticsearch.index.engine.Engine
-
Called when our engine is using too much heap and should move buffered indexed/deleted documents to disk.
- writeIndexingBuffer() - Method in class org.elasticsearch.index.engine.InternalEngine
- writeIndexingBuffer() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- writeIndexingBuffer() - Method in class org.elasticsearch.index.shard.IndexShard
-
Called when our shard is using too much heap and should move buffered indexed/deleted documents to disk.
- writeIndexingBufferAsync(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
ask this shard to refresh, in the background, to free up heap
- writeIndicesOptions(StreamOutput) - Method in class org.elasticsearch.action.support.IndicesOptions
- writeInstant(Instant) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an
Instant
to the stream with nanosecond resolution - writeInt(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an int as four bytes.
- writeIntArray(int[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeIntLE(int, byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Write an int in little-endian format.
- writeKey(K, StreamOutput) - Method in interface org.elasticsearch.cluster.DiffableUtils.KeySerializer
- writeKilobytes() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- writeList(List<? extends Writeable>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a list of
Writeable
objects - writeLock - Variable in class org.elasticsearch.index.engine.Engine
- writeLock - Variable in class org.elasticsearch.index.translog.Translog
- writeLong(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a long as eight bytes.
- writeLongArray(long[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeLongLE(long, byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Write a long in little-endian format.
- writeMap(Map<String, Object>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeMap(Map<K, V>, Writeable.Writer<K>, Writeable.Writer<V>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write a
Map
ofK
-type keys toV
-type. - writeMapOfLists(Map<K, List<V>>, Writeable.Writer<K>, Writeable.Writer<V>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write a
Map
ofK
-type keys toV
-typeList
s. - writeMapWithConsistentOrder(Map<String, ? extends Object>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
write map to stream with consistent order to make sure every map generated bytes order are same.
- writeMultiLineFormat(MultiSearchRequest, XContent) - Static method in class org.elasticsearch.action.search.MultiSearchRequest
- writeNamedWriteable(NamedWriteable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a
NamedWriteable
to the current stream, by first writing its name and then the object itself - writeNamedWriteableList(List<? extends NamedWriteable>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a list of
NamedWriteable
objects. - writeNodesTo(StreamOutput, List<NodeHotThreads>) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
- writeNodesTo(StreamOutput, List<NodeInfo>) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- writeNodesTo(StreamOutput, List<NodesReloadSecureSettingsResponse.NodeResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- writeNodesTo(StreamOutput, List<NodeStats>) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- writeNodesTo(StreamOutput, List<NodeUsage>) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- writeNodesTo(StreamOutput, List<TransportNodesSnapshotsStatus.NodeSnapshotStatus>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
- writeNodesTo(StreamOutput, List<ClusterStatsNodeResponse>) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- writeNodesTo(StreamOutput, List<TransportNodesListGatewayMetaState.NodeGatewayMetaState>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodesGatewayMetaState
- writeNodesTo(StreamOutput, List<TransportNodesListGatewayStartedShards.NodeGatewayStartedShards>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodesGatewayStartedShards
- writeNodesTo(StreamOutput, List<TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData>) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
- writeNodesTo(StreamOutput, List<TNodeResponse>) - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Write the
BaseNodesResponse.nodes
to the stream. - writeOperation(StreamOutput, Translog.Operation) - Static method in interface org.elasticsearch.index.translog.Translog.Operation
-
Writes the type and translog operation to the given stream
- writeOperationNoSize(BufferedChecksumStreamOutput, Translog.Operation) - Static method in class org.elasticsearch.index.translog.Translog
- writeOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- writeOperations(StreamOutput, List<Translog.Operation>) - Static method in class org.elasticsearch.index.translog.Translog
-
Writes all operations in the given iterable to the given output stream including the size of the array use
Translog.readOperations(StreamInput, String)
to read it back. - writeOptionalArray(Writeable.Writer<T>, T[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Same as
StreamOutput.writeArray(Writer, Object[])
but the provided array may be null. - writeOptionalArray(T[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Same as
StreamOutput.writeArray(Writeable[])
but the provided array may be null. - writeOptionalBoolean(Boolean) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalBytesReference(BytesReference) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an optional bytes reference including a length header.
- writeOptionalDouble(Double) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalFloat(Float) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalInstant(Instant) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an
Instant
to the stream, which could possibly be null - writeOptionalLong(Long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalNamedWriteable(NamedWriteable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write an optional
NamedWriteable
to the stream. - writeOptionalStreamable(Streamable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Serializes a potential null value.
- writeOptionalString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalStringArray(String[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a string array, for nullable string, writes false.
- writeOptionalText(Text) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalTimeValue(TimeValue) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write an optional
TimeValue
to the stream. - writeOptionalTimeZone(DateTimeZone) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write an optional DateTimeZone to the stream.
- writeOptionalVInt(Integer) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalWriteable(Writeable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOrder(BucketOrder, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Streams
-
Write a
BucketOrder
to aStreamOutput
. - writeOriginalIndices(OriginalIndices, StreamOutput) - Static method in class org.elasticsearch.action.OriginalIndices
- writeOtherStatsTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
- writeOtherStatsTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
- WritePrimaryResult(ReplicaRequest, Response, Translog.Location, Exception, IndexShard, Logger) - Constructor for class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- writeRawField(String, BytesReference, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.use
XContentHelper.writeRawField(String, BytesReference, XContentType, XContentBuilder, Params)
to avoid content type auto-detection - writeRawField(String, BytesReference, XContentType, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Writes a "raw" (bytes) field, handling cases where the bytes are compressed, and tries to optimize writing using
XContentBuilder.rawField(String, InputStream, XContentType)
. - WriteReplicaResult(ReplicaRequest, Translog.Location, Exception, IndexShard, Logger) - Constructor for class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
- WriteRequest<R extends WriteRequest<R>> - Interface in org.elasticsearch.action.support
-
Interface implemented by requests that modify the documents in an index like
IndexRequest
,UpdateRequest
, andBulkRequest
. - WriteRequest.RefreshPolicy - Enum in org.elasticsearch.action.support
- WriteRequestBuilder<B extends WriteRequestBuilder<B>> - Interface in org.elasticsearch.action.support
- WriteResponse - Interface in org.elasticsearch.action.support
-
Interface implemented by responses for actions that modify the documents in an index like
IndexResponse
,UpdateResponse
, andBulkResponse
. - writerSegmentStats(SegmentsStats) - Method in class org.elasticsearch.index.engine.Engine
- writerSegmentStats(SegmentsStats) - Method in class org.elasticsearch.index.engine.InternalEngine
- writeScoreDoc(StreamOutput, ScoreDoc) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeSearchRequestParams(SearchRequest, XContentBuilder) - Static method in class org.elasticsearch.action.search.MultiSearchRequest
- writeSettingsToStream(Settings, StreamOutput) - Static method in class org.elasticsearch.common.settings.Settings
- writeShardsAcknowledged(StreamOutput) - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- writeShort(short) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeSingleTermStats(StreamOutput, TermStatistics) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- writeSize(int, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Write a size under the assumption that a value of 0 means unlimited.
- writeSortField(StreamOutput, SortField) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeSortType(StreamOutput, SortField.Type) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeSortValue(StreamOutput, Object) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeStackTraces(T, StreamOutput) - Static method in exception org.elasticsearch.ElasticsearchException
-
Serializes the given exceptions stacktrace elements as well as it's suppressed exceptions to the given output stream.
- writeStreamableList(List<? extends Streamable>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a list of
Streamable
objects - writeString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeStringArray(String[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeStringArrayNullable(String[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a string array, for nullable string, writes it as 0 (empty string).
- writeStringCollection(Collection<String>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a collection of a strings.
- writeTermStats(StreamOutput, TermStatistics[]) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- writeText(Text) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeThin(StreamOutput) - Method in class org.elasticsearch.transport.BytesTransportRequest
-
Writes the data in a "thin" manner, without the actual bytes, assumes the actual bytes will be appended right after this content.
- writeTimeValue(TimeValue) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write a
TimeValue
to the stream - writeTimeZone(DateTimeZone) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write a DateTimeZone to the stream.
- writeTo(long, StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
- writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.BytesReference
-
Writes the bytes directly to the output stream.
- writeTo(AllocationCommands, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Writes
AllocationCommands
to aStreamOutput
- writeTo(RerouteExplanation, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- writeTo(RoutingExplanations, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
-
Write the RoutingExplanations object
- writeTo(IndexShardRoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ActionRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ActionResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction.NodeStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction.NodeUsageRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction.ClusterStatsNodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest.NameOrDefinition
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.ShardUpgradeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.DeleteRequest
- writeTo(StreamOutput) - Method in enum org.elasticsearch.action.DocWriteResponse.Result
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.DocWriteResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.explain.ExplainRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.explain.ExplainResponse
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.FailedNodeException
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.GetRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.GetResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetItemResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.index.IndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.GetPipelineRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.main.MainResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.RoutingMissingException
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ClearScrollResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchResponse
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchResponseSections
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchTransportService.SearchFreeContextResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ShardSearchFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.ActiveShardCount
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.EmptyResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.MasterNodeReadRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.BaseNodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.BaseNodeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- writeTo(StreamOutput) - Method in enum org.elasticsearch.action.support.WriteRequest.RefreshPolicy
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.TaskOperationFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.TimestampParsingException
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.update.UpdateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.update.UpdateResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.StartedShardEntry
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.block.ClusterBlock
- writeTo(StreamOutput) - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterName
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterState
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.DiskUsage
- writeTo(StreamOutput) - Method in enum org.elasticsearch.cluster.health.ClusterHealthStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.MetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Write this into the StreamOutput.
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
-
Writes repository metadata to stream output
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Writes restore status to stream output
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.RestoreInProgress
-
Write this into the StreamOutput.
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- writeTo(StreamOutput) - Method in enum org.elasticsearch.cluster.routing.allocation.AllocationDecision
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- writeTo(StreamOutput) - Method in enum org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.AllocationId
- writeTo(StreamOutput) - Method in exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RecoverySource
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.ShardRouting
- writeTo(StreamOutput) - Method in enum org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- writeTo(StreamOutput) - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.compress.CompressedXContent
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.document.DocumentField
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.FieldMemoryStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.geo.GeoDistance
-
Writes an instance of a GeoDistance object to an output stream
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.geo.ShapeRelation
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.geo.SpatialStrategy
- writeTo(StreamOutput) - Method in exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- writeTo(StreamOutput) - Method in interface org.elasticsearch.common.io.stream.Streamable
-
Write this object's fields to a StreamOutput.
- writeTo(StreamOutput) - Method in interface org.elasticsearch.common.io.stream.Writeable
-
Write this into the StreamOutput.
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- writeTo(StreamOutput) - Method in exception org.elasticsearch.common.ParsingException
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.transport.TransportAddress
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.ByteSizeValue
- writeTo(StreamOutput) - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Write a
DistanceUnit
to aStreamOutput
. - writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.Fuzziness
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.SizeValue
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
- writeTo(StreamOutput) - Method in exception org.elasticsearch.common.xcontent.UnknownNamedObjectException
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.DiscoveryStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.MembershipAction.JoinRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.MembershipAction.LeaveRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction.CommitClusterStateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.RejoinClusterRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
- writeTo(StreamOutput) - Method in exception org.elasticsearch.ElasticsearchException
- writeTo(StreamOutput) - Method in exception org.elasticsearch.ElasticsearchStatusException
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeGatewayMetaState
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.http.HttpInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.http.HttpStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.CommitStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.Engine.CommitId
- writeTo(StreamOutput) - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
-
Deprecated.
- writeTo(StreamOutput) - Method in exception org.elasticsearch.index.engine.RecoveryEngineException
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.Segment
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.SegmentsStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.flush.FlushStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.get.GetResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.get.GetStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.Index
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.merge.MergeStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- writeTo(StreamOutput) - Method in enum org.elasticsearch.index.query.GeoExecType
- writeTo(StreamOutput) - Method in enum org.elasticsearch.index.query.GeoValidationMethod
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- writeTo(StreamOutput) - Method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- writeTo(StreamOutput) - Method in enum org.elasticsearch.index.query.Operator
- writeTo(StreamOutput) - Method in exception org.elasticsearch.index.query.QueryShardException
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.refresh.RefreshStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.ReindexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.RemoteInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- writeTo(StreamOutput) - Method in enum org.elasticsearch.index.search.MatchQuery.Type
- writeTo(StreamOutput) - Method in enum org.elasticsearch.index.search.MatchQuery.ZeroTermsQuery
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.search.stats.SearchStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLease
-
Writes a retention lease to a stream in a manner suitable for later reconstruction via
RetentionLease(StreamInput)
. - writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
Writes a retention lease collection to a stream in a manner suitable for later reconstruction via
RetentionLeases(StreamInput)
(StreamInput)}. - writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
-
Writes a retention lease stats object to a stream in a manner suitable for later reconstruction via
RetentionLeaseStats(StreamInput)
(StreamInput)}. - writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.SeqNoStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.DocsStats
- writeTo(StreamOutput) - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.IndexingStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.ShardId
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.StoreFileMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.StoreStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.translog.TranslogStats
- writeTo(StreamOutput) - Method in enum org.elasticsearch.index.VersionType
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.warmer.WarmerStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- writeTo(StreamOutput) - Method in exception org.elasticsearch.indices.IndexTemplateMissingException
- writeTo(StreamOutput) - Method in exception org.elasticsearch.indices.InvalidIndexTemplateException
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.NodeIndicesStats
- writeTo(StreamOutput) - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryFinalizeRecoveryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryWaitForClusterStateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.TermsLookup
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.IngestInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.IngestMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.IngestStats.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.IngestStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.PipelineConfiguration
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.ProcessorInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.node.AdaptiveSelectionStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.PersistentTaskResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.PersistentTask
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.plugins.PluginInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.IndexId
- writeTo(StreamOutput) - Method in exception org.elasticsearch.repositories.RepositoryException
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.VerificationFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction.VerifyNodeRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.Script
- writeTo(StreamOutput) - Method in exception org.elasticsearch.script.ScriptException
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptMetaData
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptStats
- writeTo(StreamOutput) - Method in enum org.elasticsearch.script.ScriptType
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.StoredScriptSource
-
Writes a
StoredScriptSource
to a stream. - writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ExtendedBounds
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder.Range
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.BucketOrder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
- writeTo(StreamOutput) - Method in exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Serialize the GapPolicy to the output stream
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.SeasonalityType
-
Serialize the SeasonalityType to the output stream
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Write the model to the output stream
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.aggregations.support.ValuesSourceType
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.aggregations.support.ValueType
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.dfs.AggregatedDfs
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.DocValueFieldsContext.FieldAndFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
write common parameters to
StreamOutput
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.AliasFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.MultiValueMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.ProfileResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.ProfileShardResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.query.CollectorResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.SearchProfileShardResults
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.rescore.QueryRescoreMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.Scroll
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- writeTo(StreamOutput) - Method in exception org.elasticsearch.search.SearchContextMissingException
- writeTo(StreamOutput) - Method in exception org.elasticsearch.search.SearchException
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchHit
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchHits
- writeTo(StreamOutput) - Method in exception org.elasticsearch.search.SearchParseException
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchService.CanMatchResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchShardTarget
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchSortValues
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.slice.SliceBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
-
Write this object's fields to a StreamOutput.
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.sort.SortMode
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.sort.SortOrder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.suggest.SortBy
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
- writeTo(StreamOutput) - Method in enum org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.RestoreInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.Snapshot
- writeTo(StreamOutput) - Method in exception org.elasticsearch.snapshots.SnapshotException
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotId
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.tasks.RawTaskStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.tasks.TaskId
- writeTo(StreamOutput) - Method in class org.elasticsearch.tasks.TaskInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.tasks.TaskResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolStats
- writeTo(StreamOutput) - Method in exception org.elasticsearch.transport.ActionNotFoundTransportException
- writeTo(StreamOutput) - Method in exception org.elasticsearch.transport.ActionTransportException
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.BytesTransportRequest
- writeTo(StreamOutput) - Method in exception org.elasticsearch.transport.ConnectTransportException
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportMessage
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportService.HandshakeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportStats
- writeTo(StreamOutput, RestStatus) - Static method in enum org.elasticsearch.rest.RestStatus
- writeTo(Priority, StreamOutput) - Static method in enum org.elasticsearch.common.Priority
- writeTo(CompositeValuesSourceBuilder<?>, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceParserHelper
- writeToChannel(byte[], int, int, WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
-
Writes part of a byte array to a
WritableByteChannel
- writeToChannel(byte[], WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
-
Writes part of a byte array to a
WritableByteChannel
- writeToChannel(ByteBuffer, WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
-
Writes a
ByteBuffer
to aWritableByteChannel
- writeToCollapseBWC(StreamOutput) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
BWC serialization for collapsing
InnerHitBuilder
. - writeToNestedBWC(StreamOutput, QueryBuilder, String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
BWC serialization for nested
InnerHitBuilder
. - writeToNoId(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchResult
- writeToParentChildBWC(StreamOutput, QueryBuilder, String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
BWC serialization for parent/child
InnerHitBuilder
. - writeTopDocs(StreamOutput, TopDocs) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeToThin(IndexShardRoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- writeToThin(StreamOutput) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Writes shard information to
StreamOutput
without writing index name and shard id - writeVersion(Version, StreamOutput) - Static method in class org.elasticsearch.Version
- writeVInt(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an int in a variable-length format.
- writeVIntArray(int[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeVLong(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a non-negative long in a variable-length format.
- writeVLong(ByteArrayDataOutput, long) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Same as DataOutput#writeVLong but accepts negative values (written on 9 bytes).
- writeVLongArray(long[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeZLong(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a long in a variable-length format.
- writtenBy() - Method in class org.elasticsearch.index.store.StoreFileMetaData
-
Returns the Lucene version this file has been written by or
null
if unknown
X
- X_FIELD_NAME - Static variable in class org.elasticsearch.common.unit.Fuzziness
- X_OPAQUE_ID - Static variable in class org.elasticsearch.tasks.Task
-
The request header to mark tasks with specific ids
- XAnalyzingSuggester - Class in org.apache.lucene.search.suggest.analyzing
-
Suggester that first analyzes the surface form, adds the analyzed form to a weighted FST, and then does the same thing at lookup time.
- XAnalyzingSuggester(Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Calls
#XAnalyzingSuggester(Analyzer,Analyzer,int,int,int,boolean,FST,boolean,int,int,int,int,int) AnalyzingSuggester(analyzer, analyzer, EXACT_FIRST | PRESERVE_SEP, 256, -1)
- XAnalyzingSuggester(Analyzer, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Calls
#XAnalyzingSuggester(Analyzer,Analyzer,int,int,int,boolean,FST,boolean,int,int,int,int,int) AnalyzingSuggester(indexAnalyzer, queryAnalyzer, EXACT_FIRST | PRESERVE_SEP, 256, -1)
- XAnalyzingSuggester(Analyzer, Automaton, Analyzer, int, int, int, boolean, FST<PairOutputs.Pair<Long, BytesRef>>, boolean, int, int, int, int, int) - Constructor for class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Creates a new suggester.
- XAnalyzingSuggester.XBuilder - Class in org.apache.lucene.search.suggest.analyzing
- XBuilder(int, boolean, int) - Constructor for class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
- XContentElasticsearchExtension - Class in org.elasticsearch.common.xcontent
-
SPI extensions for Elasticsearch-specific classes (like the Lucene or Joda dependency classes) that need to be encoded by
XContentBuilder
in a specific way. - XContentElasticsearchExtension() - Constructor for class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- XContentHelper - Class in org.elasticsearch.common.xcontent
- XContentHelper() - Constructor for class org.elasticsearch.common.xcontent.XContentHelper
- XContentMapValues - Class in org.elasticsearch.common.xcontent.support
- XContentMapValues() - Constructor for class org.elasticsearch.common.xcontent.support.XContentMapValues
- XContentParserUtils - Class in org.elasticsearch.common.xcontent
-
A set of static methods to get
XContentParser.Token
fromXContentParser
while checking for their types and throwParsingException
if needed. - xContentRegistry() - Method in class org.elasticsearch.index.IndexService
- xContentType - Variable in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- xContentType() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- xContentType() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- xContentType(BytesReference) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.the content type should not be guessed except for few cases where we effectively don't know the content type. The REST layer should move to reading the Content-Type header instead. There are other places where auto-detection may be needed. This method is deprecated to prevent usages of it from spreading further without specific reasons.
- XFieldComparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- XFilteredDocIdSetIterator - Class in org.apache.lucene.search
-
Abstract decorator class of a DocIdSetIterator implementation that provides on-demand filter/validation mechanism on an underlying DocIdSetIterator.
- XFilteredDocIdSetIterator(DocIdSetIterator) - Constructor for class org.apache.lucene.search.XFilteredDocIdSetIterator
-
Constructor.
- XFuzzySuggester - Class in org.apache.lucene.search.suggest.analyzing
-
Implements a fuzzy
AnalyzingSuggester
. - XFuzzySuggester(Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
-
Creates a
FuzzySuggester
instance initialized with default values. - XFuzzySuggester(Analyzer, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
-
Creates a
FuzzySuggester
instance with an index & a query analyzer initialized with default values. - XFuzzySuggester(Analyzer, Automaton, Analyzer, int, int, int, int, boolean, int, int, boolean, FST<PairOutputs.Pair<Long, BytesRef>>, boolean, int, int, int, int, int) - Constructor for class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
-
Creates a
FuzzySuggester
instance. - XMoreLikeThis - Class in org.elasticsearch.common.lucene.search
-
Generate "more like this" similarity queries.
- XMoreLikeThis(IndexReader) - Constructor for class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Constructor requiring an IndexReader.
- XMoreLikeThis(IndexReader, TFIDFSimilarity) - Constructor for class org.elasticsearch.common.lucene.search.XMoreLikeThis
- XQueryParser - Class in org.apache.lucene.queryparser.classic
-
This class is just a workaround to make
QueryParserBase.handleBareFuzzy(String, Token, String)
accessible by sub-classes. - XQueryParser(String, Analyzer) - Constructor for class org.apache.lucene.queryparser.classic.XQueryParser
- XRejectedExecutionHandler - Interface in org.elasticsearch.common.util.concurrent
- XShapeCollection<S extends org.locationtech.spatial4j.shape.Shape> - Class in org.elasticsearch.common.geo
-
Extends spatial4j ShapeCollection for points_only shape indexing support
- XShapeCollection(List<S>, SpatialContext) - Constructor for class org.elasticsearch.common.geo.XShapeCollection
Y
- YARD - org.elasticsearch.common.unit.DistanceUnit
- year() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit year.
- YEAR - org.elasticsearch.common.time.FormatNames
- YEAR - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- YEAR_MONTH - org.elasticsearch.common.time.FormatNames
- YEAR_MONTH_DAY - org.elasticsearch.common.time.FormatNames
- YEAR_OF_CENTURY - org.elasticsearch.common.rounding.DateTimeUnit
- yearMonth() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit year and two digit month of year.
- yearMonthDay() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit year, two digit month of year, and two digit day of month.
- YELLOW - org.elasticsearch.cluster.health.ClusterHealthStatus
- yes(DiscoveryNode, String, List<NodeAllocationResult>, boolean) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Creates a YES decision with the given individual node-level decisions that comprised the final YES decision, along with the node id to which the shard is assigned and the allocation id for the shard, if available.
- YES - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The shard can be allocated to a node.
- YES - org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- YES - org.elasticsearch.persistent.decider.AssignmentDecision.Type
- YES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- YES - Static variable in class org.elasticsearch.persistent.decider.AssignmentDecision
- YOUNG - Static variable in class org.elasticsearch.monitor.jvm.GcNames
Z
- ZenDiscovery - Class in org.elasticsearch.discovery.zen
- ZenDiscovery(Settings, ThreadPool, TransportService, NamedWriteableRegistry, MasterService, ClusterApplier, ClusterSettings, UnicastHostsProvider, AllocationService, Collection<BiConsumer<DiscoveryNode, ClusterState>>) - Constructor for class org.elasticsearch.discovery.zen.ZenDiscovery
- ZenDiscovery.NodeRemovalClusterStateTaskExecutor - Class in org.elasticsearch.discovery.zen
- ZenDiscovery.NodeRemovalClusterStateTaskExecutor.Task - Class in org.elasticsearch.discovery.zen
- ZenDiscovery.RejoinClusterRequest - Class in org.elasticsearch.discovery.zen
- zenPing - Variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- ZenPing - Interface in org.elasticsearch.discovery.zen
- ZenPing.PingCollection - Class in org.elasticsearch.discovery.zen
-
a utility collection of pings where only the most recent ping is stored per node
- ZenPing.PingResponse - Class in org.elasticsearch.discovery.zen
- ZERO - Static variable in class org.elasticsearch.common.unit.ByteSizeValue
- ZERO - Static variable in class org.elasticsearch.common.unit.Fuzziness
- ZERO_TERMS_QUERY_FIELD - Static variable in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- ZERO_TERMS_QUERY_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- ZERO_ZERO - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
coordinate at [0.0, 0.0]
- zeroTermsQuery - Variable in class org.elasticsearch.index.search.MatchQuery
- zeroTermsQuery() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- zeroTermsQuery() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Returns the setting for handling zero terms queries.
- zeroTermsQuery() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- zeroTermsQuery() - Method in class org.elasticsearch.index.search.MatchQuery
- zeroTermsQuery(MatchQuery.ZeroTermsQuery) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Sets query to use in case no query terms are available, e.g.
- zeroTermsQuery(MatchQuery.ZeroTermsQuery) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets query to use in case no query terms are available, e.g.
- zeroTermsQuery(MatchQuery.ZeroTermsQuery) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- zigZagDecode(long) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Zig-zag decode.
- zigZagEncode(long) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Zig-zag encode: this helps transforming small signed numbers into small positive numbers.
- ZIP - org.elasticsearch.Build.Type
- zone() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- zone() - Method in interface org.elasticsearch.common.time.DateFormatter
-
Returns the configured time zone of the date formatter
- zoneIdToDateTimeZone(ZoneId) - Static method in class org.elasticsearch.common.time.DateUtils
_
- _ID - Static variable in class org.elasticsearch.index.get.GetResult
- _ID_PARSE_FIELD - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- _INDEX - Static variable in class org.elasticsearch.index.get.GetResult
- _innerIter - Variable in class org.apache.lucene.search.XFilteredDocIdSetIterator
- _NONE_ - Static variable in class org.elasticsearch.search.fetch.StoredFieldsContext
- _SHARDS_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- _SOURCE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- _TYPE - Static variable in class org.elasticsearch.index.get.GetResult
All Classes All Packages