- abort() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Marks snapshot as aborted
- aborted() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns true if snapshot process was aborted
- abs(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- abs(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- abs(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- abs(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- AbstractAckedClusterStateTaskListener - Class in org.elasticsearch.cluster
-
- AbstractAckedClusterStateTaskListener() - Constructor for class org.elasticsearch.cluster.AbstractAckedClusterStateTaskListener
-
- AbstractAggregationBuilder - Class in org.elasticsearch.search.aggregations
-
Base structure for aggregation builders.
- AbstractAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Sole constructor, typically used by sub-classes.
- 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() - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractAtomicOrdinalsFieldData
-
- 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
-
- AbstractBlobContainer(BlobPath) - Constructor for class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
-
- AbstractCatAction - Class in org.elasticsearch.rest.action.cat
-
- AbstractCatAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.AbstractCatAction
-
- AbstractCharFilterFactory - Class in org.elasticsearch.index.analysis
-
- AbstractCharFilterFactory(Index, Settings, String) - Constructor for class org.elasticsearch.index.analysis.AbstractCharFilterFactory
-
- AbstractClient - Class in org.elasticsearch.client.support
-
- AbstractClient(Settings, ThreadPool, Headers) - Constructor for class org.elasticsearch.client.support.AbstractClient
-
- AbstractClusterStateTaskListener - Class in org.elasticsearch.cluster
-
- AbstractClusterStateTaskListener() - Constructor for class org.elasticsearch.cluster.AbstractClusterStateTaskListener
-
- AbstractComponent - Class in org.elasticsearch.common.component
-
- AbstractComponent(Settings) - Constructor for class org.elasticsearch.common.component.AbstractComponent
-
- AbstractComponent(Settings, Class) - Constructor for class org.elasticsearch.common.component.AbstractComponent
-
- AbstractCompoundWordTokenFilterFactory - Class in org.elasticsearch.index.analysis.compound
-
Contains the common configuration settings between subclasses of this class.
- AbstractCompoundWordTokenFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.compound.AbstractCompoundWordTokenFilterFactory
-
- 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.DecayFunctionParser.AbstractDistanceScoreFunction
-
- AbstractDoubleSearchScript - Class in org.elasticsearch.script
-
- AbstractDoubleSearchScript() - Constructor for class org.elasticsearch.script.AbstractDoubleSearchScript
-
- AbstractESLogger - Class in org.elasticsearch.common.logging.support
-
- AbstractESLogger(String) - Constructor for class org.elasticsearch.common.logging.support.AbstractESLogger
-
- AbstractExecutableScript - Class in org.elasticsearch.script
-
- AbstractExecutableScript() - Constructor for class org.elasticsearch.script.AbstractExecutableScript
-
- AbstractFloatSearchScript - Class in org.elasticsearch.script
-
- AbstractFloatSearchScript() - Constructor for class org.elasticsearch.script.AbstractFloatSearchScript
-
- AbstractGeoPointDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- AbstractGeoPointDVIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
-
- AbstractGeoPointDVIndexFieldData.GeoPointDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
Lucene 5.4 GeoPointFieldType
- AbstractHDRPercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
-
- AbstractHDRPercentilesAggregator(String, ValuesSource.Numeric, AggregationContext, Aggregator, double[], int, boolean, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
-
- AbstractIndexAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Class in org.elasticsearch.index.analysis
-
- AbstractIndexAnalyzerProvider(Index, Settings, 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(Index, Settings) - 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(Index, Settings, MappedFieldType.Names, FieldDataType, 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(Index, Settings, MappedFieldType.Names, FieldDataType, IndexFieldDataCache, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
-
- AbstractIndexShardComponent - Class in org.elasticsearch.index.shard
-
- AbstractIndexShardComponent(ShardId, Settings) - Constructor for class org.elasticsearch.index.shard.AbstractIndexShardComponent
-
- AbstractLegacyBlobContainer - Class in org.elasticsearch.common.blobstore.support
-
Deprecated.
- AbstractLegacyBlobContainer(BlobPath) - Constructor for class org.elasticsearch.common.blobstore.support.AbstractLegacyBlobContainer
-
Deprecated.
- AbstractLifecycleComponent<T> - Class in org.elasticsearch.common.component
-
- AbstractLifecycleComponent(Settings) - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
-
- AbstractLifecycleComponent(Settings, Class) - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
-
- AbstractListenableActionFuture<T,L> - Class in org.elasticsearch.action.support
-
- AbstractListenableActionFuture(ThreadPool) - Constructor for class org.elasticsearch.action.support.AbstractListenableActionFuture
-
- AbstractLongSearchScript - Class in org.elasticsearch.script
-
- AbstractLongSearchScript() - Constructor for class org.elasticsearch.script.AbstractLongSearchScript
-
- AbstractMatcher<T> - Class in org.elasticsearch.common.inject.matcher
-
Implements and()
and or()
.
- 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
-
- AbstractPercentilesParser - Class in org.elasticsearch.search.aggregations.metrics.percentiles
-
- AbstractPercentilesParser(boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesParser
-
- AbstractRandomAccessOrds - Class in org.elasticsearch.index.fielddata
-
Base implementation of a RandomAccessOrds
instance.
- AbstractRandomAccessOrds() - Constructor for class org.elasticsearch.index.fielddata.AbstractRandomAccessOrds
-
- AbstractRangeBuilder<B extends AbstractRangeBuilder<B>> - Class in org.elasticsearch.search.aggregations.bucket.range
-
- AbstractRangeBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
-
- AbstractRangeBuilder.Range - Class in org.elasticsearch.search.aggregations.bucket.range
-
- 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
-
- 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
-
- AbstractRunnable - Class in org.elasticsearch.common.util.concurrent
-
An extension to runnable.
- AbstractRunnable() - Constructor for class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
- AbstractScriptParser<S extends Script> - Class in org.elasticsearch.script
-
- AbstractScriptParser() - Constructor for class org.elasticsearch.script.AbstractScriptParser
-
- AbstractSearchScript - Class in org.elasticsearch.script
-
A base class for any script type that is used during the search process (custom score, aggs, and so on).
- AbstractSearchScript() - Constructor for class org.elasticsearch.script.AbstractSearchScript
-
- AbstractSimilarityProvider - Class in org.elasticsearch.index.similarity
-
- AbstractSimilarityProvider(String) - Constructor for class org.elasticsearch.index.similarity.AbstractSimilarityProvider
-
Creates a new AbstractSimilarityProvider with the given name
- AbstractTDigestPercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
-
- AbstractTDigestPercentilesAggregator(String, ValuesSource.Numeric, AggregationContext, Aggregator, double[], double, boolean, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
-
- AbstractTermsParametersParser - Class in org.elasticsearch.search.aggregations.bucket.terms
-
- AbstractTermsParametersParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- AbstractTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- AbstractTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
-
- AbstractTokenizerFactory - Class in org.elasticsearch.index.analysis
-
- AbstractTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenizerFactory
-
- AbstractXContentParser - Class in org.elasticsearch.common.xcontent.support
-
- AbstractXContentParser() - Constructor for class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- accept(Throwable) - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult.FailureConsumer
-
- accept(T) - Method in interface org.elasticsearch.common.util.Consumer
-
- accept(BytesRef) - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Always accept the term.
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude.LongFilter
-
- accept(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude.StringFilter
-
- acceptedGlobalOrdinals - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
-
- acceptedGlobalOrdinals(RandomAccessOrds, ValuesSource.Bytes.WithOrdinals) - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.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(ElementVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
-
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
-
- acceptVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.Scoping
-
- acceptVisitor(ElementVisitor<T>) - Method in interface org.elasticsearch.common.inject.spi.Element
-
Accepts an element visitor.
- acceptVisitor(ElementVisitor<R>) - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
-
- 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
-
- accessed(long) - Method in class org.elasticsearch.percolator.PercolateContext
-
- accessed(long) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- 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
-
- accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
-
- accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
-
- accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
-
- accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
-
- accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
-
- accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
-
- accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
-
- accumulateExceptions() - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
- accumulateExceptions() - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
- accumulateExceptions() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
-
- accumulateExceptions() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
-
- accumulateExceptions() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
-
- accuracy() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- accuracy(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- accuracy(float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
Sets how similar the suggested terms at least need to be compared to
the original suggest text tokens.
- 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() - Method in class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Response
-
- acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutResponse
-
- acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveResponse
-
- AcknowledgedRequest<T extends MasterNodeRequest<T>> - 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(ActionRequest) - 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
-
Abstract class that allows to mark action responses that support acknowledgements.
- AcknowledgedResponse() - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
-
- AcknowledgedResponse(boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
-
- AcknowledgedRestListener<T extends AcknowledgedResponse> - Class in org.elasticsearch.rest.action.support
-
- AcknowledgedRestListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.support.AcknowledgedRestListener
-
- 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(TimeValue) - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Sets the acknowledgement timeout
- 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
- acos(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- acos(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- acos(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- acos(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- acos(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- acquire(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
- acquire() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
-
- acquireFSLockForPaths(Settings, Path...) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Acquires, then releases, all write.lock
files in the given
shard paths.
- acquireSearcher(String) - Method in class org.elasticsearch.index.engine.Engine
-
Returns a new searcher instance.
- acquireSearcher(String, boolean) - Method in class org.elasticsearch.index.engine.Engine
-
- acquireSearcher(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
- acquireThrottle() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
- 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 - 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.DelegatingTransportChannel
-
- action() - Method in class org.elasticsearch.transport.local.LocalTransportChannel
-
- action() - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
-
- action() - Method in interface org.elasticsearch.transport.TransportChannel
-
- 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.ping.unicast.UnicastZenPing
-
- ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
-
- 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.indices.store.TransportNodesListShardStoreMetaData
-
- ACTION_NAME - Static variable in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
-
- 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 - 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
-
- 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
-
- actionGet(String) - Method in interface org.elasticsearch.action.ActionFuture
-
- actionGet(long) - Method in interface org.elasticsearch.action.ActionFuture
-
- actionGet(long, TimeUnit) - Method in interface org.elasticsearch.action.ActionFuture
-
- actionGet(TimeValue) - Method in interface org.elasticsearch.action.ActionFuture
-
- actionGet() - Method in class org.elasticsearch.action.support.AdapterActionFuture
-
- actionGet(String) - Method in class org.elasticsearch.action.support.AdapterActionFuture
-
- actionGet(long) - Method in class org.elasticsearch.action.support.AdapterActionFuture
-
- actionGet(TimeValue) - Method in class org.elasticsearch.action.support.AdapterActionFuture
-
- actionGet(long, TimeUnit) - Method in class org.elasticsearch.action.support.AdapterActionFuture
-
- 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<Response>) - Constructor for class org.elasticsearch.action.ActionListenerResponseHandler
-
- ActionModule - Class in org.elasticsearch.action
-
- ActionModule(boolean) - 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(StreamInput) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
-
- ActionNotFoundTransportException(String) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
-
- ActionRequest<T extends ActionRequest> - Class in org.elasticsearch.action
-
- ActionRequest() - Constructor for class org.elasticsearch.action.ActionRequest
-
- ActionRequest(ActionRequest) - 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
-
- ActionRunnable<Response> - Class in org.elasticsearch.action
-
- 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(AliasAction[]) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
-
Sets the alias actions to be executed
- Actions() - Constructor for class org.elasticsearch.indices.recovery.RecoverySource.Actions
-
- Actions() - Constructor for class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
-
- ActionTransportException - Exception in org.elasticsearch.transport
-
An action invocation failure.
- ActionTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ActionTransportException
-
- ActionTransportException(String, TransportAddress, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
-
- ActionTransportException(String, TransportAddress, String, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
-
- actionType() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- actionType() - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- ActionWriteResponse - Class in org.elasticsearch.action
-
Base class for write action responses.
- ActionWriteResponse() - Constructor for class org.elasticsearch.action.ActionWriteResponse
-
- ActionWriteResponse.ShardInfo - Class in org.elasticsearch.action
-
- ActionWriteResponse.ShardInfo.Failure - Class in org.elasticsearch.action
-
- activate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
Activate throttling, which switches the lock to be a real lock
- activateOptions() - Method in class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
Prepares the appender for use.
- activateThrottling() - Method in class org.elasticsearch.index.engine.InternalEngine
-
- active() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
- active() - Method in class org.elasticsearch.index.mapper.internal.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.
- 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(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns the active primary shard for the given ShardRouting 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).
- activeReplica(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns one active replica shard for the given ShardRouting shard ID or null
if
no active replica is found.
- activeShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of active shards
- activityTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- actualSizeToRead() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
-
- Adapter() - Constructor for class org.elasticsearch.transport.TransportService.Adapter
-
- AdapterActionFuture<T,L> - Class in org.elasticsearch.action.support
-
- AdapterActionFuture() - Constructor for class org.elasticsearch.action.support.AdapterActionFuture
-
- 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(CommonStats) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
- add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
- add(ActionRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds either a delete or an index request.
- add(ActionRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
- add(BytesReference, String, String) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
- add(BytesReference, String, String, Object) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
- add(ActionRequest...) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(ActionRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- add(ActionRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Add a request to the current BulkRequest.
- add(Iterable<ActionRequest>) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- add(IndexRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- add(UpdateRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- add(DeleteRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- add(byte[], int, int) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(byte[], int, int, String, String) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(BytesReference, String, String) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(BytesReference, String, String, boolean) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(BytesReference, String, String, String, String[], Object, boolean) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
- add(IndexRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
- add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
- add(DeleteRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
- add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
- add(UpdateRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
- add(byte[], int, int) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds a framed data in binary format
- add(byte[], int, int, String, String) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds a framed data in binary format
- add(MultiGetRequest.Item) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- add(String, String, String) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- add(String, String, String[], FetchSourceContext, byte[], int, int) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- add(String, String, String[], FetchSourceContext, BytesReference) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- add(String, String, String[], FetchSourceContext, BytesReference, boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- add(String, String, String[], FetchSourceContext, String, BytesReference, boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- add(String, String, String) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
- add(String, String, Iterable<String>) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
- add(String, String, String...) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
- add(MultiGetRequest.Item) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
- add(int, GetResponse) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
-
- add(int, MultiGetResponse.Failure) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
-
- add(PercolateRequestBuilder) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
Embeds a percolate request to this multi percolate request
- add(PercolateRequest) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
Embeds a percolate request to this multi percolate request
- add(byte[], int, int) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
Embeds a percolate request which request body is defined as raw bytes to this multi percolate request
- add(BytesReference, boolean) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
Embeds a percolate request which request body is defined as raw bytes to this multi percolate request
- add(PercolateRequest) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequestBuilder
-
Bundles the specified percolate request to the multi percolate request.
- add(PercolateRequestBuilder) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequestBuilder
-
Bundles the specified percolate request build to the multi percolate request.
- add(TransportShardMultiPercolateAction.Request.Item) - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Request
-
- add(SearchRequestBuilder) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Add a search request to execute.
- add(SearchRequest) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Add a search request to execute.
- add(byte[], int, int, boolean, String[], String[], String) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
- add(BytesReference, boolean, String[], String[], String, IndicesOptions) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
- add(BytesReference, boolean, String[], String[], String, String, IndicesOptions, boolean) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
- 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.MultiSearchRequestBuilder
-
Add a search request to execute.
- add(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
-
- add(String, String, String) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
-
- add(TermVectorsRequest, BytesReference) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
-
- add(String, String, Iterable<String>) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
-
- add(String, String, String...) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
-
- add(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
-
- add(int, TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
-
- add(int, TermVectorsResponse) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
-
- add(int, MultiTermVectorsResponse.Failure) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
-
- add(NodeIndexDeletedAction.Listener) - Method in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
-
- add(ClusterStateListener) - Method in interface org.elasticsearch.cluster.ClusterService
-
Adds a listener for updated cluster states.
- add(LocalNodeMasterListener) - Method in interface org.elasticsearch.cluster.ClusterService
-
Add a listener for on/off local node master events
- add(TimeValue, TimeoutClusterStateListener) - Method in interface org.elasticsearch.cluster.ClusterService
-
Adds a cluster state listener that will timeout after the provided timeout,
and is executed after the clusterstate has been successfully applied ie.
- add(ShardId, AllocationExplanation.NodeExplanation) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
-
Create and add a node explanation to this explanation referencing a shard
- 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(RerouteExplanation) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
-
- add(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
- add(IndexRoutingTable) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- add(IndexRoutingTable.Builder) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- add(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- add(LocalNodeMasterListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- add(TimeValue, TimeoutClusterStateListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- add(String) - Method in class org.elasticsearch.common.blobstore.BlobPath
-
- add(String, Object) - Method in class org.elasticsearch.common.inject.internal.ToStringBuilder
-
- add(Module...) - Method in class org.elasticsearch.common.inject.ModulesBuilder
-
- 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(LeafReader) - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Register a LeafReader
.
- add(BytesRef, int) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Try to add key
.
- add(BytesRef) - Method in class org.elasticsearch.common.util.BytesRefHash
-
- add(long) - Method in class org.elasticsearch.common.util.LongHash
-
Try to add key
.
- add(QueryCacheStats) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
- add(RequestCacheStats) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
-
- add(long, long) - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- add(SegmentsStats) - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- add(FieldDataStats) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
-
- add(long, long) - Method in class org.elasticsearch.index.flush.FlushStats
-
- add(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
-
- add(GetStats) - Method in class org.elasticsearch.index.get.GetStats
-
- add(IndexingStats) - Method in class org.elasticsearch.index.indexing.IndexingStats
-
- add(IndexingStats, boolean) - Method in class org.elasticsearch.index.indexing.IndexingStats
-
- add(IndexingStats.Stats) - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- add(String) - Method in class org.elasticsearch.index.mapper.ContentPath
-
- add(byte[]) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.CustomBinaryDocValuesField
-
- add(double) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericDocValuesField
-
- add(float) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericDocValuesField
-
- add(long) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomLongNumericDocValuesField
-
- add(String) - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
-
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
-
- add(double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy.CustomGeoPointDocValuesField
-
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
-
- add(DynamicTemplate) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
-
- add(DynamicTemplate...) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
-
- add(IndexableField) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
- add(long, long, long, long, long, long, long, long, long, double) - Method in class org.elasticsearch.index.merge.MergeStats
-
- add(MergeStats) - Method in class org.elasticsearch.index.merge.MergeStats
-
- add(PercolateStats) - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- add(QueryBuilder) - Method in class org.elasticsearch.index.query.AndQueryBuilder
-
Deprecated.
Adds a filter to the list of filters to "and".
- add(QueryBuilder) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
-
Add a sub-query to this disjunction.
- add(QueryBuilder, ScoreFunctionBuilder) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Adds a score function that will will execute the function scoreFunctionBuilder on all documents matching the filter.
- add(ScoreFunctionBuilder) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Adds a score function that will will execute the function scoreFunctionBuilder on all documents.
- add(QueryBuilder) - Method in class org.elasticsearch.index.query.OrQueryBuilder
-
Deprecated.
Adds a filter to the list of filters to "or".
- add(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
-
- add(long, long) - Method in class org.elasticsearch.index.refresh.RefreshStats
-
- add(RefreshStats) - Method in class org.elasticsearch.index.refresh.RefreshStats
-
- add(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
-
- add(SearchStats, boolean) - 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(StoreFileMetaData) - Method in class org.elasticsearch.index.store.Store.LegacyChecksums
-
- add(StoreStats) - Method in class org.elasticsearch.index.store.StoreStats
-
- add(SuggestStats) - Method in class org.elasticsearch.index.suggest.stats.SuggestStats
-
- add(BytesReference) - Method in class org.elasticsearch.index.translog.BufferingTranslogWriter
-
- add(Translog.Operation) - Method in class org.elasticsearch.index.translog.Translog
-
Adds a created / delete / index operations to the transaction log.
- add(TranslogStats) - Method in class org.elasticsearch.index.translog.TranslogStats
-
- add(BytesReference) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
add the given bytes to the translog and return the location they were written at
- add(long, long, long) - Method in class org.elasticsearch.index.warmer.WarmerStats
-
- add(WarmerStats) - Method in class org.elasticsearch.index.warmer.WarmerStats
-
- add(FsInfo.Path) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
-
- add(ScriptStats) - Method in class org.elasticsearch.script.ScriptStats
-
- add(FieldDataFieldsContext.FieldDataField) - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsContext
-
- add(ScriptFieldsContext.ScriptField) - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsContext
-
- add(CompletionStats) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
-
- 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_NODE_ID_TO_CUSTOM_PATH - Static variable in class org.elasticsearch.env.NodeEnvironment
-
- addAddressType(TransportAddress) - Static method in class org.elasticsearch.common.transport.TransportAddressSerializers
-
- addAggregation(AbstractAggregationBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- addAggregation(AbstractAggregationBuilder) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
Add an aggregation definition.
- addAggregation(AbstractAggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an get to the search operation.
- addAggregator(AggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
- addAlias(String, String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
Adds an alias to the index.
- addAlias(String, Map<String, Object>, String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
Adds an alias to the index.
- addAlias(String, QueryBuilder, String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
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) - 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, 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, 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, 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
-
- addAliasAction(AliasAction) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
- addAliasAction(AliasAction) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias action to the request.
- 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
-
- addAnalyzer(String, Class<? extends AnalyzerProvider>) - Method in class org.elasticsearch.index.analysis.AnalysisModule
-
- 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, RestoreSource, IntSet) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- addAsRecovery(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- addAsRestore(IndexMetaData, RestoreSource) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- 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.
- 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
-
- addBitsetMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- addBlocks(IndexMetaData) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
-
- addCandidateGenerator(PhraseSuggestionBuilder.CandidateGenerator) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
- addCandidates(List<DirectCandidateGenerator.Candidate>) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
-
- addCategory(String, CharSequence...) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Setup a Category for suggestions.
- addCategory(String, Iterable<? extends CharSequence>) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Setup a Category for suggestions.
- addCell(Object) - Method in class org.elasticsearch.common.Table
-
- addCell(Object, String) - Method in class org.elasticsearch.common.Table
-
- addCharFilter(String, Class<? extends CharFilterFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisModule
-
- addChild(PathTrie<T>.TrieNode<T>) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
-
- addConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
-
- addContextField(String, CharSequence...) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Setup a Context Field for suggestions.
- addContextField(String, Iterable<? extends CharSequence>) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Setup a Context Field for suggestions.
- addCustom(IndexMetaData.Custom) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds custom metadata to the index to be created.
- addCustomAttributeProvider(DiscoveryNodeService.CustomAttributesProvider) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeService
-
- addCustomFields(XContentBuilder, T) - Method in class org.elasticsearch.rest.action.support.AcknowledgedRestListener
-
Adds api specific fields to the rest response
Does nothing by default but can be overridden by subclasses
- addCustomNameResolver(NetworkService.CustomNameResolver) - Method in class org.elasticsearch.common.network.NetworkService
-
Add a custom name resolver.
- addDefaultLocation(String) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
-
Set a default location that should be used, if no location is
provided by the query
- addDefaultLocation(double, double) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
-
Set a default location that should be used, if no location is
provided by the query
- addDefaultLocations(Collection<String>) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
-
Set a default location that should be used, if no location is
provided by the query
- addDefaultUnitsIfNeeded(Set<String>, Set<String>, ESLogger, Settings) - Static method in class org.elasticsearch.cluster.metadata.MetaData
-
As of 2.0 we require units for time and byte-sized settings.
- addDefaultUnitsIfNeeded(ESLogger, MetaData) - Static method in class org.elasticsearch.cluster.metadata.MetaData
-
As of 2.0 we require units for time and byte-sized settings.
- addDefaultValue(CharSequence) - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping.Builder
-
Add value to the default values of the mapping
- addDefaultValues(CharSequence...) - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping.Builder
-
Add set of default values to the mapping
- addDefaultValues(Iterable<? extends CharSequence>) - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping.Builder
-
Add set of default values to the mapping
- addDiscoveryType(String, Class<? extends Discovery>) - Method in class org.elasticsearch.discovery.DiscoveryModule
-
Adds a custom Discovery type.
- 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
-
- addDocValue(ParseContext, List<Field>, long) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- addDocValuesMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- addDynamicMappingsUpdate(Mapper) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Add a dynamic update to the root object mapper.
- addDynamicMappingsUpdate(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
-
- addedQuery(BytesRef, Query, Query) - Method in class org.elasticsearch.index.percolator.stats.ShardPercolateService
-
- addElectMasterService(String, Class<? extends ElectMasterService>) - Method in class org.elasticsearch.discovery.DiscoveryModule
-
Adds a custom zen master service type.
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.AbstractModule
-
- addError(Throwable) - Method in class org.elasticsearch.common.inject.AbstractModule
-
- addError(Message) - 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(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(Message) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message to be presented to the user at a later time.
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.PrivateModule
-
- addError(Throwable) - Method in class org.elasticsearch.common.inject.PrivateModule
-
- addError(Message) - 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 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 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.MemoryCircuitBreaker
-
Add a number of bytes, tripping the circuit breaker if the aggregated
estimates are above the limit.
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
-
- addExposureBuilder(ExposureBuilder<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
-
- addFailedEngineListener(Engine.FailedEngineListener) - Method in class org.elasticsearch.index.shard.IndexShard
-
- addFailure(String) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- 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(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a field to load and return (note, it must be stored) as part of the search request.
- addField(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a field to loaded and returned.
- addFieldDataField(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a field data based field to load and return.
- addFieldDataField(String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Adds a field data based field to load and return.
- addFieldDataField(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a field data based field to load and return.
- addFields(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds the fields to load and return as part of the search request.
- addFieldStringsFromParameter(TermVectorsRequest, String) - Static method in class org.elasticsearch.rest.action.termvectors.RestTermVectorsAction
-
- addFileDetail(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
- addFilter(String) - Method in class org.elasticsearch.common.settings.SettingsFilter
-
Adds a new simple pattern to the list of filters
- addFilterSettingParams(RestRequest) - Method in class org.elasticsearch.common.settings.SettingsFilter
-
- addFirst(ClusterStateListener) - Method in interface org.elasticsearch.cluster.ClusterService
-
Adds a priority listener for updated cluster states.
- addFirst(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- addGeoLocation(String, double, double, int...) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Setup a Geolocation for suggestions.
- addGeoLocation(String, String) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Setup a Geolocation for suggestions.
- addGeoLocationWithPrecision(String, double, double, String...) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Setup a Geolocation for suggestions.
- addGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
-
- 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.
- addHeader(String, String) - Method in class org.elasticsearch.rest.RestResponse
-
Add a custom header.
- addHighlightedField(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a field to be highlighted with default fragment size of 100 characters, and
default number of fragments of 5.
- addHighlightedField(String, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and
default number of fragments of 5.
- addHighlightedField(String, int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and
a provided (maximum) number of fragments.
- addHighlightedField(String, int, int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters),
a provided (maximum) number of fragments and an offset for the highlight.
- addHighlightedField(HighlightBuilder.Field) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a highlighted field.
- addHighlightedField(String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Adds a field to be highlighted with default fragment size of 100 characters, and
default number of fragments of 5.
- addHighlightedField(String, int) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and
default number of fragments of 5.
- addHighlightedField(String, int, int) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and
a provided (maximum) number of fragments.
- addHighlightedField(String, int, int, int) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters),
a provided (maximum) number of fragments and an offset for the highlight.
- addHighlightedField(HighlightBuilder.Field) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Adds a highlighted field.
- addHighlightedField(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a field to be highlighted with default fragment size of 100 characters, and
default number of fragments of 5.
- addHighlightedField(String, int) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and
default number of fragments of 5.
- addHighlightedField(String, int, int) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and
a provided (maximum) number of fragments.
- addHighlightedField(String, int, int, int) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters),
a provided (maximum) number of fragments and an offset for the highlight.
- addHighlightedField(HighlightBuilder.Field) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a highlighted field.
- addHostsProvider(UnicastHostsProvider) - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
-
- 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 filter.
- addIds(Collection<String>) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Adds ids to the filter.
- 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 executeed against it.
- addIndexFailure(String, String) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- 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
-
- addIndexStore(String, Class<? extends IndexStore>) - Method in class org.elasticsearch.index.store.IndexStoreModule
-
- addIndexWriterMaxMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- 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
-
- addInitialStateBlock(ClusterBlock) - Method in interface org.elasticsearch.cluster.ClusterService
-
Adds an initial block to be set on the first cluster state created.
- addInitialStateBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- addInnerHit(String, InnerHitsBuilder.InnerHit) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- addInnerHit(String, InnerHitsBuilder.InnerHit) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder
-
- addInnerHit(String, InnerHitsBuilder.InnerHit) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder.InnerHit
-
Adds a nested inner hit definition that collects inner hits for hits
on this inner hit level.
- addInnerHitDefinition(String, InnerHitsContext.BaseInnerHits) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext
-
- addInnerHitDefinitions(Map<String, InnerHitsContext.BaseInnerHits>) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext
-
- addInnerHits(String, InnerHitsContext.BaseInnerHits) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- addIntegerFields(ParseContext, List<Field>, int, float) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
-
- addItem(MoreLikeThisQueryBuilder.Item...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Deprecated.
- additionalSettings() - Method in class org.elasticsearch.plugins.Plugin
-
Additional node settings loaded by the plugin.
- addLast(ClusterStateListener) - Method in interface org.elasticsearch.cluster.ClusterService
-
Adds last listener.
- addLast(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
-
- addLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.common.component.LifecycleComponent
-
- addLikeItem(MoreLikeThisQueryBuilder.Item...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Adds a document to use in order to find documents that are "like" this.
- addLikeText(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Adds some text to use in order to find documents that are "like" this.
- 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.AbstractListenableActionFuture
-
- addListener() - Method in enum org.elasticsearch.action.ThreadingModel
-
- addListener(ClusterInfoService.Listener) - Method in interface org.elasticsearch.cluster.ClusterInfoService
-
Add a listener that will be called every time new information is gathered
- addListener(ClusterInfoService.Listener) - Method in class org.elasticsearch.cluster.EmptyClusterInfoService
-
- addListener(ClusterInfoService.Listener) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
-
- addListener(InitialStateDiscoveryListener) - Method in interface org.elasticsearch.discovery.Discovery
-
- addListener(InitialStateDiscoveryListener) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
-
- addListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
-
- addListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
-
- addListener(InitialStateDiscoveryListener) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- addListener(IndexingOperationListener) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- addListener(IndexSettingsService.Listener) - Method in class org.elasticsearch.index.settings.IndexSettingsService
-
Only settings registered in
ClusterModule
can be changed dynamically.
- addListener(IndicesLifecycle.Listener) - Method in interface org.elasticsearch.indices.IndicesLifecycle
-
Add a listener.
- addListener(IndicesWarmer.Listener) - Method in class org.elasticsearch.indices.IndicesWarmer
-
- addListener(IndicesLifecycle.Listener) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- addListener(NodeSettingsService.Listener) - Method in class org.elasticsearch.node.settings.NodeSettingsService
-
Only settings registered in
ClusterModule
can be changed dynamically.
- addListener(ActionListener<RestoreService.RestoreCompletionResponse>) - Method in class org.elasticsearch.snapshots.RestoreService
-
Adds restore completion listener
- addListener(SnapshotsService.SnapshotCompletionListener) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Adds snapshot completion listener
- addListener(Listener) - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Registers new listener
- addMapping(String, String) - 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.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.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- 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, String) - 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, 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, XContentBuilder) - 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.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMaskRange(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
- addMaskRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
Add a range based on a CIDR mask.
- addMessage(String, Object...) - Method in class org.elasticsearch.common.inject.internal.Errors
-
- addMessage(Message) - Method in class org.elasticsearch.common.inject.internal.Errors
-
- 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.QueryParseContext
-
- addNode(DiscoveryNode) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- addNodeInfo(NodeInfo) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
-
- addNodeInfoStats(NodeInfo, NodeStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
- addNodeInfoStats(NodeInfo, NodeStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
-
- addNodeStats(NodeStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
-
- 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(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
-
- addOption(O) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
-
- addPendingDelete(ShardId, Settings) - Method in class org.elasticsearch.indices.IndicesService
-
Adds a pending delete for the given index shard.
- addPendingDelete(Index, Settings) - Method in class org.elasticsearch.indices.IndicesService
-
Adds a pending delete for the given index.
- addPercolateQuery(String, BytesReference) - Method in class org.elasticsearch.index.percolator.PercolatorQueriesRegistry
-
- addPing(ZenPing.PingResponse) - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingCollection
-
adds a ping if newer than previous pings from the same node
- addPings(ZenPing.PingResponse[]) - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingCollection
-
adds multiple pings if newer than previous pings from the same node
- addPipelineAggregator(PipelineAggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
- addPlugin(PluginInfo) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
-
- addPlugin(Class<? extends Plugin>) - Method in class org.elasticsearch.client.transport.TransportClient.Builder
-
Add the given plugin to the client when it is created.
- addPoint(double, double) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Adds a point with lat and lon
- addPoint(String) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
- addPoint(GeoPoint) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
- addProcessedFile(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Increments number of processed files
- addProcessor(AnalysisModule.AnalysisBinderProcessor) - Method in class org.elasticsearch.index.analysis.AnalysisModule
-
- addProfiler() - Method in class org.elasticsearch.search.profile.Profilers
-
Switch to a new profile.
- addRange(String, Object, Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
-
Add a new range to this aggregation.
- addRange(Object, Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
-
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
Add a new range to this aggregation.
- addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
- addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
Add a new range to this aggregation.
- addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
-
Add a new range to this aggregation.
- addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
-
- addReaderCloseListener(DirectoryReader, IndexReader.ReaderClosedListener) - 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
-
- 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
- addRescore(RescoreSearchContext) - Method in class org.elasticsearch.percolator.PercolateContext
-
- addRescore(RescoreSearchContext) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- addRescore(RescoreSearchContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- addRescore(RescoreSearchContext) - Method in class org.elasticsearch.search.internal.SearchContext
-
- addRescore(RescoreSearchContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- addRescorer(RescoreBuilder.Rescorer) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a new rescorer.
- addRescorer(RescoreBuilder.Rescorer, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a new rescorer.
- addRescorer(RescoreBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
- address() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The address that the node can be communicated with.
- address() - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- 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.local.LocalTransport
-
- addressesFromString(String, int) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- 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
-
- addressFromStream(StreamInput) - Static method in class org.elasticsearch.common.transport.TransportAddressSerializers
-
- addressSupported(Class<? extends TransportAddress>) - Method in class org.elasticsearch.transport.local.LocalTransport
-
- addressSupported(Class<? extends TransportAddress>) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- addressSupported(Class<? extends TransportAddress>) - Method in interface org.elasticsearch.transport.Transport
-
Is the address type supported.
- addressSupported(Class<? extends TransportAddress>) - Method in class org.elasticsearch.transport.TransportService
-
- addressToStream(StreamOutput, TransportAddress) - Static method in class org.elasticsearch.common.transport.TransportAddressSerializers
-
- addRestAction(Class<? extends BaseRestHandler>) - Method in class org.elasticsearch.rest.RestModule
-
- addScriptEngine(Class<? extends ScriptEngineService>) - Method in class org.elasticsearch.script.ScriptModule
-
- 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.support.BaseInnerHitBuilder
-
Adds a script based field to load and return.
- addScriptField(String, Script) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a script based field to load and return.
- addScriptParam(String, Object) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequest
-
- addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
-
- addSetting(String, Validator) - Method in class org.elasticsearch.cluster.settings.DynamicSettings.Builder
-
- addShard(IndexShardRoutingTable, 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
-
- addSimilarity(String, Class<? extends SimilarityProvider>) - Method in class org.elasticsearch.index.similarity.SimilarityModule
-
- 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(SortBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- addSort(SortBuilder) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
Adds a sort builder.
- 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(String, SortOrder) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Adds a sort against the given field name and the sort ordering.
- addSort(SortBuilder) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Adds a generic sort builder.
- addSort(String, SortOrder) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a sort against the given field name and the sort ordering.
- addSort(SortBuilder) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Adds a generic sort builder.
- addSourceThrottling(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
- addStoredFieldsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- addSuggestion(SuggestBuilder.SuggestionBuilder<?>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- addSuggestion(SuggestBuilder.SuggestionBuilder<T>) - Method in class org.elasticsearch.action.suggest.SuggestRequestBuilder
-
Add a definition for suggestions to the request
- addSuggestion(SuggestBuilder.SuggestionBuilder<?>) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
- 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
-
- 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
-
- addTokenFilter(String, Class<? extends TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisModule
-
- addTokenizer(String, Class<? extends TokenizerFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisModule
-
- addTotals(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
-
- addTotals(GetStats) - Method in class org.elasticsearch.index.get.GetStats
-
- addTotals(IndexingStats) - Method in class org.elasticsearch.index.indexing.IndexingStats
-
- 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
-
- addTransport(String, Class<? extends Transport>) - Method in class org.elasticsearch.transport.TransportModule
-
- 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.
- addTransportAddresses(TransportAddress...) - Method in class org.elasticsearch.client.transport.TransportClientNodesService
-
- addTransportService(String, Class<? extends TransportService>) - Method in class org.elasticsearch.transport.TransportModule
-
- addTypeListener(DocumentTypeListener) - Method in class org.elasticsearch.index.mapper.MapperService
-
- 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(String, Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
-
- addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
- addUnboundedFrom(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
- addUnboundedFrom(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
- addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
-
- addUnboundedTo(String, Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
-
- addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
- addUnboundedTo(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
- addUnboundedTo(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
- addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
-
- addUnicastHostProvider(Class<? extends UnicastHostsProvider>) - Method in class org.elasticsearch.discovery.DiscoveryModule
-
Adds a custom unicast hosts provider to build a dynamic list of unicast hosts list when doing unicast discovery.
- addUnlikeItem(MoreLikeThisQueryBuilder.Item...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Adds a document to use in order to find documents that are "unlike" this.
- addUnlikeText(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Adds some text to use in order to find documents that are "unlike" this.
- addValidationError(String, ActionRequestValidationException) - Static method in class org.elasticsearch.action.ValidateActions
-
- addValidationError(String) - Method in exception org.elasticsearch.common.ValidationException
-
Add a new validation error to the accumulating validation errors
- addValidationErrors(Iterable<String>) - Method in exception org.elasticsearch.common.ValidationException
-
Add a sequence of validation errors to the accumulating validation errors
- addVersionMapMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- addWarmers(String...) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequestBuilder
-
- addWithKey(Object, IndexableField) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
- 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.MemoryCircuitBreaker
-
Add an exact number of bytes, not checking for tripping the
circuit breaker.
- addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
-
- addZenPing(Class<? extends ZenPing>) - Method in class org.elasticsearch.discovery.DiscoveryModule
-
- adjustForNoTerms(long) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData.PackedArrayEstimator
-
Adjust the breaker when no terms were actually loaded, but the field
data takes up space regardless.
- adjustForNoTerms(long) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
-
Adjust the breaker when no terms were actually loaded, but the field
data takes up space regardless.
- 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
-
- after(Priority) - Method in class org.elasticsearch.common.Priority
-
- after(Version) - Method in class org.elasticsearch.Version
-
- afterBulk(long, BulkRequest, BulkResponse) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback after a successful execution of bulk request.
- afterBulk(long, BulkRequest, Throwable) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback after a failed execution of bulk request.
- afterClose() - Method in class org.elasticsearch.common.component.LifecycleListener
-
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
-
- afterIndexClosed(Index, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called after the index has been closed.
- afterIndexClosed(Index, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- afterIndexCreated(IndexService) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called after the index has been created.
- afterIndexCreated(IndexService) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- afterIndexDeleted(Index, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called after the index has been deleted.
- afterIndexDeleted(Index, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- afterIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called after the index shard has been closed.
- afterIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- afterIndexShardCreated(IndexShard) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called after the index shard has been created.
- afterIndexShardCreated(IndexShard) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- afterIndexShardDeleted(ShardId, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called after the index shard has been deleted from disk.
- afterIndexShardDeleted(ShardId, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- afterIndexShardPostRecovery(IndexShard) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called right after the shard is moved into POST_RECOVERY mode
- afterIndexShardPostRecovery(IndexShard) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- afterIndexShardStarted(IndexShard) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called after the index shard has been started.
- afterIndexShardStarted(IndexShard) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- afterInjection(I) - Method in interface org.elasticsearch.common.inject.spi.InjectionListener
-
Invoked by Guice after it injects the fields and methods of instance.
- 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.NonEstimatingEstimator
-
- afterLoad(TermsEnum, long) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData.PackedArrayEstimator
-
Adjusts the breaker based on the aggregated value from the RamAccountingTermsEnum
- 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.
- afterLoad(TermsEnum, long) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.ParentChildEstimator
-
Adjusts the breaker based on the difference between the actual usage
and the aggregated estimations.
- 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
-
- AggregatedDfs - Class in org.elasticsearch.search.dfs
-
- AggregatedDfs(ObjectObjectHashMap<Term, TermStatistics>, ObjectObjectHashMap<String, CollectionStatistics>, long) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
-
- aggregateDfs(AtomicArray<DfsSearchResult>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
-
- Aggregation - Interface in org.elasticsearch.search.aggregations
-
An aggregation
- aggregation(String, boolean) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.Histogram.Order
-
Creates a bucket ordering strategy that sorts buckets based on a single-valued calc sug-aggregation
- aggregation(String, String, boolean) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.Histogram.Order
-
Creates a bucket ordering strategy that sorts buckets based on a multi-valued calc sug-aggregation
- aggregation(String, boolean) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.Terms.Order
-
Creates a bucket ordering strategy which sorts buckets based on a single-valued calc get
- aggregation(String, String, boolean) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.Terms.Order
-
Creates a bucket ordering strategy which sorts buckets based on a multi-valued calc get
- aggregation() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
-
- aggregation() - Method in interface org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetric
-
The result of the aggregation.
- aggregation(AbstractAggregationBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Add an get to perform as part of the search.
- AGGREGATION_TRANFORM_FUNCTION - Static variable in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
- AggregationBinaryParseElement - Class in org.elasticsearch.search.aggregations
-
- AggregationBinaryParseElement(AggregatorParsers) - Constructor for class org.elasticsearch.search.aggregations.AggregationBinaryParseElement
-
- AggregationBuilder<B extends AggregationBuilder<B>> - Class in org.elasticsearch.search.aggregations
-
A base class for all bucket aggregation builders.
- AggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.AggregationBuilder
-
Sole constructor, typically used by sub-classes.
- AggregationBuilders - Class in org.elasticsearch.search.aggregations
-
Utility class to create aggregations.
- aggregationContext() - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
-
- aggregationContext(AggregationContext) - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
-
- AggregationContext - Class in org.elasticsearch.search.aggregations.support
-
- AggregationContext(SearchContext) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationContext
-
- 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
-
- AggregationParseElement - Class in org.elasticsearch.search.aggregations
-
The search parse element that is responsible for parsing the get part of the request.
- AggregationParseElement(AggregatorParsers) - Constructor for class org.elasticsearch.search.aggregations.AggregationParseElement
-
- AggregationPath - Class in org.elasticsearch.search.aggregations.support
-
A path that can be used to sort/order buckets (in some multi-bucket aggregations, eg terms & histogram) based on
sub-aggregations.
- 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
-
- AggregationPhase(AggregationParseElement, AggregationBinaryParseElement) - Constructor for class org.elasticsearch.search.aggregations.AggregationPhase
-
- aggregations() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
-
- aggregations() - Method in class org.elasticsearch.percolator.PercolateContext
-
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.percolator.PercolateContext
-
- Aggregations - Interface in org.elasticsearch.search.aggregations
-
Represents a set of computed addAggregation.
- 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(byte[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a raw (xcontent / json) addAggregation.
- aggregations(byte[], int, int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a raw (xcontent / json) addAggregation.
- aggregations(BytesReference) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a raw (xcontent / json) addAggregation.
- aggregations(XContentBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a raw (xcontent / json) addAggregation.
- aggregations(Map) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a raw (xcontent / json) addAggregation.
- aggregations() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- aggregations() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- aggregations() - Method in class org.elasticsearch.search.internal.InternalSearchResponse
-
- aggregations() - Method in class org.elasticsearch.search.internal.SearchContext
-
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.SearchContext
-
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- aggregations() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- aggregations(InternalAggregations) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- AggregationStreams - Class in org.elasticsearch.search.aggregations
-
A registry for all the dedicated streams in the aggregation module.
- AggregationStreams() - Constructor for class org.elasticsearch.search.aggregations.AggregationStreams
-
- AggregationStreams.Stream - Interface in org.elasticsearch.search.aggregations
-
A stream that knows how to read an aggregation from the input.
- 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, AggregationContext, 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.Builder - Class in org.elasticsearch.search.aggregations
-
- AggregatorFactory - Class in org.elasticsearch.search.aggregations
-
A factory that knows how to create an
Aggregator
of a specific type.
- AggregatorFactory(String, String) - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactory
-
Constructs a new aggregator factory.
- AggregatorParsers - Class in org.elasticsearch.search.aggregations
-
A registry for all the aggregator parser, also servers as the main parser for the aggregations module
- AggregatorParsers(Set<Aggregator.Parser>, Set<PipelineAggregator.Parser>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorParsers
-
Constructs the AggregatorParsers out of all the given parsers
- 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.
- aggsUsedForSorting - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
-
- aggType - Variable in class org.elasticsearch.search.aggregations.metrics.NumericValuesSourceMetricsAggregatorParser
-
- 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(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.template.put.PutIndexTemplateRequest
-
Adds an alias that will be added when the index gets created.
- alias(String) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- Alias(AliasMetaData, IndexMetaData) - Constructor for class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
-
- aliasAction() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- AliasAction - Class in org.elasticsearch.cluster.metadata
-
- AliasAction(AliasAction) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction
-
- AliasAction(AliasAction.Type) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction
-
- AliasAction(AliasAction.Type, String, String) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction
-
- AliasAction(AliasAction.Type, String, String, String) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction
-
- AliasAction.Type - Enum in org.elasticsearch.cluster.metadata
-
- AliasActions(AliasAction.Type, String[], String[]) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- AliasActions(AliasAction.Type, String, String) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- AliasActions(AliasAction) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- AliasActions(AliasAction.Type, String, String[]) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- AliasActions() - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- aliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
-
- aliases() - 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() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- aliases(Set<Alias>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
- aliases() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
- 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(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(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(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() - 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(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(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(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(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() - Method in interface org.elasticsearch.action.AliasesRequest
-
Returns the array of aliases that the action relates to
- aliases(String[]) - Method in interface org.elasticsearch.action.AliasesRequest
-
Sets the array of aliases that the action relates to
- aliases(IndicesAliasesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to add/remove aliases from indices.
- aliases(IndicesAliasesRequest, ActionListener<IndicesAliasesResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to add/remove aliases from indices.
- aliases() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- aliases(Set<Alias>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
-
- 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.alias.delete
-
- AliasesNotFoundException(String...) - Constructor for exception org.elasticsearch.rest.action.admin.indices.alias.delete.AliasesNotFoundException
-
- AliasesNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.rest.action.admin.indices.alias.delete.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.
- aliasesService() - Method in class org.elasticsearch.index.IndexService
-
- aliasFilter(String...) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
-
Returns the filter associated with listed filtering aliases.
- aliasFilter() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
-
- aliasFilter() - Method in class org.elasticsearch.percolator.PercolateContext
-
- aliasFilter() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- aliasFilter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- aliasFilter() - Method in class org.elasticsearch.search.internal.SearchContext
-
- AliasFilterParsingException - Exception in org.elasticsearch.indices
-
- AliasFilterParsingException(Index, String, String, Throwable) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
-
- AliasFilterParsingException(StreamInput) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
-
- AliasMetaData - Class in org.elasticsearch.cluster.metadata
-
- 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
-
- 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(Settings) - 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 reutrn 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.state.ClusterStateRequest
-
- all() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Include all data
- ALL - Static variable in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- 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 - 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_NODES - Static variable in class org.elasticsearch.action.support.nodes.BaseNodesRequest
-
- 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
-
- ALL_TASKS - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
- 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() - Constructor for class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
-
- AllCircuitBreakerStats(CircuitBreakerStats[]) - Constructor for class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
-
- AllEntries - Class in org.elasticsearch.common.lucene.all
-
- AllEntries() - Constructor for class org.elasticsearch.common.lucene.all.AllEntries
-
- allEntries() - Method in class org.elasticsearch.common.lucene.all.AllTokenStream
-
- allEntries() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- allEntries() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- AllEntries.Entry - Class in org.elasticsearch.common.lucene.all
-
- allFailures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- AllField - Class in org.elasticsearch.common.lucene.all
-
- AllField(String, AllEntries, Analyzer, 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.internal
-
- AllFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- AllFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- AllFieldMapper.IncludeInAll - Interface in org.elasticsearch.index.mapper.internal
-
- AllFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- AllFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
-
- AllFieldsVisitor() - Constructor for class org.elasticsearch.index.fieldvisitor.AllFieldsVisitor
-
- AllocateAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned shard to a specific node.
- AllocateAllocationCommand(ShardId, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand
-
- AllocateAllocationCommand.Factory - Class in org.elasticsearch.cluster.routing.allocation.command
-
- allocated() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
-
- allocateDangled(Collection<IndexMetaData>, LocalAllocateDangledIndices.Listener) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices
-
- AllocateDangledRequest() - Constructor for class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledRequest
-
- allocatedPostIndexCreate() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
- allocateUnassigned(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Assign all unassigned shards to nodes
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
-
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
-
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.PrimaryShardAllocator
-
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
- ALLOCATION_ALLOW_REBALANCE_VALIDATOR - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
-
- AllocationCommand - Interface in org.elasticsearch.cluster.routing.allocation.command
-
This interface defines the basic methods of commands for allocation
- AllocationCommand.Factory<T extends AllocationCommand> - Interface in org.elasticsearch.cluster.routing.allocation.command
-
- AllocationCommands - Class in org.elasticsearch.cluster.routing.allocation.command
-
- AllocationCommands(AllocationCommand...) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.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(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
- AllocationDeciders - Class in org.elasticsearch.cluster.routing.allocation.decider
-
- AllocationDeciders(Settings, AllocationDecider[]) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
-
- AllocationDeciders(Settings, Set<AllocationDecider>) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
-
- AllocationExplanation - Class in org.elasticsearch.cluster.routing.allocation
-
Instances of this class keeps explanations of decisions that have been made by allocation.
- AllocationExplanation() - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
-
- AllocationExplanation.NodeExplanation - Class in org.elasticsearch.cluster.routing.allocation
-
Instances of this class keep messages and informations about nodes of an allocation
- AllocationId - Class in org.elasticsearch.cluster.routing
-
Uniquely identifies an allocation.
- allocationId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
An id that uniquely identifies an allocation.
- AllocationService - Class in org.elasticsearch.cluster.routing.allocation
-
This service manages the node allocation of a cluster.
- AllocationService(Settings, AllocationDeciders, ShardsAllocators, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
-
- ALLOW_UNMAPPED - Static variable in class org.elasticsearch.index.query.IndexQueryParserService
-
- allowAliasesToMultipleIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
-
- allowCredentials() - Method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
By default cookies are not included in CORS requests, but this method will enable cookies to
be added to CORS requests.
- ALLOWED_CONTENT_FIELD_NAMES - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- ALLOWED_URLS_SETTING - Static variable in class org.elasticsearch.repositories.uri.URLRepository
-
- allowedRequestHeaders() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Returns the allowed set of Request Headers.
- allowedRequestHeaders(String...) - Method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
Specifies the if headers that should be returned in the CORS 'Access-Control-Allow-Headers'
response header.
- allowedRequestMethods() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Returns the allowed set of Request Methods.
- allowedRequestMethods(HttpMethod...) - Method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
Specifies the allowed set of HTTP Request Methods that should be returned in the
CORS 'Access-Control-Request-Method' response header.
- allowLeadingWildcard() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- allowLeadingWildcard(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- 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
-
- allowPrimary() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand
-
Determine if primary allocation is allowed
- allowPrimary() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
- allowsNull(Annotation[]) - Static method in class org.elasticsearch.common.inject.internal.Nullability
-
- allowsPrimaryPromotion() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns true
iff this shard allows primary promotion, otherwise false
- allowsPrimaryPromotion() - Method in class org.elasticsearch.index.shard.ShadowIndexShard
-
- 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
-
- allReplicasActive(ShardRouting) - 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.cluster.routing.RoutingTable
-
All the shards (replicas) for all indices in this routing table.
- 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 otherwise false
- 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 - Class in org.elasticsearch.common.lucene.all
-
- allTokenStream(String, AllEntries, Analyzer) - Static method in class org.elasticsearch.common.lucene.all.AllTokenStream
-
- 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
-
- AlreadyExpiredException - Exception in org.elasticsearch.index
-
- AlreadyExpiredException(String, String, String, long, long, long) - Constructor for exception org.elasticsearch.index.AlreadyExpiredException
-
- AlreadyExpiredException(StreamInput) - Constructor for exception org.elasticsearch.index.AlreadyExpiredException
-
- ALWAYS - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
- ALWAYS_INSTANCE - Static variable in enum org.elasticsearch.common.geo.GeoDistance
-
- 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
-
- AnalysisBinderProcessor() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
-
- AnalysisModule - Class in org.elasticsearch.index.analysis
-
- AnalysisModule(Settings, IndicesAnalysisService) - Constructor for class org.elasticsearch.index.analysis.AnalysisModule
-
- AnalysisModule.AnalysisBinderProcessor - Class in org.elasticsearch.index.analysis
-
- AnalysisModule.AnalysisBinderProcessor.AnalyzersBindings - Class in org.elasticsearch.index.analysis
-
- AnalysisModule.AnalysisBinderProcessor.CharFiltersBindings - Class in org.elasticsearch.index.analysis
-
- AnalysisModule.AnalysisBinderProcessor.TokenFiltersBindings - Class in org.elasticsearch.index.analysis
-
- AnalysisModule.AnalysisBinderProcessor.TokenizersBindings - Class in org.elasticsearch.index.analysis
-
- AnalysisService - Class in org.elasticsearch.index.analysis
-
Manages configuring and storing analyzers, tokenizers, char filters and token filters.
- AnalysisService(Index, Settings) - Constructor for class org.elasticsearch.index.analysis.AnalysisService
-
- AnalysisService(Index, IndexSettingsService, IndicesAnalysisService, Map<String, AnalyzerProviderFactory>, Map<String, TokenizerFactoryFactory>, Map<String, CharFilterFactoryFactory>, Map<String, TokenFilterFactoryFactory>) - Constructor for class org.elasticsearch.index.analysis.AnalysisService
-
- analysisService() - Method in class org.elasticsearch.index.IndexService
-
- analysisService() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
-
- analysisService() - Method in class org.elasticsearch.index.mapper.MapperService
-
- analysisService() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- analysisService() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- analysisService() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- analysisService() - Method in class org.elasticsearch.percolator.PercolateContext
-
- analysisService() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- analysisService() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- analysisService() - Method in class org.elasticsearch.search.internal.SearchContext
-
- AnalysisSettingsRequired - Annotation Type in org.elasticsearch.index.analysis
-
- analyze(AnalyzeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- analyze(AnalyzeRequest, ActionListener<AnalyzeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- analyze(Analyzer, BytesRef, String, SuggestUtils.TokenConsumer, CharsRefBuilder) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- analyze(Analyzer, CharsRef, String, SuggestUtils.TokenConsumer) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- analyze(TokenStream, SuggestUtils.TokenConsumer) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
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
TokenStrem twice in the same recursion...
- AnalyzeAction - Class in org.elasticsearch.action.admin.indices.analyze
-
- analyzer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- analyzer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- analyzer() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
-
- analyzer(DetailAnalyzeResponse.AnalyzeTokenList) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
-
- analyzer(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
-
- analyzer() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
The actual analyzer.
- analyzer() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
-
- ANALYZER - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- analyzer() - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
-
Name of analyzer.
- analyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper.Builder
-
- analyzer() - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper.Builder
-
- 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.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 - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryParser.Field
-
- 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 - Variable in class org.elasticsearch.index.search.MatchQuery
-
- analyzer(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- ANALYZER - Static variable in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction.Fields
-
- analyzer(String) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Sets the analyzer to analyse to suggest text with.
- ANALYZER_VERSION - Static variable in class org.elasticsearch.common.lucene.Lucene
-
- 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.
- 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
-
- analyzerProviderFactories() - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- AnalyzerProviderFactory - Interface in org.elasticsearch.index.analysis
-
- analyzerProviderFactory(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- analyzers() - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
-
- AnalyzersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.AnalyzersBindings
-
- AnalyzerScope - Enum in org.elasticsearch.index.analysis
-
- AnalyzeToken(String, 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.apache.lucene.queryparser.classic.QueryParserSettings
-
- analyzeWildcard(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set to true to enable analysis on wildcard and prefix queries.
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryParser.Settings
-
- analyzeWildcard() - Method in class org.elasticsearch.index.query.SimpleQueryParser.Settings
-
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
- AnalyzingCompletionLookupProvider - Class in org.elasticsearch.search.suggest.completion
-
- AnalyzingCompletionLookupProvider(boolean, boolean, boolean, boolean) - Constructor for class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- 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 return true
.
- andQuery(QueryBuilder...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- AndQueryBuilder - Class in org.elasticsearch.index.query
-
- AndQueryBuilder(QueryBuilder...) - Constructor for class org.elasticsearch.index.query.AndQueryBuilder
-
Deprecated.
- AndQueryParser - Class in org.elasticsearch.index.query
-
Deprecated.
- AndQueryParser() - Constructor for class org.elasticsearch.index.query.AndQueryParser
-
Deprecated.
- 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(Class<? extends 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.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(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(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(Annotation) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
-
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
-
- annotatedWith(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.
- 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.
- 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
- 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
- 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(String, InternalAggregation.Type, SearchContext) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
-
- ANY_ORIGIN - Static variable in class org.elasticsearch.http.netty.cors.CorsHandler
-
- anySet() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- API_AND_GATEWAY - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- API_AND_SNAPSHOT - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- API_ONLY - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- ApostropheFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory for ApostropheFilter
- ApostropheFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ApostropheFilterFactory
-
- append(StringBuilder, String, int, int) - Method in class org.apache.lucene.search.postingshighlight.CustomPassageFormatter
-
- append(FieldStats) - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
Merges the provided stats into this stats instance.
- append(FieldStats) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Double
-
- append(FieldStats) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Float
-
- append(FieldStats) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Long
-
- append(FieldStats) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Text
-
- append(CharSequence) - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Appends the specified character sequence to this writer.
- append(CharSequence, int, int) - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Appends a subsequence of the specified character sequence to this writer.
- append(char) - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Appends the specified character to this writer.
- append(Path, Path, int) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Appends the path to the given base and strips N elements off the path if strip is > 0.
- append(LoggingEvent) - Method in class org.elasticsearch.common.logging.log4j.TerminalAppender
-
- appendElement(T[], T) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
- apply(Task, String, ActionRequest, ActionListener, ActionFilterChain) - 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 given
chain
- apply(String, ActionResponse, ActionListener, ActionFilterChain) - Method in interface org.elasticsearch.action.support.ActionFilter
-
Enables filtering the execution of an action on the response side, either by sending a response through the
ActionListener
or by continuing the execution through the given
chain
- apply(Task, String, ActionRequest, ActionListener, ActionFilterChain) - Method in class org.elasticsearch.action.support.ActionFilter.Simple
-
- 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, or false
if it should be aborted since the filter already handled the request and called the given listener.
- apply(String, ActionResponse, ActionListener, ActionFilterChain) - Method in class org.elasticsearch.action.support.ActionFilter.Simple
-
- apply(String, ActionResponse, ActionListener) - Method in class org.elasticsearch.action.support.ActionFilter.Simple
-
Applies this filter and returns true
if the execution chain should proceed, or false
if it should be aborted since the filter already handled the response by calling the given listener.
- apply(ClusterState, ClusterState.ClusterStateStatus, ClusterState, ClusterState.ClusterStateStatus) - Method in interface org.elasticsearch.cluster.ClusterStateObserver.ChangePredicate
-
a rough check used when starting to monitor for a new change.
- apply(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.ClusterStateObserver.ChangePredicate
-
called to see whether a cluster change should be accepted
- apply(ClusterState, ClusterState.ClusterStateStatus, ClusterState, ClusterState.ClusterStateStatus) - Method in class org.elasticsearch.cluster.ClusterStateObserver.EventPredicate
-
- apply(ClusterState, ClusterState.ClusterStateStatus, ClusterState, ClusterState.ClusterStateStatus) - Method in class org.elasticsearch.cluster.ClusterStateObserver.ValidationPredicate
-
- apply(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.ClusterStateObserver.ValidationPredicate
-
- apply(T) - Method in interface org.elasticsearch.cluster.Diff
-
Applies difference to the specified part and retunrs the resulted part
- apply(CreateIndexClusterStateUpdateRequest, IndexTemplateMetaData) - Method in interface org.elasticsearch.cluster.metadata.IndexTemplateFilter
-
- apply(CreateIndexClusterStateUpdateRequest, IndexTemplateMetaData) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateFilter.Compound
-
- apply(double) - Method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
-
- applyFailedShard(ClusterState, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
- applyFailedShards(ClusterState, List<FailedRerouteAllocation.FailedShard>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the failed shards.
- applyFailedShards(FailedRerouteAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
- applyFailedShards(FailedRerouteAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Applies changes on failed nodes based on the implemented algorithm.
- applyFailedShards(FailedRerouteAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
-
- applyFailedShards(FailedRerouteAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
-
- applyMinimumShouldMatch(BooleanQuery, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
- ApplySettings() - Constructor for class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService.ApplySettings
-
- applySettings(Settings) - Method in class org.elasticsearch.transport.TransportService
-
- applyStartedShards(ClusterState, List<? extends ShardRouting>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the started shards.
- applyStartedShards(ClusterState, List<? extends ShardRouting>, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
- applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
- applyStartedShards(StartedRerouteAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Applies changes on started nodes based on the implemented algorithm.
- applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
-
- applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
-
- applyTo(M) - Method in class org.elasticsearch.client.support.Headers
-
- 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(ScopedBindingBuilder) - Method in class org.elasticsearch.common.inject.internal.Scoping
-
- 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
-
- ArabicAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- ArabicAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ArabicAnalyzerProvider
-
- ArabicNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
-
- ArabicNormalizationFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ArabicNormalizationFilterFactory
-
- ArabicStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- ArabicStemTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ArabicStemTokenFilterFactory
-
- arcDistance(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- arcDistanceInKm(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- arcDistanceInKmWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- arcDistanceInMiles(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- arcDistanceInMilesWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- arcDistanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- ArcFixedSourceDistance(double, double, DistanceUnit) - Constructor for class org.elasticsearch.common.geo.GeoDistance.ArcFixedSourceDistance
-
- ArmenianAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- ArmenianAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ArmenianAnalyzerProvider
-
- array() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- array() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
The underlying byte array (if exists).
- array() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- array() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- array(String, String...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- array(XContentBuilderString, String...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- array(String, Object...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- array(XContentBuilderString, Object...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- arrayAsArrayList(E...) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- arrayOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns an array type whose elements are all instances of
componentType
.
- arrayOffset() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- arrayOffset() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
The offset into the underlying byte array.
- arrayOffset() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- arrayOffset() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- 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.object
-
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 enum org.elasticsearch.common.util.CollectionUtils
-
- asArrayList(E, E, E...) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- asByte() - Method in class org.elasticsearch.common.unit.Fuzziness
-
- asc() - Method in class org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket.SubAggregationComparator
-
- ASCIIFoldingTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory for ASCIIFoldingFilter.
- ASCIIFoldingTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ASCIIFoldingTokenFilterFactory
-
- asDistance() - Method in class org.elasticsearch.common.unit.Fuzziness
-
- asDistance(String) - Method in class org.elasticsearch.common.unit.Fuzziness
-
- asDouble() - 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
-
- asin(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- asin(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- asin(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- asin(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- asin(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- asInt() - 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, with an Entry wrapping each value allowing to
retain its index.
- asList() - Method in interface org.elasticsearch.search.aggregations.Aggregations
-
- asList() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- asLong() - Method in class org.elasticsearch.common.unit.Fuzziness
-
- asMap() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
-
- asMap() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
- asMap() - Method in interface org.elasticsearch.search.aggregations.Aggregations
-
- asMap() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- asMap() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
-
- asMultiBucketAggregator(AggregatorFactory, AggregationContext, Aggregator) - Static method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Utility method.
- asQuery(String...) - Method in class org.elasticsearch.index.query.support.XContentStructure
-
Use the captured bytes to parse the inner query using the specified
types.
- asQuery(String...) - Method in class org.elasticsearch.index.query.support.XContentStructure.InnerQuery
-
Return the query represented by the XContentStructure object,
returning the cached Query if it has already been parsed.
- asSequentialAccessBits(int, Scorer) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Given a Scorer
, return a Bits
instance that will match
all documents contained in the set.
- assertClusterStateThread() - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
asserts that the current thread is the cluster state update thread
- assertNotTransportThread(String) - Static method in enum org.elasticsearch.transport.Transports
-
- 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.
- assertTransportThread() - Static method in enum org.elasticsearch.transport.Transports
-
- asShort() - Method in class org.elasticsearch.common.unit.Fuzziness
-
- assignedReplicasIncludingRelocating() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
-
- assignedReplicasIncludingRelocating() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
- assignedShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of assigned shards
- assignedShards(ShardRouting) - 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.
- 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
-
- asString() - Method in class org.elasticsearch.common.unit.Fuzziness
-
- asTimeValue() - Method in class org.elasticsearch.common.unit.Fuzziness
-
- asUnordered() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
-
- asUnordered() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
- AsyncAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
-
- 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
-
- 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(ESLogger, String, ShardId, AsyncShardFetch.List<? 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.List<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.
- atan(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan2(Short, Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan2(Integer, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan2(Float, Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan2(Long, Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- atan2(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- AtomicArray<E> - Class in org.elasticsearch.common.util.concurrent
-
- AtomicArray(int) - Constructor for class org.elasticsearch.common.util.concurrent.AtomicArray
-
- AtomicArray.Entry<E> - Class in org.elasticsearch.common.util.concurrent
-
An entry within the array.
- AtomicFieldData - Interface in org.elasticsearch.index.fielddata
-
The thread safe LeafReader
level cache of the data.
- AtomicGeoPointFieldData - Interface in org.elasticsearch.index.fielddata
-
- AtomicNumericFieldData - Interface in org.elasticsearch.index.fielddata
-
- AtomicOrdinalsFieldData - Interface in org.elasticsearch.index.fielddata
-
- AtomicParentChildFieldData - Interface in org.elasticsearch.index.fielddata
-
- 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(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- attributes() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- attributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The node attributes.
- attributes() - Method in class org.elasticsearch.node.service.NodeService
-
Attributes different services in the node can add to be reported as part of the node info (for example).
- ATTRIBUTES - Static variable in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction.Fields
-
- attributes(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.BucketStreamContext
-
- attributes() - Method in class org.elasticsearch.search.aggregations.bucket.BucketStreamContext
-
- AUTO - Static variable in class org.elasticsearch.common.unit.Fuzziness
-
- AUTO_THROTTLE - Static variable in class org.elasticsearch.index.shard.MergeSchedulerConfig
-
- 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, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.AutoCreateIndex
-
- autoGeneratedId() - Method in class org.elasticsearch.action.index.IndexRequest
-
Has the id been auto generated?
- autoGeneratedId() - Method in class org.elasticsearch.index.engine.Engine.Create
-
- autoGeneratePhraseQueries() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- autoGeneratePhraseQueries(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- autoGeneratePhraseQueries(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set to true if phrase queries will be automatically generated
when the analyzer returns more than one term from whitespace
delimited text.
- autoIndexJtsGeometry - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- autoValidateJtsGeometry - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- available() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
-
Deprecated.
Method is overridden to report number of bytes that can now be read
from decoded data buffer, without reading bytes from the underlying
stream.
- available() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
Method is overridden to report number of bytes that can now be read
from decoded data buffer, without reading bytes from the underlying
stream.
- available() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
-
- available() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
- available() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
-
- available() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- availableCodecs() - Method in class org.elasticsearch.index.codec.CodecService
-
Returns all registered available codec names
- availableShardPaths(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all shard paths excluding custom shard path.
- availableShards() - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
-
- averageUsage(RoutingNode, Map<String, DiskUsage>) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Returns a
DiskUsage
for the
RoutingNode
using the
average usage of other nodes in the disk usage map.
- avg(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Avg
aggregation with the given name.
- Avg - Interface in org.elasticsearch.search.aggregations.metrics.avg
-
An aggregation that computes the average of the values in the current bucket.
- AvgAggregator - Class in org.elasticsearch.search.aggregations.metrics.avg
-
- AvgAggregator(String, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
-
- AvgAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.avg
-
- avgBucket(String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
-
- AvgBucketBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg
-
- AvgBucketBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketBuilder
-
- AvgBucketParser - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg
-
- AvgBucketParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketParser
-
- AvgBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg
-
- AvgBucketPipelineAggregator(String, String[], BucketHelpers.GapPolicy, ValueFormatter, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
-
- AvgBucketPipelineAggregator.Factory - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg
-
- AvgBuilder - Class in org.elasticsearch.search.aggregations.metrics.avg
-
Builder for the
Avg
aggregation.
- AvgBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgBuilder
-
Sole constructor.
- AvgParser - Class in org.elasticsearch.search.aggregations.metrics.avg
-
- AvgParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgParser
-
- avgShardsPerNode(String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Returns the average of shards per node for the given index
- avgShardsPerNode() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Returns the global average of shards per node
- await() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
-
- await(long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
-
- 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.
- awaitTermination() - Method in interface org.elasticsearch.indices.IndicesWarmer.TerminationHandle
-
Wait until execution of the warm-up action completes.
- awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.threadpool.ThreadPool
-
- AwarenessAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
controls shard allocation based on
awareness key-value pairs defined in the node configuration.
- AwarenessAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
-
- AwarenessAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
-
- AwarenessAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
-
- awarenessAttributes() - Method in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
-
Get the attributes defined by this instance
- cache - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
-
- cache() - Method in class org.elasticsearch.index.IndexService
-
- cache - Variable in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
- cache - Variable in enum org.elasticsearch.indices.analysis.PreBuiltCharFilters
-
- cache - Variable in enum org.elasticsearch.indices.analysis.PreBuiltTokenFilters
-
- cache - Variable in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
-
- cache() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
-
- CachedPositionIterator - Class in org.elasticsearch.search.lookup
-
- CachedPositionIterator(IndexFieldTerm) - Constructor for class org.elasticsearch.search.lookup.CachedPositionIterator
-
- 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
-
- 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
-
- calcRequiredAllocations(String, int) - Method in class org.elasticsearch.gateway.Gateway
-
- calculate(double, double) - Method in class org.elasticsearch.common.geo.GeoDistance.ArcFixedSourceDistance
-
- calculate(double, double, double, double, DistanceUnit) - Method in enum org.elasticsearch.common.geo.GeoDistance
-
- calculate(double, double) - Method in class org.elasticsearch.common.geo.GeoDistance.FactorFixedSourceDistance
-
- calculate(double, double) - Method in interface org.elasticsearch.common.geo.GeoDistance.FixedSourceDistance
-
- calculate(double, double) - Method in class org.elasticsearch.common.geo.GeoDistance.PlaneFixedSourceDistance
-
- calculate(double, double) - Method in class org.elasticsearch.common.geo.GeoDistance.SloppyArcFixedSourceDistance
-
- calculateMinShouldMatch(int, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
- Callback<T> - Interface in org.elasticsearch.common.util
-
- camelCase() - Method in class org.elasticsearch.common.xcontent.XContentBuilderString
-
- 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, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
- canAllocate(IndexMetaData, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
- canAllocate(RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
- canAllocate(ShardRouting, 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.AllocationDeciders
-
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
-
- canAllocate(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.DisableAllocationDecider
-
Deprecated.
- 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(IndexMetaData, 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.NodeVersionAllocationDecider
-
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ReplicaAfterPrimaryActiveAllocationDecider
-
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ReplicaAfterPrimaryActiveAllocationDecider
-
- 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(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
-
- canAllocate(RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
-
- 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.cache.request.IndicesRequestCache
-
Can the shard request be cached at all?
- cancel(String) - Method in class org.elasticsearch.common.util.CancellableThreads
-
cancel all current running operations.
- cancel(boolean) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
- cancel(Future<?>) - Static method in class org.elasticsearch.common.util.concurrent.FutureUtils
-
- 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.RecoveryStatus
-
cancel the recovery.
- cancel(CancellableTask, String, Consumer<Set<String>>) - 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(ShardId, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
- CancelAllocationCommand.Factory - Class in org.elasticsearch.cluster.routing.allocation.command
-
- CancellableTask - Class in org.elasticsearch.tasks
-
A task that can be canceled
- CancellableTask(long, String, String, String) - Constructor for class org.elasticsearch.tasks.CancellableTask
-
- CancellableTask(long, String, String, String, TaskId) - Constructor for class org.elasticsearch.tasks.CancellableTask
-
- 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() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- CancellableThreads.ExecutionCancelledException - Exception in org.elasticsearch.common.util
-
- CancellableThreads.Interruptable - Interface in org.elasticsearch.common.util
-
- 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.
- cancelRecoveriesForShard(ShardId, String, Predicate<RecoveryStatus>) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
cancel all ongoing recoveries for the given shard, if their status match a predicate
- cancelRecoveriesForShard(ShardId, String, Predicate<RecoveryStatus>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
cancel all ongoing recoveries for the given shard, if their status match a predicate
- 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(AllocationId) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id representing a cancelled relocation.
- cancelRelocation(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Cancels a relocation of a shard that shard must relocating.
- 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 - 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() - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes tasks request against one or more nodes.
- 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 FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
-
- canDeleteIndexContents(Index, Settings, boolean) - Method in class org.elasticsearch.indices.IndicesService
-
This method returns true if the current node is allowed to delete the
given index.
- canDeleteShardContent(ShardId, IndexMetaData) - Method in class org.elasticsearch.indices.IndicesService
-
Returns true
iff 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
-
- candidateGenerator(String) - Static method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
- CandidateGenerator(String) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.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
-
- canHaveDuplicates() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Is this request can potentially be dup on a single shard.
- canHaveDuplicates() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- canHighlight(FieldMapper) - Method in class org.elasticsearch.search.highlight.FastVectorHighlighter
-
- canHighlight(FieldMapper) - Method in interface org.elasticsearch.search.highlight.Highlighter
-
- canHighlight(FieldMapper) - Method in class org.elasticsearch.search.highlight.PlainHighlighter
-
- canHighlight(FieldMapper) - Method in class org.elasticsearch.search.highlight.PostingsHighlighter
-
- canIndex() - Method in class org.elasticsearch.index.shard.IndexShard
-
returns true if this shard supports indexing (i.e., write) operations.
- canIndex() - Method in class org.elasticsearch.index.shard.ShadowIndexShard
-
- 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
-
- 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
- canOpenIndex(ESLogger, Path) - Static method in class org.elasticsearch.index.store.Store
-
Returns true
iff the given location contains an index an the index
can be successfully opened.
- 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(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(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
-
- canRebalance(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(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.
- 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
-
- capacity() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- capitalize(String) - Static method in class org.elasticsearch.common.inject.internal.Strings
-
- capitalize(String) - Static method in class org.elasticsearch.common.Strings
-
- cardinality() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalMapping
-
- 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.
- cardinality(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
-
- CardinalityAggregator - Class in org.elasticsearch.search.aggregations.metrics.cardinality
-
An aggregator that computes approximate counts of unique values.
- CardinalityAggregator(String, ValuesSource, int, ValueFormatter, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
-
- CardinalityBuilder - Class in org.elasticsearch.search.aggregations.metrics.cardinality
-
- CardinalityBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityBuilder
-
Sole constructor.
- CardinalityParser - Class in org.elasticsearch.search.aggregations.metrics.cardinality
-
- CardinalityParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityParser
-
- 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
-
- CatalanAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- CatalanAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CatalanAnalyzerProvider
-
- category(String) - Static method in class org.elasticsearch.search.suggest.context.ContextBuilder
-
Create a new CategoryMapping
- category(String, String) - Static method in class org.elasticsearch.search.suggest.context.ContextBuilder
-
Create a new CategoryMapping
with default category
- CategoryContextMapping - Class in org.elasticsearch.search.suggest.context
-
- CategoryContextMapping(String) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- CategoryContextMapping(String, String) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- CategoryContextMapping(String, Iterable<? extends CharSequence>) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- CategoryContextMapping(String, String, Iterable<? extends CharSequence>) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- CategoryContextMapping.Builder - Class in org.elasticsearch.search.suggest.context
-
- 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(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() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- cause(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The cause for this index template creation.
- cause() - Method in class org.elasticsearch.repositories.VerificationFailure
-
- cause() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns restore operation cause
- cause() - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Returns cause for snapshot operation
- causeToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
-
- causeToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.ElasticsearchException
-
Renders a cause exception as xcontent
- cborBuilder() - Static method in class org.elasticsearch.common.xcontent.XContentFactory
-
- cborBuilder(OutputStream) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
-
Constructs a new cbor builder that will output the result into the provided output stream.
- CborXContent - Class in org.elasticsearch.common.xcontent.cbor
-
A CBOR based content implementation using Jackson.
- cborXContent - Static variable in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- CborXContentGenerator - Class in org.elasticsearch.common.xcontent.cbor
-
- CborXContentGenerator(JsonGenerator, OutputStream, String...) - Constructor for class org.elasticsearch.common.xcontent.cbor.CborXContentGenerator
-
- CborXContentParser - Class in org.elasticsearch.common.xcontent.cbor
-
- CborXContentParser(JsonParser) - Constructor for class org.elasticsearch.common.xcontent.cbor.CborXContentParser
-
- cbrt(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cbrt(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cbrt(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cbrt(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cbrt(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- CCW - Static variable in enum org.elasticsearch.common.geo.builders.ShapeBuilder.Orientation
-
- ceil(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- ceil(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- ceil(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- ceil(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- ceil(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- Cell(Object, Table.Cell) - Constructor for class org.elasticsearch.common.Table.Cell
-
- Cell(Object) - Constructor for class org.elasticsearch.common.Table.Cell
-
- Cell(Object, Map<String, String>) - Constructor for class org.elasticsearch.common.Table.Cell
-
- center(Coordinate) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
Set the center of the circle
- center(double, double) - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
set the center of the circle
- centroid() - Method in interface org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroid
-
- centroid - Variable in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- centroid() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- changed() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
-
- changesAllowed() - Method in class org.elasticsearch.indices.IndicesService
-
Returns true if changes (adding / removing) indices, shards and so on are allowed.
- channel - Variable in class org.elasticsearch.index.translog.TranslogReader
-
- channel - Variable in class org.elasticsearch.rest.action.support.RestActionListener
-
- channel(TransportRequestOptions.Type) - Method in class org.elasticsearch.transport.netty.NettyTransport.NodeChannels
-
- ChannelBufferBytesReference - Class in org.elasticsearch.common.bytes
-
- ChannelBufferBytesReference(ChannelBuffer) - Constructor for class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- ChannelBufferStreamInput - Class in org.elasticsearch.transport.netty
-
- ChannelBufferStreamInput(ChannelBuffer) - Constructor for class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- ChannelBufferStreamInput(ChannelBuffer, int) - Constructor for class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- ChannelBufferStreamInputFactory - Class in org.elasticsearch.transport.netty
-
- ChannelBufferStreamInputFactory() - Constructor for class org.elasticsearch.transport.netty.ChannelBufferStreamInputFactory
-
- channelReference - Variable in class org.elasticsearch.index.translog.TranslogReader
-
- Channels - Class in org.elasticsearch.common.io
-
- channelScore(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- CHAR_FILTERS - Static variable in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction.Fields
-
- charAt(int) - Method in class org.elasticsearch.common.io.FastStringReader
-
- charFilter(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
-
- CharFilteredText(String, String[]) - Constructor for class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.CharFilteredText
-
- charFilterFactories() - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- CharFilterFactory - Interface in org.elasticsearch.index.analysis
-
- CharFilterFactoryFactory - Interface in org.elasticsearch.index.analysis
-
- charFilterFactoryFactory(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- charFilters(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- charFilters() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- 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.index.analysis.CustomAnalyzer
-
- CharFiltersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.CharFiltersBindings
-
- CharMatcher - Interface in org.elasticsearch.index.analysis
-
A class to match character code points.
- CharMatcher.Basic - Enum in org.elasticsearch.index.analysis
-
- CharMatcher.Builder - Class in org.elasticsearch.index.analysis
-
- CharMatcher.ByUnicodeCategory - Class in org.elasticsearch.index.analysis
-
- CharSequenceReader - Class in org.elasticsearch.common.io
-
- CharSequenceReader() - Constructor for class org.elasticsearch.common.io.CharSequenceReader
-
- charTermAttr - Variable in class org.elasticsearch.search.suggest.SuggestUtils.TokenConsumer
-
- checkAndNotify() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
- checkAndNotify() - Method in interface org.elasticsearch.watcher.ResourceWatcher
-
- 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(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(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(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(DeleteWarmerRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
-
- checkBlock(GetWarmersRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.warmer.get.TransportGetWarmersAction
-
- checkBlock(PutWarmerRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
-
- checkBlock(Request, ClusterState) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
-
- checkChronology(Chronology) - Method in class org.joda.time.base.BaseDateTime
-
Checks the specified chronology before storing it, potentially altering it.
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.NumberFieldType
-
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.FieldNamesFieldType
-
- checkCompatibility(MappedFieldType, List<String>, boolean) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Checks for any conflicts between this field type and other.
- checkCorsSettingForRegex(String) - Static method in class org.elasticsearch.rest.support.RestUtils
-
Determine if CORS setting is a regex
- CheckFileCommand - Class in org.elasticsearch.common.cli
-
A helper command that checks if configured paths have been changed when running a CLI command.
- CheckFileCommand(Terminal) - Constructor for class org.elasticsearch.common.cli.CheckFileCommand
-
- checkForCancel() - Method in class org.elasticsearch.common.util.CancellableThreads
-
call this will throw an exception if operation was cancelled.
- 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.
- checkForOfficialPlugins(String) - Static method in class org.elasticsearch.plugins.PluginManager
-
- checkForTimeout(long) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- 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, 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, ExistsRequest) - Method in class org.elasticsearch.action.exists.TransportExistsAction
-
- checkGlobalBlock(ClusterState, FieldStatsRequest) - Method in class org.elasticsearch.action.fieldstats.TransportFieldStatsTransportAction
-
- checkGlobalBlock(ClusterState, PercolateRequest) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
-
- checkGlobalBlock(ClusterState, SuggestRequest) - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
-
- 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
-
- 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, DfsOnlyRequest) - Method in class org.elasticsearch.action.termvectors.dfs.TransportDfsOnlyAction
-
- checkIdle(long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Called by
IndexingMemoryController
to check whether more than
inactiveTimeNS
has passed since the last
indexing operation, and become inactive (reducing indexing and translog buffers to tiny values) if so.
- checkIdle(IndexShard, long) - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
-
ask this shard to check now whether it is inactive, and reduces its indexing and translog buffers if so.
- checkIndex(ShardPath) - Method in class org.elasticsearch.common.util.MultiDataPathUpgrader
-
Runs check-index on the target shard and throws an exception if it failed
- checkIndexTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
-
- checkIndexTime(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
-
- checkInstant(long, Chronology) - Method in class org.joda.time.base.BaseDateTime
-
Checks the specified instant before storing it, potentially altering it.
- checkIntegrity() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
-
Deprecated.
- 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
-
- checkJarHell() - Static method in class org.elasticsearch.bootstrap.JarHell
-
Checks the current classpath for duplicate classes
- checkJarHell(URL[]) - Static method in class org.elasticsearch.bootstrap.JarHell
-
Checks the set of URLs for duplicate classes
- checkJavaVersion(String, String) - Static method in class org.elasticsearch.bootstrap.JarHell
-
Checks that the java specification version targetVersion
required by resource
is compatible with the current installation.
- checkNoRemainingFields(String, Map<String, Object>, Version) - Static method in class org.elasticsearch.index.mapper.DocumentMapperParser
-
- checkNoRemainingFields(Map<String, Object>, 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(long, int, ChannelReference) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
- CHECKPOINT_FILE_NAME - Static variable in class org.elasticsearch.index.translog.Translog
-
- CHECKPOINT_SUFFIX - Static variable in class org.elasticsearch.index.translog.Translog
-
- checkRequestBlock(ClusterState, TransportSingleShardAction<AnalyzeRequest, AnalyzeResponse>.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
-
- 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, TransportSingleShardAction<GetFieldMappingsIndexRequest, GetFieldMappingsResponse>.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
-
- 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, ExistsRequest, String[]) - Method in class org.elasticsearch.action.exists.TransportExistsAction
-
- checkRequestBlock(ClusterState, FieldStatsRequest, String[]) - Method in class org.elasticsearch.action.fieldstats.TransportFieldStatsTransportAction
-
- checkRequestBlock(ClusterState, PercolateRequest, String[]) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
-
- checkRequestBlock(ClusterState, SuggestRequest, String[]) - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
-
- 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
-
- checkRequestBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
- checkRequestBlock(ClusterState, TransportSingleShardAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
- checkRequestBlock(ClusterState, DfsOnlyRequest, String[]) - Method in class org.elasticsearch.action.termvectors.dfs.TransportDfsOnlyAction
-
- checkSegmentInfoIntegrity(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
- checksum(byte[]) - Method in interface org.elasticsearch.common.http.client.HttpDownloadHelper.Checksummer
-
Return the hex string for the given byte array
- checksum() - Method in class org.elasticsearch.index.shard.CommitPoint.FileInfo
-
- 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, FromXContentBuilder<T>, ParseFieldMatcher, boolean, XContentType) - Constructor for class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
- ChecksumBlobStoreFormat(String, String, FromXContentBuilder<T>, ParseFieldMatcher, boolean) - Constructor for class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
- CHECKSUMS_PREFIX - Static variable in class org.elasticsearch.index.store.Store
-
- checkUnrecognizedParams(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel.AbstractModelParser
-
- checkVersionFormat(String) - Static method in class org.elasticsearch.bootstrap.JarHell
-
- checkWriteConsistency() - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
-
- checkWriteConsistency() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
-
- checkWriteConsistency() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
True if write consistency should be checked for an implementation
- childBindingAlreadySet(Key<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
-
- childFilter - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- ChildMemoryCircuitBreaker - Class in org.elasticsearch.common.breaker
-
Breaker that will check a parent's when incrementing
- ChildMemoryCircuitBreaker(BreakerSettings, ESLogger, 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, ESLogger, 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.
- childQuery - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- children - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder.CoordinateNode
-
- children(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Children
aggregation with the given name.
- Children - Interface in org.elasticsearch.search.aggregations.bucket.children
-
An single bucket aggregation that translates parent documents to their children documents.
- ChildrenBuilder - Class in org.elasticsearch.search.aggregations.bucket.children
-
- ChildrenBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.children.ChildrenBuilder
-
Sole constructor.
- ChildrenConstantScoreQuery - Class in org.elasticsearch.index.search.child
-
- ChildrenConstantScoreQuery(IndexParentChildFieldData, Query, String, String, Filter, int, BitSetProducer) - Constructor for class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
-
Deprecated.
- ChildrenParser - Class in org.elasticsearch.search.aggregations.bucket.children
-
- ChildrenParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.children.ChildrenParser
-
- ChildrenQuery - Class in org.elasticsearch.index.search.child
-
- ChildrenQuery(ParentChildIndexFieldData, String, String, Filter, Query, ScoreType, int, int, int, BitSetProducer) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- ChildrenQuery.ParentCollector - Class in org.elasticsearch.index.search.child
-
Deprecated.
- ChildrenQuery.ParentScoreCollector - Class in org.elasticsearch.index.search.child
-
Deprecated.
- ChildrenQuery.ParentScoreCountCollector - Class in org.elasticsearch.index.search.child
-
Deprecated.
- ChildrenQuery.ParentWeight - Class in org.elasticsearch.index.search.child
-
Deprecated.
- ChildTaskActionRequest<Request extends ActionRequest<Request>> - Class in org.elasticsearch.action.support
-
Base class for action requests that can have associated child tasks
- ChildTaskActionRequest() - Constructor for class org.elasticsearch.action.support.ChildTaskActionRequest
-
- ChildTaskActionRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.ChildTaskActionRequest
-
- ChildTaskRequest - Class in org.elasticsearch.action.support
-
Base class for requests that can have associated child tasks
- ChildTaskRequest() - Constructor for class org.elasticsearch.action.support.ChildTaskRequest
-
- ChildTaskRequest(TransportRequest) - Constructor for class org.elasticsearch.action.support.ChildTaskRequest
-
- childType - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- childType(String) - Method in class org.elasticsearch.search.aggregations.bucket.children.ChildrenBuilder
-
Set the type of children documents.
- childWeight - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
-
Deprecated.
- ChineseAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
Only for old indexes
- ChineseAnalyzerProvider(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ChineseAnalyzerProvider
-
- 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.ChiSquareBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- ChiSquare.ChiSquareParser - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- ChiSquareBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare.ChiSquareBuilder
-
- ChiSquareParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare.ChiSquareParser
-
- chooseStorageFormat(LeafReader, PackedLongValues, Ordinals, RandomAccessOrds, long, long, float, int) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData
-
- chunkSize() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns data file chunk size.
- chunkSize() - Method in class org.elasticsearch.repositories.fs.FsRepository
-
Returns data file chunk size.
- cidrMaskToMinMax(String) - Static method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
-
Computes the min & max ip addresses (represented as long values -
same way as stored in index) represented by the given CIDR mask
expression.
- circle(CircleBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- CircleBuilder - Class in org.elasticsearch.common.geo.builders
-
- CircleBuilder() - Constructor for class org.elasticsearch.common.geo.builders.CircleBuilder
-
- 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.MemoryCircuitBreaker
-
Method used to trip the 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
-
- CircuitBreakerModule - Class in org.elasticsearch.indices.breaker
-
- CircuitBreakerModule(Settings) - Constructor for class org.elasticsearch.indices.breaker.CircuitBreakerModule
-
- CircuitBreakerService - Class in org.elasticsearch.indices.breaker
-
Interface for Circuit Breaker services, which provide breakers to classes
that load field data.
- CircuitBreakerService(Settings) - 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
-
- 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(StreamInput) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
-
- CircuitBreakingException(String, long, long) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
-
- CjkAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- CjkAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CjkAnalyzerProvider
-
- CJKBigramFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory that creates a CJKBigramFilter
to form bigrams of CJK terms
that are generated from StandardTokenizer or ICUTokenizer.
- CJKBigramFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CJKBigramFilterFactory
-
- CJKWidthFilterFactory - Class in org.elasticsearch.index.analysis
-
- CJKWidthFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CJKWidthFilterFactory
-
- Classes - Class in org.elasticsearch.common
-
- Classes(long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Classes
-
- ClassicFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory for ClassicFilter
- ClassicFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ClassicFilterFactory
-
- ClassicTokenizerFactory - Class in org.elasticsearch.index.analysis
-
Factory for ClassicTokenizer
- ClassicTokenizerFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ClassicTokenizerFactory
-
- ClassMap(String, Class<T>, Set<String>, Class<?>...) - Constructor for class org.elasticsearch.common.util.ExtensionPoint.ClassMap
-
- 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.
- ClassSet(String, Class<T>, Class<?>...) - Constructor for class org.elasticsearch.common.util.ExtensionPoint.ClassSet
-
- clause(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
- clause(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
-
- CLEAN_FILES - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
-
- cleanCaches(Injector) - Static method in class org.elasticsearch.common.inject.Injectors
-
- cleanLuceneIndex(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
This method removes all lucene files from the given directory.
- cleanOpenFiles() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- cleanPath() - Static method in class org.elasticsearch.common.blobstore.BlobPath
-
- cleanPath(String) - Static method in class org.elasticsearch.common.Strings
-
Normalize the path by suppressing sequences like "path/.." and
inner simple dots.
- cleanTruncate(String, int) - Static method in class org.elasticsearch.common.Strings
-
Truncates string to a length less than length.
- 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.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.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.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 class org.elasticsearch.common.util.MinimalMap
-
- 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.index.IndexQueryCache
-
- clear(String) - Method in class org.elasticsearch.index.cache.query.none.NoneQueryCache
-
- clear(String) - Method in interface org.elasticsearch.index.cache.query.QueryCache
-
- 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(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() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
-
- clear(String) - 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.DocValuesIndexFieldData
-
- clear(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
-
- clear() - Method in class org.elasticsearch.index.fielddata.plain.IndexIndexFieldData
-
- clear() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.GlobalFieldData
-
- clear() - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- clear() - Method in class org.elasticsearch.index.percolator.PercolatorQueriesRegistry
-
- clear() - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
-
- clear() - Method in class org.elasticsearch.index.store.Store.LegacyChecksums
-
- clear(IndexShard) - Method in class org.elasticsearch.indices.cache.request.IndicesRequestCache
-
- clear() - Method in class org.elasticsearch.search.lookup.FieldLookup
-
- clear() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
-
- clear() - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
-
- clear() - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- clear() - Method in class org.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttributeImpl
-
- CLEAR_SCROLL_CONTEXTS_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- 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.
- 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.cache.query.IndicesQueryCache
-
Clear all entries that belong to the given index.
- ClearIndicesCacheAction - Class in org.elasticsearch.action.admin.indices.cache.clear
-
- 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
-
- clearIndicesCacheRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a clean indices cache request.
- 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 refresh 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(ClearScrollRequest) - Method in interface org.elasticsearch.client.Client
-
Clears the search contexts associated with specified scroll ids.
- 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
-
- clearScroll(ClearScrollRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
- ClearScrollAction - Class in org.elasticsearch.action.search
-
- ClearScrollContextsRequest() - Constructor for class org.elasticsearch.search.action.SearchServiceTransportAction.ClearScrollContextsRequest
-
- ClearScrollRequest - Class in org.elasticsearch.action.search
-
- ClearScrollRequest() - Constructor for class org.elasticsearch.action.search.ClearScrollRequest
-
- ClearScrollRequest(ActionRequest) - Constructor for class org.elasticsearch.action.search.ClearScrollRequest
-
Creates a clear scroll request caused by some other request, which is provided as an
argument so that its headers and context can be copied to the new request
- 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.ping.unicast.UnicastZenPing
-
Clears the list of cached ping responses.
- client - Variable in class org.elasticsearch.action.ActionRequestBuilder
-
- Client - Interface in org.elasticsearch.client
-
A client provides a one stop interface for performing actions/operations against the cluster.
- client() - Method in class org.elasticsearch.node.Node
-
A client that can be used to execute actions (operations) against the cluster.
- client(boolean) - Method in class org.elasticsearch.node.NodeBuilder
-
Is the node going to be a client node which means it will hold no data (node.data is
set to false) and other optimizations by different modules.
- CLIENT_ATTR - Static variable in class org.elasticsearch.cluster.node.DiscoveryNode
-
- CLIENT_TYPE - Static variable in class org.elasticsearch.client.transport.TransportClient
-
- CLIENT_TYPE_SETTING - Static variable in interface org.elasticsearch.client.Client
-
- clientBootstrap - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- ClientChannelPipelineFactory(NettyTransport) - Constructor for class org.elasticsearch.transport.netty.NettyTransport.ClientChannelPipelineFactory
-
- clientNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
- clientNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Is the node a client node or not.
- ClientTransportModule - Class in org.elasticsearch.client.transport
-
- ClientTransportModule() - Constructor for class org.elasticsearch.client.transport.ClientTransportModule
-
- CliTool - Class in org.elasticsearch.common.cli
-
A base class for command-line interface tool.
- CliTool(CliToolConfig) - Constructor for class org.elasticsearch.common.cli.CliTool
-
- CliTool(CliToolConfig, Terminal) - Constructor for class org.elasticsearch.common.cli.CliTool
-
- CliTool.Command - Class in org.elasticsearch.common.cli
-
- CliTool.Command.Exit - Class in org.elasticsearch.common.cli
-
- CliTool.Command.Help - Class in org.elasticsearch.common.cli
-
- CliTool.ExitStatus - Enum in org.elasticsearch.common.cli
-
- CliToolConfig - Class in org.elasticsearch.common.cli
-
- CliToolConfig.Builder - Class in org.elasticsearch.common.cli
-
- CliToolConfig.Cmd - Class in org.elasticsearch.common.cli
-
- CliToolConfig.Cmd.Builder - Class in org.elasticsearch.common.cli
-
- CliToolConfig.OptionBuilder - Class in org.elasticsearch.common.cli
-
- CliToolConfig.OptionGroupBuilder - Class in org.elasticsearch.common.cli
-
- 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.compress.CompressedIndexInput
-
Deprecated.
- clone() - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
-
Deprecated.
- clone() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
-
- clone() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.BooleanFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.DoubleFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.LongFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- clone() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.NumberFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- clone() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.StringFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
- clone() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.FieldNamesFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.TimestampFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.TTLFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- clone() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- clone() - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
-
- clone() - Method in class org.elasticsearch.index.translog.ImmutableTranslogReader
-
- 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.apache.lucene.store.RateLimitedFSDirectory
-
- close() - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- close() - Method in class org.elasticsearch.cache.recycler.PageCacheRecycler
-
- close() - Method in class org.elasticsearch.client.FilterClient
-
- close(CloseIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Closes an index based on the index name.
- close(CloseIndexRequest, ActionListener<CloseIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Closes an index based on the index name.
- close() - 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.client.transport.TransportClientNodesService
-
- close() - Method in class org.elasticsearch.common.Base64.OutputStream
-
Flushes and closes (I think, in the superclass) the stream.
- close() - Method in interface org.elasticsearch.common.blobstore.BlobStore
-
- close() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
-
- close() - Method in class org.elasticsearch.common.blobstore.url.URLBlobStore
- 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.compress.CompressedIndexInput
-
Deprecated.
- close() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
- close() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
Close the shell of the polygon
- close() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder.Ring
-
- close() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder.InternalPolygonBuilder
-
- close() - Method in class org.elasticsearch.common.geo.builders.PolygonBuilder
-
- close() - Method in class org.elasticsearch.common.io.FastCharArrayReader
-
Closes the stream and releases any system resources associated with
it.
- close() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Close the stream.
- close() - Method in class org.elasticsearch.common.io.FastStringReader
-
Closes the stream and releases any system resources associated with
it.
- 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.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(Iterable<? extends Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
-
- close(Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
-
- close(boolean, Iterable<Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Release the provided
Releasable
s, ignoring exceptions if
success
is
false.
- close(boolean, Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
-
Release the provided
Releasable
s, ignoring exceptions if
success
is
false.
- close() - Method in class org.elasticsearch.common.logging.log4j.TerminalAppender
-
- close() - Method in class org.elasticsearch.common.lucene.all.AllEntries
-
- 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 class org.elasticsearch.common.netty.OpenChannelsHandler
-
- 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.util.BytesRefHash
-
- close() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
-
- 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.xcontent.json.JsonXContentGenerator
-
- close() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- close() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- close() - Method in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- close() - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
-
- close() - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
-
- close() - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction
-
- close() - Method in class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
-
- close() - Method in class org.elasticsearch.env.NodeEnvironment
-
- close() - Method in class org.elasticsearch.env.ShardLock
-
- close() - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
- close() - Method in class org.elasticsearch.index.analysis.AnalysisService
-
- close() - Method in class org.elasticsearch.index.analysis.NumericTokenizer
-
- 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.index.IndexQueryCache
-
- close() - Method in class org.elasticsearch.index.cache.query.none.NoneQueryCache
-
- close() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsConsumer
-
Deprecated.
- close() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
-
Deprecated.
- close() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommit
-
Releases the current snapshot.
- close() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommits
-
- close() - Method in class org.elasticsearch.index.engine.Engine
-
- close() - Method in class org.elasticsearch.index.engine.Engine.Searcher
-
- close() - Method in class org.elasticsearch.index.engine.EngineSearcher
-
- close() - Method in class org.elasticsearch.index.engine.RecoveryCounter
-
- 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.GeoPointArrayAtomicFieldData
-
- close() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointArrayLegacyAtomicFieldData
-
- close() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
-
- close() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildAtomicFieldData
-
- close() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVBytesAtomicFieldData
-
- close(String, boolean) - Method in class org.elasticsearch.index.IndexService
-
- close() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- close() - Method in class org.elasticsearch.index.mapper.MapperService
-
- close() - Method in class org.elasticsearch.index.percolator.PercolatorQueriesRegistry
-
- close() - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- close() - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- close() - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCollector
-
Deprecated.
- close() - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCountCollector
-
Deprecated.
- close(String, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
- close() - Method in class org.elasticsearch.index.shard.StoreRecoveryService
-
- close() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
- close() - Method in class org.elasticsearch.index.store.IndexStore
-
- close() - Method in class org.elasticsearch.index.store.Store
-
- close() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
-
- 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.Translog.View
-
- close() - Method in class org.elasticsearch.index.translog.TranslogReader
-
- close() - Method in class org.elasticsearch.index.translog.TranslogService
-
- close() - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- close() - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache
-
- close() - Method in class org.elasticsearch.indices.cache.request.IndicesRequestCache
-
- close() - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
-
- close() - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection.StatusRef
-
- close() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- close() - Method in class org.elasticsearch.indices.store.IndicesStore
-
- close() - Method in class org.elasticsearch.node.Node
-
- close() - Method in class org.elasticsearch.percolator.PercolatorService
-
- close() - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
-
- close() - Method in class org.elasticsearch.rest.RestFilter
-
- close() - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
-
- close() - Method in class org.elasticsearch.script.NativeScriptEngineService
-
- close() - Method in class org.elasticsearch.script.ScriptService
-
- close() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Called upon release of the aggregator.
- close() - Method in class org.elasticsearch.search.aggregations.bucket.BestDocsDeferringCollector
-
- 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.significant.SignificantTermsAggregatorFactory
-
- 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.suggest.completion.CompletionTokenStream
-
- close() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- close() - Method in class org.elasticsearch.transport.netty.NettyTransport.NodeChannels
-
- closed() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns true if the state is closed.
- closed - Variable in class org.elasticsearch.index.translog.TranslogReader
-
- closeIndex(CloseIndexClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexStateService
-
- 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
- CloseIndexRequest - Class in org.elasticsearch.action.admin.indices.close
-
A request to close an index.
- CloseIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
- CloseIndexRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Constructs a new close index request for the specified index.
- closeIndexRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a close index request.
- CloseIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.close
-
Builder for close index request
- CloseIndexRequestBuilder(ElasticsearchClient, CloseIndexAction) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
-
- CloseIndexRequestBuilder(ElasticsearchClient, CloseIndexAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
-
- CloseIndexResponse - Class in org.elasticsearch.action.admin.indices.close
-
A response for a close index action.
- 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.RecoveryStatus
-
- closeNoLock(String) - Method in class org.elasticsearch.index.engine.Engine
-
Method to close the engine while the write lock is held.
- closeNoLock(String) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Closes the engine without acquiring the write lock.
- closeNoLock(String) - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- 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.
- closeWithTragicEvent(Throwable) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
- closeWriter() - Method in class org.elasticsearch.common.logging.log4j.ConsoleAppender
- cluster() - Method in interface org.elasticsearch.client.AdminClient
-
A client allowing to perform actions/operations against the cluster.
- CLUSTER_BYTES_SIZE_SETTINGS - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
All known byte-sized cluster settings.
- CLUSTER_READ_ONLY_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- CLUSTER_ROUTING_ALLOCATION_ALLOW_REBALANCE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
-
- CLUSTER_ROUTING_ALLOCATION_AWARENESS_ATTRIBUTES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
-
- CLUSTER_ROUTING_ALLOCATION_AWARENESS_FORCE_GROUP - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
-
- CLUSTER_ROUTING_ALLOCATION_CLUSTER_CONCURRENT_REBALANCE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
-
- CLUSTER_ROUTING_ALLOCATION_CONCURRENT_RECOVERIES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
-
- CLUSTER_ROUTING_ALLOCATION_DISABLE_ALLOCATION - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
-
Deprecated.
- CLUSTER_ROUTING_ALLOCATION_DISABLE_NEW_ALLOCATION - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
-
Deprecated.
- CLUSTER_ROUTING_ALLOCATION_DISABLE_REPLICA_ALLOCATION - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
-
Deprecated.
- CLUSTER_ROUTING_ALLOCATION_DISK_THRESHOLD_ENABLED - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- CLUSTER_ROUTING_ALLOCATION_ENABLE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
-
- CLUSTER_ROUTING_ALLOCATION_HIGH_DISK_WATERMARK - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- CLUSTER_ROUTING_ALLOCATION_INCLUDE_RELOCATIONS - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- CLUSTER_ROUTING_ALLOCATION_LOW_DISK_WATERMARK - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- CLUSTER_ROUTING_ALLOCATION_NODE_CONCURRENT_RECOVERIES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
-
- CLUSTER_ROUTING_ALLOCATION_NODE_INITIAL_PRIMARIES_RECOVERIES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
-
- CLUSTER_ROUTING_ALLOCATION_REROUTE_INTERVAL - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- CLUSTER_ROUTING_ALLOCATION_SNAPSHOT_RELOCATION_ENABLED - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
-
Disables relocation of shards that are currently being snapshotted.
- CLUSTER_ROUTING_EXCLUDE_GROUP - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
-
- CLUSTER_ROUTING_INCLUDE_GROUP - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
-
- CLUSTER_ROUTING_REBALANCE_ENABLE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
-
- CLUSTER_ROUTING_REQUIRE_GROUP - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
-
- CLUSTER_TIME_SETTINGS - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
All known time cluster settings.
- CLUSTER_TOTAL_SHARDS_PER_NODE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
-
Controls the maximum number of shards per node on a global level.
- ClusterAdminClient - Interface in org.elasticsearch.client
-
Administrative actions/operations against indices.
- ClusterBlock - Class in org.elasticsearch.cluster.block
-
- ClusterBlock(int, String, boolean, boolean, RestStatus, EnumSet<ClusterBlockLevel>) - Constructor for class org.elasticsearch.cluster.block.ClusterBlock
-
- ClusterBlockException - Exception in org.elasticsearch.cluster.block
-
- ClusterBlockException(ImmutableSet<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.Builder - Class in org.elasticsearch.cluster.block
-
- 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.MetaDataUpdateSettingsService
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.routing.RoutingService
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.Gateway
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.GatewayMetaState
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.GatewayService
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.indices.store.IndicesStore
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.node.settings.NodeSettingsService
-
- clusterChanged(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.
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.RestoreService
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.SnapshotShardsService
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.tasks.TaskManager
-
- 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
-
- ClusterDynamicSettings - Annotation Type in org.elasticsearch.cluster.settings
-
- ClusterHealthAction - Class in org.elasticsearch.action.admin.cluster.health
-
- 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(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a cluster health request.
- 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
-
- 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, see
InternalClusterInfoService.shardIdentifierFromRouting(String)
for the key used in the shardSizes map
- ClusterInfo() - Constructor for class org.elasticsearch.cluster.ClusterInfo
-
- ClusterInfo(Map<String, DiskUsage>, Map<String, DiskUsage>, Map<String, Long>, Map<ShardRouting, String>) - Constructor for class org.elasticsearch.cluster.ClusterInfo
-
Creates a new ClusterInfo instance.
- clusterInfo() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
- ClusterInfoRequest<T extends ClusterInfoRequest<T>> - Class in org.elasticsearch.action.support.master.info
-
- ClusterInfoRequest() - 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
- ClusterInfoService.Listener - Interface in org.elasticsearch.cluster
-
Interface for listeners to implement in order to perform actions when
new information about the cluster has been gathered
- ClusterModule - Class in org.elasticsearch.cluster
-
Configures classes and services that affect the entire cluster.
- ClusterModule(Settings) - Constructor for class org.elasticsearch.cluster.ClusterModule
-
- clusterName - Variable in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
-
- clusterName - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
- clusterName - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
- ClusterName - Class in org.elasticsearch.cluster
-
- ClusterName(String) - Constructor for class org.elasticsearch.cluster.ClusterName
-
- clusterName - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- clusterName() - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.PingRequest
-
- clusterName() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
-
- clusterName(String) - Method in class org.elasticsearch.node.NodeBuilder
-
The cluster name this node is part of (maps to the cluster.name setting).
- clusterNameFromSettings(Settings) - Static method in class org.elasticsearch.cluster.ClusterName
-
- ClusterNameModule - Class in org.elasticsearch.cluster
-
- ClusterNameModule(Settings) - Constructor for class org.elasticsearch.cluster.ClusterNameModule
-
- 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, NodeSettingsService) - 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 - Class in org.elasticsearch.action.admin.cluster.reroute
-
Request to submit cluster reroute allocation commands
- ClusterRerouteRequest() - Constructor for class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
- clusterRerouteRequest() - Static method in class org.elasticsearch.client.Requests
-
- 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
- ClusterSearchShardsAction - Class in org.elasticsearch.action.admin.cluster.shards
-
- ClusterSearchShardsGroup - Class in org.elasticsearch.action.admin.cluster.shards
-
- ClusterSearchShardsGroup(String, int, ShardRouting[]) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
-
- ClusterSearchShardsRequest - Class in org.elasticsearch.action.admin.cluster.shards
-
- ClusterSearchShardsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
- ClusterSearchShardsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
- clusterSearchShardsRequest() - 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
- 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[]) - 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 - Interface in org.elasticsearch.cluster
-
- ClusterShardHealth - Class in org.elasticsearch.cluster.health
-
- ClusterShardHealth(int, IndexShardRoutingTable) - Constructor for class org.elasticsearch.cluster.health.ClusterShardHealth
-
- 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>, boolean) - Constructor for class org.elasticsearch.cluster.ClusterState
-
- ClusterState.Builder - Class in org.elasticsearch.cluster
-
- ClusterState.ClusterStateStatus - Enum in org.elasticsearch.cluster
-
- ClusterState.Custom - Interface in org.elasticsearch.cluster
-
- ClusterState.Metric - Enum in org.elasticsearch.cluster
-
- ClusterStateAction - Class in org.elasticsearch.action.admin.cluster.state
-
- ClusterStateHealth - Class in org.elasticsearch.cluster.health
-
- ClusterStateHealth(int, int, int, int, int, int, int, double, ClusterHealthStatus, List<String>, Map<String, ClusterIndexHealth>) - Constructor for class org.elasticsearch.cluster.health.ClusterStateHealth
-
Full constructor which is only intended to provide wire-compatibility for 2.x.
- ClusterStateHealth(MetaData, RoutingTable) - Constructor for class org.elasticsearch.cluster.health.ClusterStateHealth
-
Creates a new ClusterStateHealth
instance based on cluster meta data and its routing table as a convenience.
- 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.
- ClusterStateListener - Interface in org.elasticsearch.cluster
-
A listener to be notified when a cluster state changes.
- ClusterStateNonMasterUpdateTask - Class in org.elasticsearch.cluster
-
This is a marker interface to indicate that the task should be executed
even if the current node is not a master.
- ClusterStateNonMasterUpdateTask() - Constructor for class org.elasticsearch.cluster.ClusterStateNonMasterUpdateTask
-
- 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(ClusterService, ESLogger) - Constructor for class org.elasticsearch.cluster.ClusterStateObserver
-
- ClusterStateObserver(ClusterService, TimeValue, ESLogger) - Constructor for class org.elasticsearch.cluster.ClusterStateObserver
-
- ClusterStateObserver.ChangePredicate - Interface in org.elasticsearch.cluster
-
- ClusterStateObserver.EventPredicate - Class in org.elasticsearch.cluster
-
- ClusterStateObserver.Listener - Interface in org.elasticsearch.cluster
-
- ClusterStateObserver.ValidationPredicate - Class in org.elasticsearch.cluster
-
- clusterStateProcessed(String, ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.AbstractAckedClusterStateTaskListener
-
- clusterStateProcessed(String, ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.AbstractClusterStateTaskListener
-
- clusterStateProcessed(String, ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
- clusterStateProcessed(String, ClusterState, ClusterState) - Method in interface org.elasticsearch.cluster.ClusterStateTaskListener
-
- clusterStateProcessed(String, ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
- clusterStatePublished(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor
-
Callback invoked after new cluster state is published.
- ClusterStateRequest - Class in org.elasticsearch.action.admin.cluster.state
-
- ClusterStateRequest() - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
-
- clusterStateRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a cluster state request.
- 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
-
- ClusterStateResponse() - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
-
- ClusterStateResponse(ClusterName, ClusterState) - 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
- ClusterStateTaskExecutor<T> - Class in org.elasticsearch.cluster
-
- ClusterStateTaskExecutor() - Constructor for class org.elasticsearch.cluster.ClusterStateTaskExecutor
-
- ClusterStateTaskExecutor.BatchResult<T> - Class in org.elasticsearch.cluster
-
Represents the result of a batched execution of cluster state update tasks
- ClusterStateTaskExecutor.BatchResult.Builder<T> - Class in org.elasticsearch.cluster
-
- ClusterStateTaskExecutor.TaskResult - Class in org.elasticsearch.cluster
-
- ClusterStateTaskExecutor.TaskResult.FailureConsumer - Interface 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.fd.NodesFaultDetection.PingRequest
-
- 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(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(ClusterStatsNodeResponse[]) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
-
- ClusterStatsNodes.Counts - Class in org.elasticsearch.action.admin.cluster.stats
-
- ClusterStatsNodes.JvmStats - Class in org.elasticsearch.action.admin.cluster.stats
-
- ClusterStatsNodes.JvmVersion - Class in org.elasticsearch.action.admin.cluster.stats
-
- ClusterStatsNodes.OsStats - Class in org.elasticsearch.action.admin.cluster.stats
-
- ClusterStatsNodes.ProcessStats - Class in org.elasticsearch.action.admin.cluster.stats
-
- ClusterStatsRequest - Class in org.elasticsearch.action.admin.cluster.stats
-
A request to get cluster level stats.
- ClusterStatsRequest() - 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.
- clusterStatsRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a cluster stats request.
- 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, ClusterName, String, ClusterStatsNodeResponse[]) - 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 - Class in org.elasticsearch.action.admin.cluster.settings
-
Request for an update cluster settings action
- ClusterUpdateSettingsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
- clusterUpdateSettingsRequest() - Static method in class org.elasticsearch.client.Requests
-
- 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(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- clusterUUID() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- cmd(String, Class<? extends CliTool.Command>) - Static method in class org.elasticsearch.common.cli.CliToolConfig.Builder
-
- cmd(String) - Method in class org.elasticsearch.common.cli.CliToolConfig
-
- cmds(CliToolConfig.Cmd.Builder...) - Method in class org.elasticsearch.common.cli.CliToolConfig.Builder
-
- cmds(CliToolConfig.Cmd...) - Method in class org.elasticsearch.common.cli.CliToolConfig.Builder
-
- cmds() - Method in class org.elasticsearch.common.cli.CliToolConfig
-
- cmdType() - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd
-
- coalesceToEmpty(String) - Static method in class org.elasticsearch.common.Strings
-
- codec(String) - Method in class org.elasticsearch.index.codec.CodecService
-
- CODEC_NAME - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- CODEC_NAME - Static variable in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
-
- CODEC_VERSION_CHECKSUMS - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- CODEC_VERSION_LATEST - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- CODEC_VERSION_SERIALIZED_LABELS - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- CODEC_VERSION_START - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- 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(Index) - Constructor for class org.elasticsearch.index.codec.CodecService
-
- CodecService(Index, Settings) - Constructor for class org.elasticsearch.index.codec.CodecService
-
- CodecService(Index, IndexSettingsService, MapperService) - Constructor for class org.elasticsearch.index.codec.CodecService
-
- coerce(boolean) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
-
- coerce(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
-
- coerce - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- COERCE - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
-
- coerce(boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy.Builder
-
- coerce(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy.Builder
-
- coerce - Variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy
-
- COERCE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy.Defaults
-
- COERCE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy.Names
-
- coerce(boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
-
- coerce(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
-
- coerce - Variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
-
- coerce() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
-
- COERCE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
-
- COERCE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
-
- coerce(boolean) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
- coerce(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
- coerce(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- coerce(boolean) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
- coerce(boolean) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
- collateMatch() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
-
- collateParams(Map<String, Object>) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets additional params for collate script
- collatePrune(boolean) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets whether to prune suggestions after collation
- collateQuery(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets a query used for filtering out suggested phrases (collation).
- collateQuery(Template) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets a query used for filtering out suggested phrases (collation).
- collect(int) - Method in class org.elasticsearch.common.lucene.Lucene.EarlyTerminatingCollector
-
- collect(int) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
-
- collect(Mapper, Collection<ObjectMapper>, Collection<FieldMapper>) - Static method in enum org.elasticsearch.index.mapper.MapperUtils
-
Split mapper and its descendants into object and field mappers.
- collect(int) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- collect(int, long) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollector
-
Collect the given doc in the given bucket.
- collect(int) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollector
-
- collect(int, long) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollectorBase
-
- collect(long, long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
-
- collect(int) - Method in class org.elasticsearch.search.scan.ScanContext.ScanCollector
-
- 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
-
- 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, 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
-
- collectionToDelimitedString(Iterable<?>, String) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a Collection as a delimited (e.g.
- CollectionUtils - Enum in org.elasticsearch.common.util
-
Collections-related utility methods.
- collectMode - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
-
- collectMode(Aggregator.SubAggCollectionMode) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Expert: set the collection mode.
- collector - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
-
Deprecated.
- collector(SearchContext) - Method in class org.elasticsearch.search.scan.ScanContext
-
- CollectorResult - Class in org.elasticsearch.search.profile
-
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.CollectorResult
-
- CollectorResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.CollectorResult
-
- collectPayloads(boolean) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
- columnNumber - Variable in class org.elasticsearch.common.xcontent.XContentLocation
-
- combine(Module...) - Static method in class org.elasticsearch.common.inject.util.Modules
-
Returns a new module that installs all of modules
.
- combine(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.util.Modules
-
Returns a new module that installs all of modules
.
- combine(double, double, double) - Method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
-
- COMBINE_SCRIPT - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- COMBINE_SCRIPT_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- CombineFunction - Enum in org.elasticsearch.common.lucene.search.function
-
- combineFunction - Variable in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
-
- combineGrouped(List<? extends Query>) - Method in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
-
- combineNamedQueries(QueryParseContext) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- combineScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
-
Set the combine script.
- 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(Terminal) - Constructor for class org.elasticsearch.common.cli.CliTool.Command
-
- commands() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Get the commands wrapped by this instance
- commit() - Method in class org.elasticsearch.index.translog.Translog
-
- CommitId(byte[]) - Constructor for class org.elasticsearch.index.engine.Engine.CommitId
-
- CommitId(StreamInput) - Constructor for class org.elasticsearch.index.engine.Engine.CommitId
-
- CommitPoint - Class in org.elasticsearch.index.shard
-
- CommitPoint(long, String, CommitPoint.Type, List<CommitPoint.FileInfo>, List<CommitPoint.FileInfo>) - Constructor for class org.elasticsearch.index.shard.CommitPoint
-
- CommitPoint.FileInfo - Class in org.elasticsearch.index.shard
-
- CommitPoint.Type - Enum in org.elasticsearch.index.shard
-
- CommitPoints - Class in org.elasticsearch.index.shard
-
- CommitPoints(List<CommitPoint>) - Constructor for class org.elasticsearch.index.shard.CommitPoints
-
- commits() - Method in class org.elasticsearch.index.shard.CommitPoints
-
- 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
-
- 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
-
- committed - Variable in class org.elasticsearch.index.engine.Segment
-
- CommonFields() - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
-
- CommonGramsTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- CommonGramsTokenFilterFactory(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CommonGramsTokenFilterFactory
-
- CommonSettings() - Constructor for class org.elasticsearch.index.fielddata.IndexFieldData.CommonSettings
-
- 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(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.Flag - Enum in org.elasticsearch.action.admin.indices.stats
-
- commonTermsBlendedQuery(Term[], float[], boolean, 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.Operator - Enum in org.elasticsearch.index.query
-
- CommonTermsQueryParser - Class in org.elasticsearch.index.query
-
- CommonTermsQueryParser() - Constructor for class org.elasticsearch.index.query.CommonTermsQueryParser
-
- comparator(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.terms.Terms.Order
-
- Comparators - Enum in org.elasticsearch.common.util
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Comparator used for sorting.
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.AbstractGeoPointDVIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVNumericIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.DoubleArrayIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.FloatArrayIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.GlobalFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
-
- comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
-
- compare(BytesReference, BytesReference) - Method in class org.elasticsearch.common.text.UTF8SortedAsUnicodeComparator
-
- compare(ShardRouting, ShardRouting) - Method in class org.elasticsearch.gateway.PriorityComparator
-
- compare(B, B) - Method in class org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket.SubAggregationComparator
-
- compare(CompletionSuggestion.Entry.Option, CompletionSuggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggester.ScoreComparator
-
- 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
against d2
, pushing at the bottom.
- compareTo(IndicesShardStoresResponse.StoreStatus) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
- compareTo(ShardIterator) - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
-
- compareTo(Priority) - Method in class org.elasticsearch.common.Priority
-
- compareTo(Text) - Method in class org.elasticsearch.common.text.Text
-
- compareTo(DistanceUnit.Distance) - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
-
- 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(Translog.Location) - Method in class org.elasticsearch.index.translog.Translog.Location
-
- compareTo(TranslogReader) - Method in class org.elasticsearch.index.translog.TranslogReader
-
- compareTo(Number) - Method in class org.elasticsearch.script.ScoreAccessor
-
- 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(Snapshot) - Method in class org.elasticsearch.snapshots.Snapshot
-
Compares two snapshots by their start time
- compareTo(ThreadPoolStats.Stats) - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
- compatibleWith(IndexFieldData) - Method in enum org.elasticsearch.search.aggregations.support.ValueType
-
- compile(String, String) - Static method in class org.elasticsearch.common.regex.Regex
-
- compile(String...) - Static method in class org.elasticsearch.common.xcontent.support.filtering.FilterPath
-
- compile(String, Map<String, String>) - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
-
Compile a template string to (in this case) a Mustache object than can
later be re-used for execution to fill in missing parameter values.
- compile(String, Map<String, String>) - Method in class org.elasticsearch.script.NativeScriptEngineService
-
- compile(String, Map<String, String>) - Method in interface org.elasticsearch.script.ScriptEngineService
-
- compile(Script, ScriptContext, HasContextAndHeaders, Map<String, String>) - Method in class org.elasticsearch.script.ScriptService
-
Checks if a script can be executed and compiles it if needed, or returns the previously compiled and cached script.
- compiled() - Method in class org.elasticsearch.script.CompiledScript
-
Method to get the compiled script object.
- CompiledScript - Class in org.elasticsearch.script
-
CompiledScript holds all the parameters necessary to execute a previously compiled script.
- CompiledScript(ScriptService.ScriptType, String, String, Object) - Constructor for class org.elasticsearch.script.CompiledScript
-
Constructor for CompiledScript.
- compileInternal(Script, HasContextAndHeaders, Map<String, String>) - Method in class org.elasticsearch.script.ScriptService
-
Compiles a script straight-away, or returns the previously compiled and cached script,
without checking if it can be executed based on settings.
- 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(Collection<SnapshotsInProgress.ShardSnapshotStatus>) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress
-
Checks if all shards in the list have completed
- 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)
- completedOperations() - Method in exception org.elasticsearch.index.shard.TranslogRecoveryPerformer.BatchOperationException
-
the number of succesful operations performed before the exception was thrown
- completion - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- completion(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- completion() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- Completion090PostingsFormat - Class in org.elasticsearch.search.suggest.completion
-
This PostingsFormat
is basically a T-Sink for a default postings
format that is used to store postings on disk fitting the lucene APIs and
builds a suggest FST as an auxiliary data structure next to the actual
postings format.
- Completion090PostingsFormat(PostingsFormat, Completion090PostingsFormat.CompletionLookupProvider) - Constructor for class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
-
- Completion090PostingsFormat() - Constructor for class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
-
- Completion090PostingsFormat.CompletionLookupProvider - Class in org.elasticsearch.search.suggest.completion
-
- Completion090PostingsFormat.CompletionTerms - Class in org.elasticsearch.search.suggest.completion
-
- Completion090PostingsFormat.LookupFactory - Class in org.elasticsearch.search.suggest.completion
-
- completionDataFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- completionDataFields() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- completionField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- CompletionFieldMapper - Class in org.elasticsearch.index.mapper.core
-
- CompletionFieldMapper(String, MappedFieldType, int, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- CompletionFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
-
- CompletionFieldMapper.CompletionFieldType - Class in org.elasticsearch.index.mapper.core
-
- CompletionFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
-
- CompletionFieldMapper.Fields - Class in org.elasticsearch.index.mapper.core
-
- CompletionFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
-
- completionFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- completionFields() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- CompletionFieldType() - Constructor for class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- CompletionFieldType(CompletionFieldMapper.CompletionFieldType) - Constructor for class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- CompletionLookupProvider() - Constructor for class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionLookupProvider
-
- completionStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
-
- completionStats(IndexReader, String...) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
-
Returns total in-heap bytes used by all suggesters.
- CompletionStats - Class in org.elasticsearch.search.suggest.completion
-
- CompletionStats() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionStats
-
- CompletionStats(long, ObjectLongHashMap<String>) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionStats
-
- CompletionSuggester - Class in org.elasticsearch.search.suggest.completion
-
- CompletionSuggester() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggester
-
- CompletionSuggester.ScoreComparator - Class in org.elasticsearch.search.suggest.completion
-
- CompletionSuggestion - Class in org.elasticsearch.search.suggest.completion
-
- CompletionSuggestion() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion
-
- CompletionSuggestion(String, int) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion
-
- completionSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a completion suggestion lookup query with the provided name
- 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
-
- CompletionSuggestionContext - Class in org.elasticsearch.search.suggest.completion
-
- CompletionSuggestionContext(Suggester) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- CompletionSuggestionFuzzyBuilder - Class in org.elasticsearch.search.suggest.completion
-
- CompletionSuggestionFuzzyBuilder(String) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
- CompletionSuggestParser - Class in org.elasticsearch.search.suggest.completion
-
- CompletionSuggestParser(CompletionSuggester) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestParser
-
- CompletionTerms(Terms, Completion090PostingsFormat.LookupFactory) - Constructor for class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionTerms
-
- CompletionTokenStream - Class in org.elasticsearch.search.suggest.completion
-
- CompletionTokenStream(TokenStream, BytesRef, CompletionTokenStream.ToFiniteStrings) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionTokenStream
-
- CompletionTokenStream.ByteTermAttribute - Interface in org.elasticsearch.search.suggest.completion
-
- CompletionTokenStream.ByteTermAttributeImpl - Class in org.elasticsearch.search.suggest.completion
-
- CompletionTokenStream.ToFiniteStrings - Interface in org.elasticsearch.search.suggest.completion
-
- CompositeIndicesRequest - Interface in org.elasticsearch.action
-
Needs to be implemented by all
ActionRequest
subclasses that are composed of
multiple subrequests which relate to one or more indices.
- compound - Variable in class org.elasticsearch.index.engine.Segment
-
- compound(List<Terms.Order>) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.Terms.Order
-
Creates a bucket ordering strategy which sorts buckets based multiple criteria
- compound(Terms.Order...) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.Terms.Order
-
Creates a bucket ordering strategy which sorts buckets based multiple criteria
- compress(boolean) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
-
- compress() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- compress - Variable in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
- compress - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- compress() - Method in class org.elasticsearch.transport.TransportRequestOptions
-
- compress() - Method in class org.elasticsearch.transport.TransportResponseOptions
-
- COMPRESS_THRESHOLD - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
-
- compressed() - Method in class org.elasticsearch.common.compress.CompressedXContent
-
Return the compressed bytes.
- CompressedIndexInput - Class in org.elasticsearch.common.compress
-
- CompressedIndexInput(IndexInput) - Constructor for class org.elasticsearch.common.compress.CompressedIndexInput
-
Deprecated.
- compressedReference() - Method in class org.elasticsearch.common.compress.CompressedXContent
-
- CompressedStreamInput - Class in org.elasticsearch.common.compress
-
- CompressedStreamInput(StreamInput) - Constructor for class org.elasticsearch.common.compress.CompressedStreamInput
-
- 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(ToXContent, XContentType, ToXContent.Params) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
-
- CompressedXContent(BytesReference) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
-
- CompressedXContent(byte[]) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
-
- CompressedXContent(String) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
-
- compression - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- compression - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
-
- compression() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
-
- COMPRESSION_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesParser
-
- compressionLevel - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- Compressor - Interface in org.elasticsearch.common.compress
-
- compressor(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
- compressor(ChannelBuffer) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
- compressor(IndexInput) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
- CompressorFactory - Class in org.elasticsearch.common.compress
-
- CompressorFactory() - Constructor for class org.elasticsearch.common.compress.CompressorFactory
-
- compressThreshold(long) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
-
- 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
-
- computeNxys(long, long, long, long, String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
-
- concat(Iterator<? extends T>...) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
Combines multiple iterators into a single iterator.
- concat(FieldMapper) - Method in class org.elasticsearch.index.mapper.FieldMappers
-
- concreteAliases(MetaData, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- concreteAllClosedIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- concreteAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Returns all the concrete indices.
- concreteAllOpenIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- concreteIndex() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
-
- concreteIndex() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction.InternalRequest
-
- concreteIndices(ClusterState, IndicesRequest) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
- concreteIndices(ClusterState, IndicesOptions, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Translates the provided index expression into actual concrete indices, properly deduplicated.
- concreteIndices(ClusterState, IndicesOptions, long, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Translates the provided index expression into actual concrete indices, properly deduplicated.
- 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.
- 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(Recycler.Factory<T>) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
- 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
-
- 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
-
- ConcurrentRebalanceAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
-
- concurrentSmallFileStreamPool() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- ConcurrentSnapshotExecutionException - Exception in org.elasticsearch.snapshots
-
Thrown when a user tries to start multiple snapshots at the same time
- ConcurrentSnapshotExecutionException(SnapshotId, String) - Constructor for exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
-
- ConcurrentSnapshotExecutionException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
-
- concurrentStreamPool() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- concurrentStreams() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- conf() - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
-
- confidence(Float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the confidence level for this suggester.
- config(String, Class<? extends CliTool>) - Static method in class org.elasticsearch.common.cli.CliToolConfig
-
- config() - Method in class org.elasticsearch.index.engine.Engine
-
- config - Variable in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
-
- config() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
-
- configFile() - Method in class org.elasticsearch.env.Environment
-
The config location.
- 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
.
- configure() - Method in class org.elasticsearch.action.ActionModule
-
- configure() - Method in class org.elasticsearch.client.node.NodeClientModule
-
- configure() - Method in class org.elasticsearch.client.transport.ClientTransportModule
-
- configure() - Method in class org.elasticsearch.cluster.ClusterModule
-
- configure() - Method in class org.elasticsearch.cluster.ClusterNameModule
-
- configure(Binder) - Method in class org.elasticsearch.common.inject.AbstractModule
-
- configure() - Method in class org.elasticsearch.common.inject.AbstractModule
-
Configures a
Binder
via the exposed methods.
- 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() - Method in class org.elasticsearch.common.inject.PrivateModule
-
Creates bindings and other configurations private to this module.
- configure(Settings, boolean) - Static method in class org.elasticsearch.common.logging.log4j.LogConfigurator
-
Consolidates settings and converts them into actual log4j settings, then initializes loggers and appenders.
- configure() - Method in class org.elasticsearch.common.network.NetworkModule
-
- configure() - Method in class org.elasticsearch.common.settings.SettingsModule
-
- configure() - Method in class org.elasticsearch.discovery.DiscoveryModule
-
- configure() - Method in class org.elasticsearch.env.EnvironmentModule
-
- configure() - Method in class org.elasticsearch.env.NodeEnvironmentModule
-
- configure() - Method in class org.elasticsearch.gateway.GatewayModule
-
- configure() - Method in class org.elasticsearch.http.HttpServerModule
-
- configure() - Method in class org.elasticsearch.index.aliases.IndexAliasesServiceModule
-
- configure() - Method in class org.elasticsearch.index.analysis.AnalysisModule
-
- configure() - Method in class org.elasticsearch.index.cache.IndexCacheModule
-
- configure() - Method in class org.elasticsearch.index.deletionpolicy.DeletionPolicyModule
-
- configure() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataModule
-
- configure() - Method in class org.elasticsearch.index.IndexModule
-
- configure() - Method in class org.elasticsearch.index.IndexNameModule
-
- configure() - Method in class org.elasticsearch.index.LocalNodeIdModule
-
- configure() - Method in class org.elasticsearch.index.mapper.MapperServiceModule
-
- configure() - Method in class org.elasticsearch.index.search.shape.ShapeModule
-
- configure() - Method in class org.elasticsearch.index.settings.IndexSettingsModule
-
- configure() - Method in class org.elasticsearch.index.shard.IndexShardModule
-
- configure() - Method in class org.elasticsearch.index.similarity.SimilarityModule
-
- configure() - Method in class org.elasticsearch.index.store.IndexStoreModule
-
- configure() - Method in class org.elasticsearch.index.store.StoreModule
-
- configure() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerModule
-
- configure() - Method in class org.elasticsearch.indices.IndicesModule
-
- configure() - Method in class org.elasticsearch.monitor.MonitorModule
-
- configure() - Method in class org.elasticsearch.node.NodeModule
-
- configure() - Method in class org.elasticsearch.percolator.PercolatorModule
-
- configure() - Method in class org.elasticsearch.plugins.PluginsModule
-
- configure() - Method in class org.elasticsearch.repositories.RepositoriesModule
-
- configure() - Method in class org.elasticsearch.repositories.RepositoryModule
-
Configures a
Binder
via the exposed methods.
- configure() - Method in class org.elasticsearch.repositories.RepositoryNameModule
-
- configure() - Method in class org.elasticsearch.rest.action.RestActionModule
-
- configure() - Method in class org.elasticsearch.rest.RestModule
-
- configure() - Method in class org.elasticsearch.script.ScriptModule
-
- configure() - Method in class org.elasticsearch.search.SearchModule
-
- configure() - Method in class org.elasticsearch.threadpool.ThreadPoolModule
-
- configure() - Method in class org.elasticsearch.transport.TransportModule
-
- configure() - Method in class org.elasticsearch.tribe.TribeModule
-
- configure() - Method in class org.elasticsearch.Version.Module
-
- configure() - Method in class org.elasticsearch.watcher.ResourceWatcherModule
-
- configureAggs() - Method in class org.elasticsearch.search.SearchModule
-
- configureClientChannelPipelineFactory() - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- configureFetchSubPhase() - Method in class org.elasticsearch.search.SearchModule
-
- configureFunctionScore() - Method in class org.elasticsearch.search.SearchModule
-
- configureHighlighters() - Method in class org.elasticsearch.search.SearchModule
-
- configureSearch() - Method in class org.elasticsearch.search.SearchModule
-
- configureServerChannelPipelineFactory() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- configureServerChannelPipelineFactory(String, Settings) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- configureSuggesters() - Method in class org.elasticsearch.search.SearchModule
-
- connectedNodes() - Method in class org.elasticsearch.client.transport.TransportClient
-
Returns the current connected transport nodes that this client will use.
- connectedNodes() - Method in class org.elasticsearch.client.transport.TransportClientNodesService
-
- connectedNodes - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- connectionListener - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- connectionLock - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- CONNECTIONS_PER_NODE_BULK - Static variable in class org.elasticsearch.transport.netty.NettyTransport
-
- CONNECTIONS_PER_NODE_PING - Static variable in class org.elasticsearch.transport.netty.NettyTransport
-
- CONNECTIONS_PER_NODE_RECOVERY - Static variable in class org.elasticsearch.transport.netty.NettyTransport
-
- CONNECTIONS_PER_NODE_REG - Static variable in class org.elasticsearch.transport.netty.NettyTransport
-
- CONNECTIONS_PER_NODE_STATE - Static variable in class org.elasticsearch.transport.netty.NettyTransport
-
- connectionsPerNodeBulk - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- connectionsPerNodePing - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- connectionsPerNodeRecovery - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- connectionsPerNodeReg - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- connectionsPerNodeState - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- connectOnNetworkDisconnect - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- connectTimeout - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- connectToChannels(NettyTransport.NodeChannels, DiscoveryNode) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- connectToChannelsLight(DiscoveryNode) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- connectToNode(DiscoveryNode) - Method in class org.elasticsearch.transport.local.LocalTransport
-
- connectToNode(DiscoveryNode) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- connectToNode(DiscoveryNode, boolean) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- connectToNode(DiscoveryNode) - Method in interface org.elasticsearch.transport.Transport
-
Connects to the given node, if already connected, does nothing.
- connectToNode(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
-
- connectToNodeLight(DiscoveryNode) - Method in class org.elasticsearch.transport.local.LocalTransport
-
- connectToNodeLight(DiscoveryNode) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- connectToNodeLight(DiscoveryNode) - Method in interface org.elasticsearch.transport.Transport
-
Connects to a node in a light manner.
- connectToNodeLight(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
-
- 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, Throwable) - Constructor for exception org.elasticsearch.transport.ConnectTransportException
-
- ConnectTransportException(DiscoveryNode, String, String, Throwable) - Constructor for exception org.elasticsearch.transport.ConnectTransportException
-
- ConnectTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ConnectTransportException
-
- consistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Sets the consistency level of write.
- consistencyLevel() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- consistencyLevel() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
- consistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Sets the consistency level of write.
- consistencyLevel() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- consistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the consistency level of write.
- ConsoleAppender - Class in org.elasticsearch.common.logging.log4j
-
ConsoleAppender appends log events to System.out
or
System.err
using a layout specified by the user.
- ConsoleAppender() - Constructor for class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
Constructs an unconfigured appender.
- ConsoleAppender(Layout) - Constructor for class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
Creates a configured appender.
- ConsoleAppender(Layout, String) - Constructor for class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
Creates a configured appender.
- ConsoleCtrlHandler - Interface in org.elasticsearch.bootstrap
-
- consoleLoggingEnabled() - Static method in class org.elasticsearch.common.logging.Loggers
-
- 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
-
- 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(QueryBuilder) - Constructor for class org.elasticsearch.index.query.ConstantScoreQueryBuilder
-
A query that wraps a query and simply returns a constant score equal to the
query boost for every document in the query.
- ConstantScoreQueryParser - Class in org.elasticsearch.index.query
-
- ConstantScoreQueryParser() - Constructor for class org.elasticsearch.index.query.ConstantScoreQueryParser
-
- ConstantScorer - Class in org.elasticsearch.index.search.child
-
A scorer that wraps a DocIdSetIterator
and emits a constant score.
- 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.
- Consumer<T> - Interface in org.elasticsearch.common.util
-
Used to simplify backporting Elasticsearch 5.0 code to 2.0
- consumer(IndexOutput) - Method in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- consumer(IndexOutput) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionLookupProvider
-
- containPhysicalIndexFile(String) - Method in class org.elasticsearch.index.shard.CommitPoint
-
- 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(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlock
-
- contains(Object) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- contains(Class) - Method in exception org.elasticsearch.ElasticsearchException
-
Check whether this exception contains an exception of the given type:
either it is of the given class itself or it contains a nested cause
of the given type.
- contains(String) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns true iff this metadata contains the given file.
- containsAll(Collection<?>) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- containsKey(Object) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
- 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(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.
- containsKey(K) - Method in class org.elasticsearch.common.collect.MapBuilder
-
- containsKey(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- containsKey(Object) - Method in class org.elasticsearch.common.util.MinimalMap
-
- 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
-
- containsValue(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- containsValue(Object) - Method in class org.elasticsearch.common.util.MinimalMap
-
- 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
-
- containsWhitespace(CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Check whether the given CharSequence contains any whitespace characters.
- content() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
- 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_FIELD_NAME_INPUT - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- CONTENT_FIELD_NAME_OUTPUT - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- CONTENT_FIELD_NAME_PAYLOAD - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- CONTENT_FIELD_NAME_WEIGHT - Static variable in class org.elasticsearch.index.mapper.core.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.core.BinaryFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.ByteFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.DateFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.FloatFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.LongFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.ShortFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.AllFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.ip.IpFieldMapper
-
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- contentBuilder() - Static method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- contentBuilder() - Static method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- contentBuilder() - Static method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- contentBuilder(XContentType, OutputStream) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
-
Constructs a xcontent builder that will output the result into the provided output stream.
- contentBuilder(XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
-
Returns a binary content builder for the provided content type.
- contentBuilder() - Static method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- ContentPath - Class in org.elasticsearch.index.mapper
-
- ContentPath() - Constructor for class org.elasticsearch.index.mapper.ContentPath
-
- ContentPath(int) - Constructor for class org.elasticsearch.index.mapper.ContentPath
-
Constructs a json path with an offset.
- ContentPath.Type - Enum in org.elasticsearch.index.mapper
-
- contentType(XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the content type that will be used when generating a document from user provided objects (like Map).
- contentType(XContentType) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets the content type that will be used when generating a document from user provided objects (like Map).
- contentType() - Method in class org.elasticsearch.common.settings.loader.JsonSettingsLoader
-
- contentType() - Method in class org.elasticsearch.common.settings.loader.XContentSettingsLoader
-
- contentType() - Method in class org.elasticsearch.common.settings.loader.YamlSettingsLoader
-
- contentType() - Method in class org.elasticsearch.common.xcontent.cbor.CborXContentGenerator
-
- contentType() - Method in class org.elasticsearch.common.xcontent.cbor.CborXContentParser
-
- contentType() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
-
- contentType() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- contentType() - Method in class org.elasticsearch.common.xcontent.smile.SmileXContentGenerator
-
- contentType() - Method in class org.elasticsearch.common.xcontent.smile.SmileXContentParser
-
- contentType() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- contentType() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
-
- contentType() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- contentType() - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContentGenerator
-
- contentType() - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContentParser
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
-
- contentType() - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
-
- contentType() - Method in class org.elasticsearch.rest.BytesRestResponse
-
- contentType() - Method in class org.elasticsearch.rest.RestResponse
-
The response content type.
- context() - Method in interface org.elasticsearch.cluster.metadata.MetaData.Custom
-
- context() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
- context - Variable in class org.elasticsearch.common.lucene.uid.Versions.DocIdAndVersion
-
- CONTEXT - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- context() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
- context - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
-
- context() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- context() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
-
- context - Variable in class org.elasticsearch.search.highlight.HighlighterContext
-
- Context(SortedMap<String, ContextMapping.ContextConfig>, ParseContext.Document) - Constructor for class org.elasticsearch.search.suggest.context.ContextMapping.Context
-
- CONTEXT_FACTORY - Static variable in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsFetchSubPhase
-
- CONTEXT_MODE_GATEWAY - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- CONTEXT_MODE_PARAM - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- CONTEXT_MODE_SNAPSHOT - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- ContextAndHeaderHolder - Class in org.elasticsearch.common
-
- ContextAndHeaderHolder() - Constructor for class org.elasticsearch.common.ContextAndHeaderHolder
-
- ContextBuilder<E extends ContextMapping> - Class in org.elasticsearch.search.suggest.context
-
- ContextBuilder(String) - Constructor for class org.elasticsearch.search.suggest.context.ContextBuilder
-
- ContextConfig() - Constructor for class org.elasticsearch.search.suggest.context.ContextMapping.ContextConfig
-
- 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(SortedMap<String, ContextMapping>) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Builder
-
- ContextMapping - Class in org.elasticsearch.search.suggest.context
-
A
ContextMapping
is used t define a context that may used
in conjunction with a suggester.
- ContextMapping(String, String) - Constructor for class org.elasticsearch.search.suggest.context.ContextMapping
-
Define a new context mapping of a specific type
- ContextMapping.Context - Class in org.elasticsearch.search.suggest.context
-
- ContextMapping.ContextConfig - Class in org.elasticsearch.search.suggest.context
-
- ContextMapping.ContextQuery - Class in org.elasticsearch.search.suggest.context
-
- ContextQuery(String) - Constructor for class org.elasticsearch.search.suggest.context.ContextMapping.ContextQuery
-
- contextSize() - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- contextSize() - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- contextSize() - Method in interface org.elasticsearch.common.HasContext
-
- contextSize() - Method in class org.elasticsearch.percolator.PercolateContext
-
- continueProcessing(RestRequest, RestChannel) - Method in interface org.elasticsearch.rest.RestFilterChain
-
Continue processing the 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(L) - Method in class org.elasticsearch.action.support.AdapterActionFuture
-
- convert(T) - Method in class org.elasticsearch.action.support.PlainActionFuture
-
- convert(T) - Method in class org.elasticsearch.action.support.PlainListenableActionFuture
-
- 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(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(DistanceUnit) - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
-
- 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
-
- convertFromStringArray(String[]) - Static method in class org.elasticsearch.common.text.Text
-
- convertToDoubleFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude
-
- convertToElastic(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
- convertToFeatures(String...) - Static method in enum org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
-
- convertToJson(BytesReference, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
- convertToJson(BytesReference, boolean, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
- convertToJson(byte[], int, int, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
- convertToJson(byte[], int, int, boolean, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
- convertToLongFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude
-
- convertToMap(BytesReference, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
- convertToOrdinalsFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude
-
- convertToRuntime(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
- convertToStringFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.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.
- convertToTypes(Matcher<? super TypeLiteral<?>>, TypeConverter) - Method in class org.elasticsearch.common.inject.PrivateModule
-
- coordinate(Coordinate) - Method in class org.elasticsearch.common.geo.builders.PointBuilder
-
- coordinate(double, double) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- coordinate - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder.CoordinateNode
-
- CoordinateNode(Coordinate) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder.CoordinateNode
-
Creates a new leaf CoordinateNode
- CoordinateNode(List<ShapeBuilder.CoordinateNode>) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder.CoordinateNode
-
Creates a new parent CoordinateNode
- coordinates() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
The coordinates setup by the builder will be assembled to a polygon.
- coordinates() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
-
- coordinates() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder.InternalLineStringBuilder
-
- coordinates(boolean) - Method in class org.elasticsearch.common.geo.builders.PointCollection
-
Copy all points to a new Array
- coordinatesArray(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- coordinatesToXcontent(XContentBuilder, boolean) - Method in class org.elasticsearch.common.geo.builders.PointCollection
-
- 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(byte[], OutputStream) - Static method in class org.elasticsearch.common.io.Streams
-
Copy the contents of the given byte array to the given OutputStream.
- copy(Reader, Writer) - Static method in class org.elasticsearch.common.io.Streams
-
Copy the contents of the given Reader to the given Writer.
- copy(String, Writer) - Static method in class org.elasticsearch.common.io.Streams
-
Copy the contents of the given String to the given output Writer.
- copy(BytesRef, BytesRef) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
-
- copyAndAdd(T) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashSet
-
Copy the current set and return a copy that contains or replaces entry
.
- copyAndAddAll(Collection<? extends T>) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashSet
-
Copy the current set and return a copy that is the union of the current
set and entries
, potentially replacing existing entries in
case of equality.
- copyAndPut(K, V) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Associate key
with value
and return a new copy
of the hash table.
- copyAndPutAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
- copyAndPutMapper(Mapper) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
-
Return a copy of this mapper that has the given mapper
as a
sub mapper.
- copyAndRemove(Object) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Remove the given key from this map.
- copyAndRemove(Object) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashSet
-
Copy the current set and return a copy that removes entry
if it exists.
- copyAndRemoveAll(Collection<?>) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
- copyAndRemoveAll(Collection<?>) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashSet
-
Copy the current set and return a copy that is the difference of the current
set and entries
.
- copyBytesArray() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- copyBytesArray() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns the bytes copied over as a byte array.
- copyBytesArray() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- copyBytesArray() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- copyBytesRef() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- copyBytesRef() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Converts to a copied Lucene BytesRef.
- copyBytesRef() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- copyBytesRef() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- copyContextAndHeadersFrom(HasContextAndHeaders) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- copyContextAndHeadersFrom(HasContextAndHeaders) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- copyContextAndHeadersFrom(HasContextAndHeaders) - Method in interface org.elasticsearch.common.HasContextAndHeaders
-
copies over the context and the headers
- copyContextAndHeadersFrom(HasContextAndHeaders) - Method in class org.elasticsearch.percolator.PercolateContext
-
- copyContextFrom(HasContext) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- copyContextFrom(HasContext) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- copyContextFrom(HasContext) - Method in interface org.elasticsearch.common.HasContext
-
Copies the context from the given context holder to this context holder.
- copyContextFrom(HasContext) - Method in class org.elasticsearch.percolator.PercolateContext
-
- copyCurrentEvent(XContentGenerator, XContentParser) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
- copyCurrentStructure(XContentParser) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
-
- copyCurrentStructure(XContentParser) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- copyCurrentStructure(XContentParser) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
-
- copyCurrentStructure(XContentGenerator, XContentParser) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
- copyDirectoryRecursively(Path, Path) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Copy recursively a dir to a new location
- copyHeaders(ElasticsearchException) - Method in class org.elasticsearch.rest.RestResponse
-
- copyHeadersFrom(HasHeaders) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- copyHeadersFrom(HasHeaders) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- copyHeadersFrom(HasHeaders) - Method in interface org.elasticsearch.common.HasHeaders
-
- copyHeadersFrom(HasHeaders) - Method in class org.elasticsearch.percolator.PercolateContext
-
- copyNamedQueries() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- copyOf(Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Return a copy of the provided map.
- copyOf(Collection<? extends T>) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashSet
-
Return a copy of the provided set.
- copyOf(ObjectObjectMap<KType, VType>) - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
- 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.
- CopyOnWriteHashSet<T> - Class in org.elasticsearch.common.collect
-
- CopyOnWriteHashSet() - Constructor for class org.elasticsearch.common.collect.CopyOnWriteHashSet
-
Create a new empty set.
- copyRawValue(BytesReference, XContent) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
-
- copyShards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
- copySign(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- copySign(Float, Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- copyTo - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- copyTo(FieldMapper.CopyTo) - Method 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.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttributeImpl
-
- 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.
- 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
-
- correctSubStringLen(String, int) - Static method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- 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
-
- CorruptStateException(Throwable) - Constructor for exception org.elasticsearch.gateway.CorruptStateException
-
- CorsConfig - Class in org.elasticsearch.http.netty.cors
-
Configuration for Cross-Origin Resource Sharing (CORS).
- CorsConfigBuilder - Class in org.elasticsearch.http.netty.cors
-
Builder used to configure and build a
CorsConfig
instance.
- CorsHandler - Class in org.elasticsearch.http.netty.cors
-
- CorsHandler(CorsConfig) - Constructor for class org.elasticsearch.http.netty.cors.CorsHandler
-
Creates a new instance with the specified
CorsConfig
.
- corsSettingAsArray(String) - Static method in class org.elasticsearch.rest.support.RestUtils
-
Return the CORS setting as an array of origins.
- cos(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cos(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cos(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cos(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cos(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cosh(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- cost() - Method in class org.apache.lucene.search.XFilteredDocIdSetIterator
-
- count() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
-
- count(CountRequest) - Method in interface org.elasticsearch.client.Client
-
- count(CountRequest, ActionListener<CountResponse>) - Method in interface org.elasticsearch.client.Client
-
- count(CountRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
- count(CountRequest, ActionListener<CountResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
- count - Variable in class org.elasticsearch.common.io.FastCharArrayReader
-
The index of the end of this buffer.
- count - Variable in class org.elasticsearch.common.io.FastCharArrayWriter
-
The number of chars in the buffer.
- count - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
-
- count() - Method in class org.elasticsearch.common.lucene.Lucene.EarlyTerminatingCollector
-
- count() - Method in class org.elasticsearch.common.metrics.CounterMetric
-
- count() - Method in class org.elasticsearch.common.metrics.MeanMetric
-
- count() - Method in class org.elasticsearch.common.metrics.MeterMetric
-
- count - Variable in class org.elasticsearch.index.cache.query.QueryCache.EntriesStats
-
- count() - Method in class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Return the number of geo points the current document has.
- count() - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Return the number of values of the current document.
- count() - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Retrieves the count of values for the current document.
- count - Variable in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
- count() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
- count() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
- count() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
-
- count() - Method in class org.elasticsearch.percolator.PercolatorService.ReduceResult
-
- count(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
ValueCount
aggregation with the given name.
- count() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
-
- count(boolean) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.Terms.Order
-
- count() - Method in interface org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroid
-
- count - Variable in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- count() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- count - Variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- count() - Method in interface org.elasticsearch.search.MultiValueMode.UnsortedNumericDoubleValues
-
- COUNT_ASC - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.Histogram.Order
-
- COUNT_DESC - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.Histogram.Order
-
- CountAction - Class in org.elasticsearch.action.count
-
- 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
-
- countDown() - Method in class org.elasticsearch.common.util.concurrent.CountDown
-
Decrements the count-down and returns true
iff this call
reached zero otherwise false
- 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
-
- countOccurrencesOf(String, String) - Static method in class org.elasticsearch.common.Strings
-
Count the occurrences of the substring in string s.
- CountRequest - Class in org.elasticsearch.action.count
-
- CountRequest(String...) - Constructor for class org.elasticsearch.action.count.CountRequest
-
Deprecated.
Constructs a new count request against the provided indices.
- countRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
- CountRequestBuilder - Class in org.elasticsearch.action.count
-
- CountRequestBuilder(ElasticsearchClient, CountAction) - Constructor for class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
- CountResponse - Class in org.elasticsearch.action.count
-
- CountResponse(SearchResponse) - Constructor for class org.elasticsearch.action.count.CountResponse
-
Deprecated.
- Counts() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
-
- 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() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- create(boolean) - Method in class org.elasticsearch.action.index.IndexRequest
-
- create(boolean) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- 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(Priority) - Static method in class org.elasticsearch.cluster.BasicClusterStateTaskConfig
-
Build a cluster state update task configuration with the
specified
Priority
and no timeout.
- create(Priority, TimeValue) - Static method in class org.elasticsearch.cluster.BasicClusterStateTaskConfig
-
Build a cluster state update task configuration with the
specified
Priority
and timeout.
- create(boolean) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
-
- create(K, Errors) - Method in class org.elasticsearch.common.inject.internal.FailableCache
-
- 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(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(int, double) - Static method in class org.elasticsearch.common.util.BloomFilter
-
Creates a bloom filter based on the with the expected number
of insertions and expected false positive probability.
- create(int, double, int) - Static method in class org.elasticsearch.common.util.BloomFilter
-
Creates a bloom filter based on the expected number of insertions, expected false positive probability,
and number of hash functions.
- create(String, Settings) - Method in interface org.elasticsearch.index.analysis.AnalyzerProviderFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ApostropheFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ArabicNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ArabicStemTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ASCIIFoldingTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.BrazilianStemTokenFilterFactory
-
- create(Reader) - Method in interface org.elasticsearch.index.analysis.CharFilterFactory
-
- create(String, Settings) - Method in interface org.elasticsearch.index.analysis.CharFilterFactoryFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.CJKBigramFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.CJKWidthFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ClassicFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.ClassicTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.CommonGramsTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.compound.DictionaryCompoundWordTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.compound.HyphenationCompoundWordTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.CzechStemTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.DecimalDigitFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.DelimitedPayloadTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.DutchStemTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.EdgeNGramTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.EdgeNGramTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ElisionTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.FrenchStemTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.GermanNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.GermanStemTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.HindiNormalizationFilterFactory
-
- create(Reader) - Method in class org.elasticsearch.index.analysis.HtmlStripCharFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.IndicNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.KeepTypesFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.KeepWordFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.KeywordMarkerTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.KeywordTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.KStemTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.LengthTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.LetterTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.LimitTokenCountFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.LowerCaseTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.LowerCaseTokenizerFactory
-
- create(Reader) - Method in class org.elasticsearch.index.analysis.MappingCharFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.NGramTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.NGramTokenizerFactory
-
- create() - Method in class org.elasticsearch.index.analysis.PathHierarchyTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.PatternCaptureGroupTokenFilterFactory
-
- create(Reader) - Method in class org.elasticsearch.index.analysis.PatternReplaceCharFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.PatternReplaceTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.PatternTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.PersianNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.PorterStemTokenFilterFactory
-
- create(String, Settings) - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
-
- create(String, Settings) - Method in class org.elasticsearch.index.analysis.PreBuiltCharFilterFactoryFactory
-
- create(String, Settings) - Method in class org.elasticsearch.index.analysis.PreBuiltTokenFilterFactoryFactory
-
- create(String, Settings) - Method in class org.elasticsearch.index.analysis.PreBuiltTokenizerFactoryFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ReverseTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.RussianStemTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ScandinavianFoldingFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ScandinavianNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.SerbianNormalizationFilterFactory
-
- 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.SnowballTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.SoraniNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.StandardTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.StandardTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.StemmerOverrideTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.StemmerTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.ThaiTokenizerFactory
-
- create(TokenStream) - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
- create(String, Settings) - Method in interface org.elasticsearch.index.analysis.TokenFilterFactoryFactory
-
- create() - Method in interface org.elasticsearch.index.analysis.TokenizerFactory
-
- create(String, Settings) - Method in interface org.elasticsearch.index.analysis.TokenizerFactoryFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.TrimTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.TruncateTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.UAX29URLEmailTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.UniqueTokenFilterFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.UpperCaseTokenFilterFactory
-
- create() - Method in class org.elasticsearch.index.analysis.WhitespaceTokenizerFactory
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.WordDelimiterTokenFilterFactory
-
- create(Engine.Create) - Method in class org.elasticsearch.index.engine.Engine
-
- Create(Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long, boolean, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.Create
-
- Create(Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long) - Constructor for class org.elasticsearch.index.engine.Engine.Create
-
- Create(Term, ParsedDocument) - Constructor for class org.elasticsearch.index.engine.Engine.Create
-
- create(Engine.Create) - Method in class org.elasticsearch.index.engine.InternalEngine
-
- create(Engine.Create) - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- create(QueryParseContext, BaseGeoPointFieldMapper.GeoPointFieldType, String, List<CharSequence>) - Static method in class org.elasticsearch.index.query.GeohashCellQuery
-
Create a new geohash filter for a given set of geohashes.
- create(DocIdSetIterator, Weight, float) - Static method in class org.elasticsearch.index.search.child.ConstantScorer
-
- create(GeoPoint, GeoPoint, BaseGeoPointFieldMapper.GeoPointFieldType) - Static method in class org.elasticsearch.index.search.geo.IndexedGeoBoundingBoxQuery
-
- create(Engine.Create) - Method in class org.elasticsearch.index.shard.IndexShard
-
- create(String, Settings) - Method in class org.elasticsearch.index.similarity.PreBuiltSimilarityProvider.Factory
-
- create(String, Settings) - Method in interface org.elasticsearch.index.similarity.SimilarityProvider.Factory
-
- Create() - Constructor for class org.elasticsearch.index.translog.Translog.Create
-
- Create(Engine.Create) - Constructor for class org.elasticsearch.index.translog.Translog.Create
-
- Create(String, String, byte[]) - Constructor for class org.elasticsearch.index.translog.Translog.Create
-
- create(TranslogWriter.Type, ShardId, String, long, Path, Callback<ChannelReference>, int, TranslogWriter.ChannelFactory) - Static method in class org.elasticsearch.index.translog.TranslogWriter
-
- create(ShardId, long, ChannelReference, int) - Method in enum org.elasticsearch.index.translog.TranslogWriter.Type
-
- create(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
- create(Reader, Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltCharFilters
-
- create(TokenStream, Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenFilters
-
- create(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
-
- create(AggregationContext, Aggregator, boolean) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Creates the aggregator
- create(List<InternalFilters.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- create(List<InternalGeoHashGrid.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
-
- create(List<B>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
- create(String, List<B>, InternalOrder, long, InternalHistogram.EmptyBucketInfo, ValueFormatter, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Factory
-
- create(List<B>, InternalHistogram<B>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Factory
-
- create(InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Create a new copy of this
Aggregation
with the same settings as
this
Aggregation
and contains the provided sub-aggregations.
- create(String, List<InternalDateRange.Bucket>, ValueFormatter, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Factory
-
- create(List<InternalDateRange.Bucket>, InternalDateRange) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Factory
-
- create(String, List<InternalGeoDistance.Bucket>, ValueFormatter, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance.Factory
-
- create(List<InternalGeoDistance.Bucket>, InternalGeoDistance) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance.Factory
-
- create(List<B>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- create(String, List<B>, ValueFormatter, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
-
- create(List<B>, R) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
-
- create(String, List<InternalIPv4Range.Bucket>, ValueFormatter, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Factory
-
- create(List<InternalIPv4Range.Bucket>, InternalIPv4Range) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Factory
-
- create(long, long, List<InternalSignificantTerms.Bucket>, InternalSignificantTerms) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
- create(List<SignificantLongTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
-
- create(long, long, List<InternalSignificantTerms.Bucket>, InternalSignificantTerms) - 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(long, long, List<InternalSignificantTerms.Bucket>, InternalSignificantTerms) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
-
- create(List<InternalSignificantTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
-
- create(long, long, List<InternalSignificantTerms.Bucket>, InternalSignificantTerms) - 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(String, List<InternalTerms.Bucket>, long, long, InternalTerms) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
-
- create(String, List<InternalTerms.Bucket>, long, long, InternalTerms) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- create(List<LongTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
-
- create(String, List<InternalTerms.Bucket>, long, long, InternalTerms) - 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(String, List<InternalTerms.Bucket>, long, long, InternalTerms) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
-
- create(List<InternalTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
- create(String, List<InternalTerms.Bucket>, long, long, InternalTerms) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
- create(List<B>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
Create a new copy of this
Aggregation
with the same settings as
this
Aggregation
and contains the provided buckets.
- create() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorFactory
-
Creates the pipeline aggregator
- create(String) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormat.DateTime
-
- create(String) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormat.Number
-
- create(String) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormat.Patternable
-
- create(ChannelBuffer) - Static method in class org.elasticsearch.transport.netty.ChannelBufferStreamInputFactory
-
- create(ChannelBuffer, int) - Static method in class org.elasticsearch.transport.netty.ChannelBufferStreamInputFactory
-
- createAdapter() - Method in class org.elasticsearch.transport.TransportService
-
- createBucket(InternalAggregations, InternalFilters.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- createBucket(InternalAggregations, InternalGeoHashGrid.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
-
- createBucket(InternalAggregations, B) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
- createBucket(InternalAggregations, B) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Factory
-
- createBucket(Object, long, InternalAggregations, boolean, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Factory
-
- createBucket(String, double, double, long, InternalAggregations, boolean, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Factory
-
- createBucket(InternalAggregations, InternalDateRange.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Factory
-
- createBucket(String, double, double, long, InternalAggregations, boolean, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance.Factory
-
- createBucket(InternalAggregations, InternalGeoDistance.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance.Factory
-
- createBucket(InternalAggregations, B) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- createBucket(String, double, double, long, InternalAggregations, boolean, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
-
- createBucket(InternalAggregations, B) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
-
- createBucket(String, double, double, long, InternalAggregations, boolean, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Factory
-
- createBucket(InternalAggregations, InternalIPv4Range.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.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, InternalSignificantTerms.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, InternalTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
- createBucket(InternalAggregations, B) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
- createBuilder(String) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
-
- createBuilder(String) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.TypeParser
-
- 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
-
- createChildInjector(Iterable<? extends Module>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns a new injector that inherits all state from this injector.
- createChildInjector(Module...) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns a new injector that inherits all state from this injector.
- createChildInjector(Injector) - Method in class org.elasticsearch.common.inject.ModulesBuilder
-
- createComponents(String) - Method in class org.apache.lucene.analysis.PrefixAnalyzer
-
- createComponents(String) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
-
- createComponents(String) - Method in class org.elasticsearch.index.analysis.NumericAnalyzer
-
- createComponents(String) - Method in class org.elasticsearch.index.analysis.PatternAnalyzer
-
- createComponents(String) - Method in class org.elasticsearch.index.analysis.SnowballAnalyzer
-
Deprecated.
Constructs a StandardTokenizer
filtered by a StandardFilter
, a LowerCaseFilter
, a StopFilter
,
and a SnowballFilter
- createComponents(String) - Method in class org.elasticsearch.index.analysis.StandardHtmlStripAnalyzer
-
- createCopyToContext() - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that will be within a copy-to operation.
- createEmptyBucket(boolean, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Factory
-
- createExternalValueContext(Object) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that will have the external value set.
- createFactory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgParser
-
- createFactory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxParser
-
- createFactory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinParser
-
- createFactory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Method in class org.elasticsearch.search.aggregations.metrics.NumericValuesSourceMetricsAggregatorParser
-
- createFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, double) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsParser
-
- createFactory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsParser
-
- createFactory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumParser
-
- CreateFailedEngineException - Exception in org.elasticsearch.index.engine
-
- CreateFailedEngineException(ShardId, String, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.CreateFailedEngineException
-
- CreateFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.CreateFailedEngineException
-
- createFilter(int) - Method in class org.elasticsearch.common.util.BloomFilter.Factory
-
- createGenerator(OutputStream) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- createGenerator(OutputStream, String[]) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- createGenerator(OutputStream) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- createGenerator(OutputStream, String[]) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- createGenerator(OutputStream) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- createGenerator(OutputStream, String[]) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- createGenerator(OutputStream) - Method in interface org.elasticsearch.common.xcontent.XContent
-
Creates a new generator using the provided output stream.
- createGenerator(OutputStream, String[]) - Method in interface org.elasticsearch.common.xcontent.XContent
-
Creates a new generator using the provided output stream and some filters.
- createGenerator(OutputStream) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- createGenerator(OutputStream, String[]) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- createIndex(CreateIndexClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
-
- createIndex(String, Settings, String) - Method in class org.elasticsearch.indices.IndicesService
-
- CreateIndexAction - Class in org.elasticsearch.action.admin.indices.create
-
- CreateIndexClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.create
-
Cluster state update request that allows to create an index
- 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(ActionRequest) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Constructs a new request to create an index that was triggered by a different request,
provided as an argument so that its headers and context can be copied to the new request.
- CreateIndexRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Constructs a new request to create an index with the specified name.
- CreateIndexRequest(String, Settings) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Constructs a new request to create an index with the specified name and settings.
- createIndexRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a create index request.
- 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.
- createInjector(Module...) - Static method in class org.elasticsearch.common.inject.Guice
-
Creates an injector for the given set of modules.
- createInjector(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.Guice
-
Creates an injector for the given set of modules.
- 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.
- 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() - Method in class org.elasticsearch.common.inject.ModulesBuilder
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator.Factory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator.Factory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator.Factory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator.Factory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator.Factory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.Factory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator.Factory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator.Factory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorFactory
-
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator.Factory
-
- createInternal(AggregationContext, Aggregator, boolean, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
-
- createMapper(String, String, boolean, ObjectMapper.Nested, ObjectMapper.Dynamic, ContentPath.Type, Map<String, Mapper>, Settings) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
-
- createMapper(String, String, boolean, ObjectMapper.Nested, ObjectMapper.Dynamic, ContentPath.Type, Map<String, Mapper>, Settings) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
-
- createMultiFieldContext(Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
-
- createMultiFieldContext() - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that will be within multi-fields.
- createNestedContext(String) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that will be used within a nested document.
- createNormalizedWeight(Query, boolean) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
- createNumericTokenizer(char[]) - Method in class org.elasticsearch.index.analysis.NumericAnalyzer
-
- createNumericTokenizer(char[]) - Method in class org.elasticsearch.index.analysis.NumericDateAnalyzer
-
- createNumericTokenizer(char[]) - Method in class org.elasticsearch.index.analysis.NumericDoubleAnalyzer
-
- createNumericTokenizer(char[]) - Method in class org.elasticsearch.index.analysis.NumericFloatAnalyzer
-
- createNumericTokenizer(char[]) - Method in class org.elasticsearch.index.analysis.NumericIntegerAnalyzer
-
- createNumericTokenizer(char[]) - Method in class org.elasticsearch.index.analysis.NumericLongAnalyzer
-
- createNumericTokenizer(char[]) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.NumericIpAnalyzer
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.RateLimitedFSDirectory
-
- createOutput(String) - Method in class org.elasticsearch.common.blobstore.support.AbstractLegacyBlobContainer
-
Deprecated.
- createParseContext(String, String, String) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
- createParser(String) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- createParser(InputStream) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- createParser(byte[]) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- createParser(byte[], int, int) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- createParser(BytesReference) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- createParser(Reader) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- createParser(String) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- createParser(InputStream) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- createParser(byte[]) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- createParser(byte[], int, int) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- createParser(BytesReference) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- createParser(Reader) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- createParser(String) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- createParser(InputStream) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- createParser(byte[]) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- createParser(byte[], int, int) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- createParser(BytesReference) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- createParser(Reader) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- createParser(String) - Method in interface org.elasticsearch.common.xcontent.XContent
-
Creates a parser over the provided string content.
- createParser(InputStream) - Method in interface org.elasticsearch.common.xcontent.XContent
-
Creates a parser over the provided input stream.
- createParser(byte[]) - Method in interface org.elasticsearch.common.xcontent.XContent
-
Creates a parser over the provided bytes.
- createParser(byte[], int, int) - Method in interface org.elasticsearch.common.xcontent.XContent
-
Creates a parser over the provided bytes.
- createParser(BytesReference) - Method in interface org.elasticsearch.common.xcontent.XContent
-
Creates a parser over the provided bytes.
- createParser(Reader) - Method in interface org.elasticsearch.common.xcontent.XContent
-
Creates a parser over the provided reader.
- createParser(BytesReference) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
- createParser(String) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- createParser(InputStream) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- createParser(byte[]) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- createParser(byte[], int, int) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- createParser(BytesReference) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- createParser(Reader) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- createPipelineAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
-
- createProxy(Errors, Class<?>) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
-
- 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
-
- 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
-
- createScript(String, ScriptService.ScriptType, String, Map<String, Object>) - Method in class org.elasticsearch.script.AbstractScriptParser
-
- createShard(ShardRouting) - Method in class org.elasticsearch.index.IndexService
-
- createSimpleScript(XContentParser) - Method in class org.elasticsearch.script.AbstractScriptParser
-
- 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(SnapshotsService.SnapshotRequest, SnapshotsService.CreateSnapshotListener) - 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 - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Create snapshot request
- CreateSnapshotRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
- CreateSnapshotRequest(String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Constructs a new put repository request with the provided snapshot and repository names
- createSnapshotRequest(String, String) - Static method in class org.elasticsearch.client.Requests
-
Creates new snapshot
- 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) - Method in class org.elasticsearch.action.support.ChildTaskActionRequest
-
- createTask(long, String, String, TaskId) - Method in class org.elasticsearch.action.support.ChildTaskActionRequest
-
- createTask(long, String, String) - Method in class org.elasticsearch.action.support.ChildTaskRequest
-
- createTask(long, String, String, TaskId) - Method in class org.elasticsearch.action.support.ChildTaskRequest
-
- createTask(long, String, String, TaskId) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
- createTask(long, String, String) - Method in class org.elasticsearch.transport.TransportRequest
-
Returns the task object that should be used to keep track of the processing of the request.
- createTaskManager() - Method in class org.elasticsearch.transport.TransportService
-
- createTerm(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Creates a term associated with the field of this mapper for the given
value.
- createTopDocsCollector(int) - Method in class org.elasticsearch.search.aggregations.bucket.BestDocsDeferringCollector
-
- createTopLevelAggregators(AggregationContext) - 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
-
- createUid(StringBuilder, 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
-
- createUidAsBytes(BytesRef, BytesRef, BytesRefBuilder) - Static method in class org.elasticsearch.index.mapper.Uid
-
- createUids(List<? extends DocumentRequest>) - 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
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.DiversifiedFactory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator.Factory
-
- createUnmapped(AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator.Factory
-
- createUnmapped(AggregationContext, 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 might validate the files checksum if the file has been written with a newer lucene version
and the metadata holds the necessary information to detect that it was been written by Lucene 4.8 or newer.
- createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.queries.MinDocQuery
-
- createWeight(IndexSearcher, boolean) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
-
- createWeight(IndexSearcher, boolean) - Method in class org.elasticsearch.common.lucene.IndexCacheableQuery
-
- createWeight(IndexSearcher, boolean) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
-
- createWeight(IndexSearcher, boolean) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- createWeight(IndexSearcher, boolean) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeQuery
-
- createWeight(IndexSearcher, boolean) - Method in class org.elasticsearch.index.search.geo.GeoPolygonQuery
-
- createWeight(IndexSearcher, boolean) - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxQuery
-
- createWeight(IndexSearcher, boolean) - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
-
- createWeight(Query, boolean) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
- creationDate(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- creationDate() - 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
.
- CrossFieldsQueryBuilder(float) - Constructor for class org.elasticsearch.index.search.MultiMatchQuery.CrossFieldsQueryBuilder
-
- CTRL_CLOSE_EVENT - Static variable in interface org.elasticsearch.bootstrap.ConsoleCtrlHandler
-
- cumulativeSum(String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
-
- CumulativeSumBuilder - Class in org.elasticsearch.search.aggregations.pipeline.cumulativesum
-
- CumulativeSumBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumBuilder
-
- CumulativeSumParser - Class in org.elasticsearch.search.aggregations.pipeline.cumulativesum
-
- CumulativeSumParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumParser
-
- CumulativeSumPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.cumulativesum
-
- CumulativeSumPipelineAggregator() - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
-
- CumulativeSumPipelineAggregator(String, String[], ValueFormatter, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
-
- CumulativeSumPipelineAggregator.Factory - Class in org.elasticsearch.search.aggregations.pipeline.cumulativesum
-
- CURRENT - Static variable in class org.elasticsearch.Build
-
- current() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodeIterator
-
- current - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
-
- current() - Method in class org.elasticsearch.index.get.GetStats
-
- current() - Method in class org.elasticsearch.index.warmer.WarmerStats
-
- current() - Static method in class org.elasticsearch.search.internal.SearchContext
-
- 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.
- currentName() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- currentName() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- currentNanoTime() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
ovrride this to control time based decisions during 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
-
- 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, String[]) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Returns status of the currently running snapshots
- currentSnapshotShards(SnapshotId) - 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.
- currentStage() - Method in class org.elasticsearch.common.inject.PrivateModule
-
- currentState() - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
-
- currentTimeInNanos() - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
-
- currentToken() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- currentToken() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- currentTotalTermFreq - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
-
- Cursor() - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
-
- custom(IndexMetaData.Custom) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds custom metadata to the index to be created.
- custom(IndexMetaData.Custom) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- custom(String) - Method in class org.elasticsearch.cluster.ClusterState
-
- custom(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- custom(String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- custom(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- custom(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- CustomAnalyzer - Class in org.elasticsearch.index.analysis
-
- CustomAnalyzer(TokenizerFactory, CharFilterFactory[], TokenFilterFactory[]) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzer
-
- CustomAnalyzer(TokenizerFactory, CharFilterFactory[], TokenFilterFactory[], int, int) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzer
-
- CustomAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
A custom analyzer that is built out of a single Tokenizer
and a list
of TokenFilter
s.
- CustomAnalyzerProvider(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzerProvider
-
- CustomBinaryDocValuesField(String, byte[]) - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper.CustomBinaryDocValuesField
-
- customBoost() - Method in class org.elasticsearch.common.lucene.all.AllEntries
-
- customBoost() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
-
- customBoost() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
-
- customBoost() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
-
- customBoost() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
-
- customBoost() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
-
- customBoost() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
-
- customBoost() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
-
- customBoost() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- customBoost() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Derived classes can override it to specify that boost value is set by derived classes.
- CustomByteNumericField(byte, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.CustomByteNumericField
-
- CustomDoubleNumericDocValuesField(String, double) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericDocValuesField
-
- CustomDoubleNumericField(double, NumberFieldMapper.NumberFieldType) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericField
-
- CustomFieldQuery - Class in org.apache.lucene.search.vectorhighlight
-
- CustomFieldQuery(Query, IndexReader, FastVectorHighlighter) - Constructor for class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
-
- CustomFieldQuery(Query, IndexReader, boolean, boolean) - 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>, List<String>, boolean) - Constructor for class org.elasticsearch.index.fieldvisitor.CustomFieldsVisitor
-
- CustomFieldsVisitor(Set<String>, boolean) - Constructor for class org.elasticsearch.index.fieldvisitor.CustomFieldsVisitor
-
- CustomFloatNumericDocValuesField(String, float) - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericDocValuesField
-
- CustomFloatNumericField(float, NumberFieldMapper.NumberFieldType) - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericField
-
- CustomGeoPointDocValuesField(String, double, double) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy.CustomGeoPointDocValuesField
-
- customHeaders - Variable in class org.elasticsearch.rest.RestResponse
-
- CustomIntegerNumericField(int, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.CustomIntegerNumericField
-
- CustomLongNumericDocValuesField(String, long) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomLongNumericDocValuesField
-
- CustomLongNumericField(long, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.CustomLongNumericField
-
- CustomNumericDocValuesField(String) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
-
- CustomNumericField(Number, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
-
- CustomPassageFormatter - Class in org.apache.lucene.search.postingshighlight
-
Custom passage formatter that allows us to:
1) extract different snippets (instead of a single big string) together with their scores (
Snippet
)
2) use the
Encoder
implementations that are already used with the other highlighters
- CustomPassageFormatter(String, String, Encoder) - Constructor for class org.apache.lucene.search.postingshighlight.CustomPassageFormatter
-
- CustomPostingsHighlighter - Class in org.apache.lucene.search.postingshighlight
-
Subclass of the PostingsHighlighter
that works for a single field in a single document.
- CustomPostingsHighlighter(Analyzer, CustomPassageFormatter, String, boolean) - Constructor for class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
-
- CustomPostingsHighlighter(Analyzer, CustomPassageFormatter, BreakIterator, String, boolean) - Constructor for class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
-
- customPrototypes - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- customPrototypes - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- CustomQueryScorer - Class in org.elasticsearch.search.highlight
-
- CustomQueryScorer(Query, IndexReader, String, String) - Constructor for class org.elasticsearch.search.highlight.CustomQueryScorer
-
- CustomQueryScorer(Query, IndexReader, String) - Constructor for class org.elasticsearch.search.highlight.CustomQueryScorer
-
- CustomQueryScorer(Query, String, String) - Constructor for class org.elasticsearch.search.highlight.CustomQueryScorer
-
- CustomQueryScorer(Query, String) - Constructor for class org.elasticsearch.search.highlight.CustomQueryScorer
-
- CustomQueryScorer(Query) - Constructor for class org.elasticsearch.search.highlight.CustomQueryScorer
-
- CustomQueryScorer(WeightedSpanTerm[]) - Constructor for class org.elasticsearch.search.highlight.CustomQueryScorer
-
- customs(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
-
- customs() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
-
- customs(Map<String, IndexMetaData.Custom>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
- customs() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
- customs() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
- customs() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- customs(ImmutableOpenMap<String, ClusterState.Custom>) - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- customs() - Method in class org.elasticsearch.cluster.ClusterState
-
- customs() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- customs(ImmutableOpenMap<String, MetaData.Custom>) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- customs() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- customs(Map<String, IndexMetaData.Custom>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
-
- customs() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- CustomShortNumericField(short, NumberFieldMapper.NumberFieldType) - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper.CustomShortNumericField
-
- 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.
- 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
-
- CzechAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- CzechAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CzechAnalyzerProvider
-
- CzechStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- CzechStemTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CzechStemTokenFilterFactory
-
- factor(float) - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
-
- factor(float) - Method in class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionBuilder
-
- FactorBuilder - Class in org.elasticsearch.index.query.functionscore.factor
-
Deprecated.
- FactorBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.factor.FactorBuilder
-
Deprecated.
- factorDistance(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- factorDistance02(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- factorDistance13(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- factorDistanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- FactorFixedSourceDistance(double, double, DistanceUnit) - Constructor for class org.elasticsearch.common.geo.GeoDistance.FactorFixedSourceDistance
-
- factories - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
-
- factories() - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
-
- FactorParser - Class in org.elasticsearch.index.query.functionscore.factor
-
Deprecated.
- FactorParser() - Constructor for class org.elasticsearch.index.query.functionscore.factor.FactorParser
-
Deprecated.
- Factory() - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand.Factory
-
- Factory() - Constructor for class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand.Factory
-
- Factory() - Constructor for class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand.Factory
-
- FACTORY - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- Factory(BloomFilter.Factory.Entry[]) - Constructor for class org.elasticsearch.common.util.BloomFilter.Factory
-
- Factory(String) - Constructor for class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
-
- Factory(String, Similarity) - Constructor for class org.elasticsearch.index.similarity.PreBuiltSimilarityProvider.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Bytes.ParentChild>, String, Query, Query) - Constructor for class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator.Factory
-
- Factory(String, Query) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator.Factory
-
- Factory(String, List<FiltersAggregator.KeyedFilter>, boolean, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator.Factory
-
- Factory(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>, Rounding, InternalOrder, boolean, long, ExtendedBounds, InternalHistogram.Factory<?>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator.Factory
-
- factory - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
- Factory() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Factory
-
- Factory(String, ValuesSourceConfig) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator.Factory
-
- Factory(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator.Factory
-
- Factory(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator.Factory
-
- FACTORY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange
-
- Factory() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Factory
-
- FACTORY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
-
- Factory() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance.Factory
-
- Factory() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
-
- FACTORY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
-
- Factory() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>, InternalRange.Factory, List<RangeAggregator.Range>, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Factory
-
- Factory(String, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.Factory
-
- Factory(String, String, ValuesSourceConfig<ValuesSource.Numeric>) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.GeoPoint>, boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.GeoPoint>) - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.MinAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], int, boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentileRanksAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], int, boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.HDRPercentilesAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], double, boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], double, boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregator.Factory
-
- Factory(String, Script, Script, Script, Script, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>, double) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator.Factory
-
- Factory(String, ValuesSourceConfig<ValuesSource.Numeric>) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator.Factory
-
- Factory(String, FetchPhase, SubSearchContext) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator.Factory
-
- Factory(String, ValuesSourceConfig<VS>) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator.Factory
-
- Factory(String, String[], BucketHelpers.GapPolicy, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator.Factory
-
- Factory(String, String[], BucketHelpers.GapPolicy, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator.Factory
-
- Factory(String, String[], BucketHelpers.GapPolicy, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator.Factory
-
- Factory(String, String[], BucketHelpers.GapPolicy, ValueFormatter, double[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator.Factory
-
- Factory(String, String[], double, BucketHelpers.GapPolicy, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator.Factory
-
- Factory(String, String[], BucketHelpers.GapPolicy, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator.Factory
-
- Factory(String, String[], BucketHelpers.GapPolicy, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator.Factory
-
- Factory(String, Map<String, String>, Script, ValueFormatter, BucketHelpers.GapPolicy) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator.Factory
-
- Factory(String, String[], ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator.Factory
-
- Factory(String, String[], ValueFormatter, BucketHelpers.GapPolicy, Long) - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator.Factory
-
- Factory(String, Map<String, String>, Script, BucketHelpers.GapPolicy) - Constructor for class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorPipelineAggregator.Factory
-
- Factory(String, String[], ValueFormatter, BucketHelpers.GapPolicy, int, int, MovAvgModel, boolean) - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator.Factory
-
- Factory(String, String[], ValueFormatter, BucketHelpers.GapPolicy, int) - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator.Factory
-
- FACTORY - Static variable in class org.elasticsearch.search.suggest.phrase.LaplaceScorer
-
- FACTORY - Static variable in class org.elasticsearch.search.suggest.phrase.StupidBackoffScorer
-
- 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.
- FactoryProvider2<F> - Class in org.elasticsearch.common.inject.assistedinject
-
The newer implementation of factory provider.
- fail(RecoveryFailedException, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
fail the recovery and call listener
- FAIL_ON_UNSUPPORTED_FIELD - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryParser.Field
-
- 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
-
- 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 class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response.Item
-
- failed() - Method in enum org.elasticsearch.cluster.SnapshotsInProgress.State
-
- failed(Throwable) - Method in class org.elasticsearch.index.shard.SnapshotStatus
-
- failed() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
-
- failed() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
-
- failedEngine - Variable in class org.elasticsearch.index.engine.Engine
-
- failedEngineListener - 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
-
- FailedRerouteAllocation - Class in org.elasticsearch.cluster.routing.allocation
-
- FailedRerouteAllocation(AllocationDeciders, RoutingNodes, DiscoveryNodes, List<FailedRerouteAllocation.FailedShard>, ClusterInfo) - Constructor for class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation
-
- FailedRerouteAllocation.FailedShard - Class in org.elasticsearch.cluster.routing.allocation
-
A failed shard with the shard routing itself and an optional
details on why it failed.
- FailedShard(ShardRouting, String, Throwable) - Constructor for class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation.FailedShard
-
- 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.cluster.routing.allocation.FailedRerouteAllocation
-
- 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
- failEngine(String, Throwable) - 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
-
- 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
- failRestore(SnapshotId, ShardId) - Method in class org.elasticsearch.snapshots.RestoreService
-
Fails the given snapshot restore operation for the given shard
- failShard(String, Throwable) - 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
- Failure(String, int, String, Throwable, RestStatus, boolean) - Constructor for class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- Failure(String, String, int, Throwable) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
-
- Failure(String, String, String, Throwable) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
- Failure(String, String, String, Throwable) - Constructor for class org.elasticsearch.action.get.MultiGetResponse.Failure
-
- Failure(String, String, String, Throwable) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
-
- failure(T, Throwable) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.BatchResult.Builder
-
- failure(Throwable) - Static method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
-
- failure - Variable in class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation.FailedShard
-
- failure(String) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
- failure() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
- failureDescription() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
-
- 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.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
-
- failures() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
The failed nodes, if set to be captured.
- failures(Iterable<T>, Throwable) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.BatchResult.Builder
-
- failures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- failures() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodesGatewayMetaState
-
- failures() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodesGatewayStartedShards
-
- failures() - Method in exception org.elasticsearch.index.mapper.MergeMappingException
-
- failures() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
-
- failures() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
-
- FALSE - Static variable in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Values
-
- FastCharArrayReader - Class in org.elasticsearch.common.io
-
- FastCharArrayReader(char[]) - Constructor for class org.elasticsearch.common.io.FastCharArrayReader
-
Creates a CharArrayReader from the specified array of chars.
- FastCharArrayReader(char[], int, int) - Constructor for class org.elasticsearch.common.io.FastCharArrayReader
-
Creates a CharArrayReader from the specified array of chars.
- FastCharArrayWriter - Class in org.elasticsearch.common.io
-
A similar class to
CharArrayWriter
allowing to get the underlying
char[] buffer.
- FastCharArrayWriter() - Constructor for class org.elasticsearch.common.io.FastCharArrayWriter
-
Creates a new CharArrayWriter.
- FastCharArrayWriter(int) - Constructor for class org.elasticsearch.common.io.FastCharArrayWriter
-
Creates a new CharArrayWriter with the specified initial size.
- 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 otherwise
false
- FastStringReader - Class in org.elasticsearch.common.io
-
A character stream whose source is a string that is not thread safe
- FastStringReader(String) - Constructor for class org.elasticsearch.common.io.FastStringReader
-
Creates a new string reader.
- FastVectorHighlighter - Class in org.elasticsearch.search.highlight
-
- FastVectorHighlighter(Settings) - Constructor for class org.elasticsearch.search.highlight.FastVectorHighlighter
-
- FaultDetection - Class in org.elasticsearch.discovery.zen.fd
-
- FaultDetection(Settings, ThreadPool, TransportService, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- features(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
-
- features() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
-
- featuresAsEnums() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
-
- fetch(List<MoreLikeThisQueryBuilder.Item>) - Method in class org.elasticsearch.index.search.morelikethis.MoreLikeThisFetchService
-
- fetch(GetRequest, String) - Method in class org.elasticsearch.index.search.shape.ShapeFetchService
-
Fetches the Shape with the given ID in the given type and index.
- FETCH_ID_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- FETCH_ID_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- 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.source.FetchSourceContext
-
- fetchData(DiscoveryNodes, MetaData, 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
-
- FetchPhase - Class in org.elasticsearch.search.fetch
-
- FetchPhase(Set<FetchSubPhase>, InnerHitsFetchSubPhase) - Constructor for class org.elasticsearch.search.fetch.FetchPhase
-
- FetchPhaseExecutionException - Exception in org.elasticsearch.search.fetch
-
- FetchPhaseExecutionException(SearchContext, String, Throwable) - Constructor for exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
-
- FetchPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
-
- fetchResponse(List<MoreLikeThisQueryBuilder.Item>, SearchContext) - Method in class org.elasticsearch.index.search.morelikethis.MoreLikeThisFetchService
-
- FetchResult(ShardId, Map<DiscoveryNode, T>, Set<String>, Set<String>) - Constructor for class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
-
- fetchResult() - Method in class org.elasticsearch.percolator.PercolateContext
-
- fetchResult() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
-
- fetchResult() - Method in interface org.elasticsearch.search.fetch.FetchSearchResultProvider
-
- fetchResult() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
-
- fetchResult() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- 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
-
- 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
-
- FetchSearchResultProvider - Interface in org.elasticsearch.search.fetch
-
- 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.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.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.search.builder.SearchSourceBuilder
-
Indicate how the _source should be fetched.
- fetchSource() - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- fetchSource(boolean) - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- 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() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- 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() - Method in class org.elasticsearch.action.get.GetRequest
-
- fetchSourceContext() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- 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() - Method in class org.elasticsearch.percolator.PercolateContext
-
- fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.percolator.PercolateContext
-
- FetchSourceContext - Class in org.elasticsearch.search.fetch.source
-
- FetchSourceContext(boolean) - Constructor for class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- FetchSourceContext(String) - Constructor for class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- FetchSourceContext(String, String) - Constructor for class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- FetchSourceContext(String[]) - Constructor for class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- FetchSourceContext(String[], String[]) - Constructor for class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- FetchSourceContext(boolean, String[], String[], boolean) - Constructor for class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- fetchSourceContext() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- fetchSourceContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- fetchSourceContext() - Method in class org.elasticsearch.search.internal.SearchContext
-
- fetchSourceContext(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.search.internal.SubSearchContext
-
- FetchSourceParseElement - Class in org.elasticsearch.search.fetch.source
-
"source" : true/false
"source" : "field"
"source" : [ "include", "include" ]
"source" : {
"include" : ["obj"]
"exclude" : ["obj"]
}
- FetchSourceParseElement() - Constructor for class org.elasticsearch.search.fetch.source.FetchSourceParseElement
-
- FetchSourceSubPhase - Class in org.elasticsearch.search.fetch.source
-
- FetchSourceSubPhase() - Constructor for class org.elasticsearch.search.fetch.source.FetchSourceSubPhase
-
- FetchSubPhase - Interface in org.elasticsearch.search.fetch
-
- FetchSubPhase.ContextFactory<SubPhaseContext extends FetchSubPhaseContext> - Interface in org.elasticsearch.search.fetch
-
This interface is in the fetch phase plugin mechanism.
- FetchSubPhase.HitContext - Class in org.elasticsearch.search.fetch
-
- FetchSubPhaseContext - Class in org.elasticsearch.search.fetch
-
All configuration and context needed by the FetchSubPhase to execute on hits.
- FetchSubPhaseContext() - Constructor for class org.elasticsearch.search.fetch.FetchSubPhaseContext
-
- FetchSubPhaseParseElement<SubPhaseContext extends FetchSubPhaseContext> - Class in org.elasticsearch.search.fetch
-
A parse element for a
FetchSubPhase
that is used when parsing a search request.
- FetchSubPhaseParseElement() - Constructor for class org.elasticsearch.search.fetch.FetchSubPhaseParseElement
-
- field(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- field() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- field - Variable in class org.elasticsearch.action.termvectors.TermVectorsFilter.ScoreTerm
-
- field() - Method in enum org.elasticsearch.common.rounding.DateTimeUnit
-
- FIELD - Static variable in class org.elasticsearch.common.unit.Fuzziness
-
- field(String, ToXContent) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, ToXContent, ToXContent.Params) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, char[], int, int) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, char[], int, int) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, String) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, String, XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, String) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, String, XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Integer) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Integer) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, int) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, int) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Float) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Float) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, float) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, float) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, BigDecimal) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, BigDecimal) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, BigDecimal, int, RoundingMode, boolean) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, BigDecimal, int, RoundingMode, boolean) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, BytesRef) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, BytesRef) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Text) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Text) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, byte[], int, int) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Map<String, Object>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Map<String, Object>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Iterable<?>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Iterable<?>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, boolean...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, boolean...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, String...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, String...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Object...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Object...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, int...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, int, int, int...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, int...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, long...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, long...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, float...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, float...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, double...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, double...) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Object) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Object) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, boolean) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, boolean) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, byte[]) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, byte[]) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, ReadableInstant) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, ReadableInstant) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, ReadableInstant, DateTimeFormatter) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, ReadableInstant, DateTimeFormatter) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Date) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Date) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String, Date, DateTimeFormatter) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(XContentBuilderString, Date, DateTimeFormatter) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- field(String) - Method in class org.elasticsearch.index.get.GetResult
-
- FIELD - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- field(String) - Method in class org.elasticsearch.index.query.GeohashCellQuery.Builder
-
- field(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Adds a field to run the multi match against.
- 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) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Adds a field to run the query string against.
- 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) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Add a field to run the query against
- 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) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Add a stored field to be loaded and returned with the inner hit.
- FIELD - Static variable in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction.Fields
-
- field(String) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridBuilder
-
Set the field to use to get geo points.
- field(String) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingBuilder
-
Set the field to count missing values on.
- field(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
Set the field to use to compute distances.
- field(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Set the field to fetch significant terms from.
- field(String) - Method in class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
-
- field() - Method in class org.elasticsearch.search.aggregations.support.FieldContext
-
- field(String) - Method in class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
-
Sets the field from which the values will be extracted.
- field(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a field to load and return (note, it must be stored) as part of the
search request.
- field(String) - Method in class org.elasticsearch.search.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, int) - Method in class org.elasticsearch.search.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.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.highlight.HighlightBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and
a provided (maximum) number of fragments.
- field(HighlightBuilder.Field) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
- Field(String) - Constructor for class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
- field - Variable in class org.elasticsearch.search.highlight.HighlighterContext
-
- field() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
-
- field(String) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- field(String) - Method in interface org.elasticsearch.search.SearchHit
-
The hit field matching the given field name.
- field(String) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
-
Set the name of the field containing a geolocation to use
- field - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- field(String) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Sets from what field to fetch the candidate suggestions from.
- FIELD_COORDINATES - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- FIELD_DATA - Static variable in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction.Fields
-
- FIELD_FIELDNAME - Static variable in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- FIELD_GEOMETRIES - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- FIELD_MISSING - Static variable in class org.elasticsearch.search.suggest.context.ContextMapping
-
- FIELD_NEIGHBORS - Static variable in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- FIELD_ORIENTATION - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- FIELD_PRECISION - Static variable in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- FIELD_RADIUS - Static variable in class org.elasticsearch.common.geo.builders.CircleBuilder
-
- FIELD_TYPE - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.ByteFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.FloatFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.LongFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.ShortFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.VersionFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.ip.IpFieldMapper.Defaults
-
- FIELD_TYPE - Static variable in class org.elasticsearch.search.suggest.context.ContextMapping
-
- FIELD_VALUE - Static variable in class org.elasticsearch.search.suggest.context.ContextMapping
-
- fieldCaseConversion(XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- 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
- fieldContext() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- fieldContext(FieldContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- fieldData - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- fieldData(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- fieldData() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- FIELDDATA - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
- FieldData - Enum in org.elasticsearch.index.fielddata
-
Utility methods, similar to Lucene's DocValues
.
- fieldData() - Method in class org.elasticsearch.index.IndexService
-
- fieldData() - Method in class org.elasticsearch.index.shard.IndexShard
-
- fieldData() - Method in class org.elasticsearch.percolator.PercolateContext
-
- FieldData(IndexFieldData<?>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
-
- FieldData(IndexOrdinalsFieldData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
-
- Fielddata(IndexGeoPointFieldData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint.Fielddata
-
- FieldData(IndexNumericFieldData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
-
- fieldData() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- fieldData() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- fieldData() - Method in class org.elasticsearch.search.internal.SearchContext
-
- FIELDDATA_CACHE_CONCURRENCY_LEVEL - Static variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
-
- 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_CLEAN_INTERVAL_SETTING - Static variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
-
- 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
-
- FieldDataCacheCleaner(Cache, ESLogger, ThreadPool, TimeValue) - Constructor for class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.FieldDataCacheCleaner
-
- fieldDataField(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a field to load from the field data cache and return as part of the
search request.
- FieldDataField(String) - Constructor for class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsContext.FieldDataField
-
- fieldDataFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Sets specific search group stats to retrieve the stats for.
- fieldDataFields() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- fieldDataFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- fieldDataFields() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- FieldDataFieldsContext - Class in org.elasticsearch.search.fetch.fielddata
-
All the required context to pull a field from the field data cache.
- FieldDataFieldsContext() - Constructor for class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsContext
-
- FieldDataFieldsContext.FieldDataField - Class in org.elasticsearch.search.fetch.fielddata
-
- FieldDataFieldsFetchSubPhase - Class in org.elasticsearch.search.fetch.fielddata
-
Query sub phase which pulls data from field data (using the cache if
available, building it if not).
- FieldDataFieldsFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsFetchSubPhase
-
- FieldDataFieldsParseElement - Class in org.elasticsearch.search.fetch.fielddata
-
Parses field name values from the fielddata_fields
parameter in a
search request.
- FieldDataFieldsParseElement() - Constructor for class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsParseElement
-
- fieldDataService() - Method in class org.elasticsearch.search.lookup.DocLookup
-
- fieldDataService() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
-
- fieldDataSettings - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- fieldDataSettings(Settings) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- fieldDataSettings(Settings) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- fieldDataSettings(Settings) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
-
- FieldDataStats - Class in org.elasticsearch.index.fielddata
-
- FieldDataStats() - Constructor for class org.elasticsearch.index.fielddata.FieldDataStats
-
- FieldDataStats(long, long, ObjectLongHashMap<String>) - Constructor for class org.elasticsearch.index.fielddata.FieldDataStats
-
- fieldDataStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
-
- FieldDataType - Class in org.elasticsearch.index.fielddata
-
- FieldDataType(String) - Constructor for class org.elasticsearch.index.fielddata.FieldDataType
-
- FieldDataType(String, Settings.Builder) - Constructor for class org.elasticsearch.index.fielddata.FieldDataType
-
- FieldDataType(String, Settings) - Constructor for class org.elasticsearch.index.fielddata.FieldDataType
-
- fieldDataType - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
-
- fieldDataType - Variable in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
-
- fieldDataType() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- FieldDataWeigher() - Constructor for class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.FieldDataWeigher
-
- FieldLookup - Class in org.elasticsearch.search.lookup
-
- 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(String) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- 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
-
- FieldMappers - Class in org.elasticsearch.index.mapper
-
- FieldMappers() - Constructor for class org.elasticsearch.index.mapper.FieldMappers
-
- FieldMappers(FieldMapper) - Constructor for class org.elasticsearch.index.mapper.FieldMappers
-
- 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(SpanQueryBuilder, String) - Constructor for class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
-
- FieldMaskingSpanQueryParser - Class in org.elasticsearch.index.query
-
- FieldMaskingSpanQueryParser() - Constructor for class org.elasticsearch.index.query.FieldMaskingSpanQueryParser
-
- fieldName() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeQuery
-
- fieldName() - Method in class org.elasticsearch.index.search.geo.GeoPolygonQuery
-
- fieldName() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxQuery
-
- fieldName - Variable in class org.elasticsearch.search.highlight.HighlighterContext
-
- fieldName(String) - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping.Builder
-
Set the name of the field to use
- FieldNameAnalyzer - Class in org.elasticsearch.index.analysis
-
- FieldNameAnalyzer(Map<String, Analyzer>) - Constructor for class org.elasticsearch.index.analysis.FieldNameAnalyzer
-
- fieldNames - Variable in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
-
- fieldNames() - Method in class org.elasticsearch.percolator.PercolateContext
-
- fieldNames() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- fieldNames() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- fieldNames() - Method in class org.elasticsearch.search.internal.SearchContext
-
- fieldNames() - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- FieldNamesFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
A mapper that indexes the field names of a document under _field_names
.
- FieldNamesFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- FieldNamesFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- FieldNamesFieldMapper.FieldNamesFieldType - Class in org.elasticsearch.index.mapper.internal
-
- FieldNamesFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- FieldNamesFieldType() - Constructor for class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.FieldNamesFieldType
-
- FieldNamesFieldType(FieldNamesFieldMapper.FieldNamesFieldType) - Constructor for class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.FieldNamesFieldType
-
- fieldOptions() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
-
- FieldOptions() - Constructor for class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- FieldQueryExtension - Interface in org.apache.lucene.queryparser.classic
-
- fieldQueryExtensions - Static variable in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- fields() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- fields(List<String>) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- fields(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
-
- 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(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
- fields() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
- fields() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- fields(String[]) - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- fields(String...) - Method in class org.elasticsearch.action.get.GetRequest
-
Explicitly specify the fields that will be returned.
- fields() - Method in class org.elasticsearch.action.get.GetRequest
-
Explicitly specify the fields that will be returned.
- fields(String...) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- fields() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- fields(String...) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Explicitly specify the fields that will be returned.
- fields() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Get the fields to be returned.
- fields() - Method in class org.elasticsearch.common.lucene.all.AllEntries
-
- fields() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
-
- Fields() - Constructor for class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- FIELDS - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item.Field
-
- fields() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- fields(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- FIELDS - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryParser.Field
-
- Fields() - Constructor for class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction.Fields
-
- Fields() - Constructor for class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction.Fields
-
- FIELDS - Static variable in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction.Fields
-
- fields() - Method in class org.elasticsearch.script.AbstractSearchScript
-
Allows to access the *stored* fields.
- fields(List<String>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the fields to load and return as part of the search request.
- fields(String...) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds the fields to load and return as part of the search request.
- fields() - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsContext
-
- fields() - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsContext
-
- fields() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight
-
- fields() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- fields(Map<String, SearchHitField>) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- Fields() - Constructor for class org.elasticsearch.search.internal.InternalSearchHit.Fields
-
- Fields() - Constructor for class org.elasticsearch.search.internal.InternalSearchHit.InternalNestedIdentity.Fields
-
- fields() - Method in class org.elasticsearch.search.lookup.FieldLookup
-
- fields(Map<String, List<Object>>) - Method in class org.elasticsearch.search.lookup.FieldLookup
-
Sets the post processed values.
- fields() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
-
- fields() - Method in interface org.elasticsearch.search.SearchHit
-
A map of hit fields (from field name to hit fields) if additional fields
were required to be loaded.
- Fields() - Constructor for class org.elasticsearch.search.suggest.Suggest.Fields
-
- Fields() - Constructor for class org.elasticsearch.search.suggest.SuggestUtils.Fields
-
- fieldsConsumer(SegmentWriteState) - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
-
Deprecated.
- fieldsConsumer(SegmentWriteState) - Method in class org.elasticsearch.index.codec.postingsformat.Elasticsearch090PostingsFormat
-
Deprecated.
- fieldsConsumer(SegmentWriteState) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
-
- FieldsLookup - Class in org.elasticsearch.search.lookup
-
- fieldsOrNull() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- 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.
- FieldsParseElement - Class in org.elasticsearch.search.fetch
-
- FieldsParseElement() - Constructor for class org.elasticsearch.search.fetch.FieldsParseElement
-
- fieldsProducer(SegmentReadState) - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
-
Deprecated.
- fieldsProducer(SegmentReadState) - Method in class org.elasticsearch.index.codec.postingsformat.Elasticsearch090PostingsFormat
-
Deprecated.
- fieldsProducer(SegmentReadState) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
-
- fieldStatistics() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- fieldStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the field statistics for each term in the shard or skip.
- fieldStatistics() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
-
- fieldStatistics(ObjectObjectHashMap<String, CollectionStatistics>) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- fieldStatistics() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- FieldStats<T extends Comparable<T>> - Class in org.elasticsearch.action.fieldstats
-
- FieldStats() - Constructor for class org.elasticsearch.action.fieldstats.FieldStats
-
- FieldStats(int, long, long, long, long) - Constructor for class org.elasticsearch.action.fieldstats.FieldStats
-
- fieldStats(FieldStatsRequest) - Method in interface org.elasticsearch.client.Client
-
- fieldStats(FieldStatsRequest, ActionListener<FieldStatsResponse>) - Method in interface org.elasticsearch.client.Client
-
- fieldStats(FieldStatsRequest, ActionListener<FieldStatsResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
- fieldStats(FieldStatsRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
- FieldStats.Date - Class in org.elasticsearch.action.fieldstats
-
- FieldStats.Double - Class in org.elasticsearch.action.fieldstats
-
- FieldStats.Float - Class in org.elasticsearch.action.fieldstats
-
- FieldStats.Long - Class in org.elasticsearch.action.fieldstats
-
- FieldStats.Text - Class in org.elasticsearch.action.fieldstats
-
- FieldStatsAction - Class in org.elasticsearch.action.fieldstats
-
- FieldStatsRequest - Class in org.elasticsearch.action.fieldstats
-
- FieldStatsRequest() - Constructor for class org.elasticsearch.action.fieldstats.FieldStatsRequest
-
- FieldStatsRequestBuilder - Class in org.elasticsearch.action.fieldstats
-
- FieldStatsRequestBuilder(ElasticsearchClient, FieldStatsAction) - Constructor for class org.elasticsearch.action.fieldstats.FieldStatsRequestBuilder
-
- FieldStatsResponse - Class in org.elasticsearch.action.fieldstats
-
- FieldStatsResponse() - Constructor for class org.elasticsearch.action.fieldstats.FieldStatsResponse
-
- FieldStatsResponse(int, int, int, List<ShardOperationFailedException>, Map<String, Map<String, FieldStats>>) - Constructor for class org.elasticsearch.action.fieldstats.FieldStatsResponse
-
- FieldStatsShardRequest - Class in org.elasticsearch.action.fieldstats
-
- FieldStatsShardRequest() - Constructor for class org.elasticsearch.action.fieldstats.FieldStatsShardRequest
-
- FieldStatsShardRequest(ShardId, FieldStatsRequest) - Constructor for class org.elasticsearch.action.fieldstats.FieldStatsShardRequest
-
- FieldStatsShardResponse - Class in org.elasticsearch.action.fieldstats
-
- FieldStatsShardResponse() - Constructor for class org.elasticsearch.action.fieldstats.FieldStatsShardResponse
-
- FieldStatsShardResponse(ShardId, Map<String, FieldStats>) - Constructor for class org.elasticsearch.action.fieldstats.FieldStatsShardResponse
-
- 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
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
-
- fieldType() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
-
- fieldType - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- fieldType() - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- fieldType - Variable in class org.elasticsearch.index.mapper.FieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- fieldType() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
-
- fieldType() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- fieldType() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
-
- fieldType() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- fieldType() - Method in class org.elasticsearch.search.aggregations.support.FieldContext
-
- fieldType() - Method in class org.elasticsearch.search.lookup.FieldLookup
-
- fieldType() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- fieldType(CompletionFieldMapper.CompletionFieldType) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- 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(String) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- 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.fieldvaluefactor
-
Builder to construct field_value_factor
functions for a function
score query.
- FieldValueFactorFunctionBuilder(String) - Constructor for class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionBuilder
-
- FieldValueFactorFunctionParser - Class in org.elasticsearch.index.query.functionscore.fieldvaluefactor
-
Parses out a function_score function that looks like:
- FieldValueFactorFunctionParser() - Constructor for class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionParser
-
- fifteenMinuteEWMA() - Static method in class org.elasticsearch.common.metrics.EWMA
-
Creates a new EWMA which is equivalent to the UNIX fifteen minute load average and which expects to be ticked
every 5 seconds.
- fifteenMinuteRate() - Method in class org.elasticsearch.common.metrics.MeterMetric
-
- File() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.File
-
- File(String, long, boolean) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.File
-
- file(String) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
-
- FILE_CHUNK - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
-
- FILE_SUFFIX - Static variable in class org.elasticsearch.script.ScriptParameterParser
-
- FileChangesListener - Class in org.elasticsearch.watcher
-
Callback interface that file changes File Watcher is using to notify listeners about changes.
- FileChangesListener() - Constructor for class org.elasticsearch.watcher.FileChangesListener
-
- fileChunkSize() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- fileDetails() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
- fileExists(String) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
-
- FileInfo(String, String, long, String) - Constructor for class org.elasticsearch.index.shard.CommitPoint.FileInfo
-
- FileInfo(String, StoreFileMetaData, ByteSizeValue) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Constructs a new instance of file info
- 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(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(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(int, long) - Method in class org.elasticsearch.index.shard.SnapshotStatus.Index
-
- files(int, long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Sets files stats
- FILES_INFO - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
-
- fileStore - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
-
Cached FileStore from path
- FileSystemUtils - Class in org.elasticsearch.common.io
-
Elasticsearch utils to work with
Path
- FileWatcher - Class in org.elasticsearch.watcher
-
File resources watcher
The file watcher checks directory and all its subdirectories for file changes and notifies its listeners accordingly
- FileWatcher(Path) - Constructor for class org.elasticsearch.watcher.FileWatcher
-
Creates new file watcher on the given directory
- fill(long, long, byte) - Method in interface org.elasticsearch.common.util.ByteArray
-
Fill slots between fromIndex
inclusive to toIndex
exclusive with value
.
- fill(long, long, double) - Method in interface org.elasticsearch.common.util.DoubleArray
-
Fill slots between fromIndex
inclusive to toIndex
exclusive with value
.
- fill(long, long, float) - Method in interface org.elasticsearch.common.util.FloatArray
-
Fill slots between fromIndex
inclusive to toIndex
exclusive with value
.
- fill(long, long, int) - Method in interface org.elasticsearch.common.util.IntArray
-
Fill slots between fromIndex
inclusive to toIndex
exclusive with value
.
- fill(long, long, long) - Method in interface org.elasticsearch.common.util.LongArray
-
Fill slots between fromIndex
inclusive to toIndex
exclusive with value
.
- fillBytesRef(BytesRefBuilder) - Method in class org.elasticsearch.search.suggest.SuggestUtils.TokenConsumer
-
- fillDocIdsToLoad(AtomicArray<IntArrayList>, ScoreDoc[]) - Method in class org.elasticsearch.search.controller.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
-
- filter() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the filter associated with the alias
- filter(String) - 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.Alias
-
Associates a filter to the alias
- filter(QueryBuilder) - 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(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- filter(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- filter() - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- filter(String) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- filter(Map<String, Object>) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- filter(QueryBuilder) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- filter(CompressedXContent) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- filter(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- filter(Map<String, Object>) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- filter(XContentBuilder) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- filter() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- filter - Variable in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
-
- filter(Map<String, Object>, String[], String[]) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
- filter(Terms, LeafReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
-
- 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() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- filter(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Filter
aggregation with the given name.
- Filter - Interface in org.elasticsearch.search.aggregations.bucket.filter
-
A filter
aggregation.
- filter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
-
Set the filter to use, only documents that match this filter will fall
into the bucket defined by this
Filter
aggregation.
- filter(String, QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregationBuilder
-
Add a new filter with the given key.
- filter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregationBuilder
-
Add a new filter with no key.
- filter(String[], String[]) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- 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
-
Builder for the
Filter
aggregation.
- FilterAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
-
Sole constructor.
- FilterAggregator - Class in org.elasticsearch.search.aggregations.bucket.filter
-
Aggregate all docs that match a filter.
- FilterAggregator(String, Weight, AggregatorFactories, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
-
- FilterAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.filter
-
- 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, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
-
- FilterBinaryParseElement - Class in org.elasticsearch.search.query
-
- FilterBinaryParseElement() - Constructor for class org.elasticsearch.search.query.FilterBinaryParseElement
-
- filterChain(RestFilter) - Method in class org.elasticsearch.rest.RestController
-
Returns a filter chain with the final filter being the provided filter.
- filterChainOrNull(RestFilter) - Method in class org.elasticsearch.rest.RestController
-
Returns a filter chain (if needed) to execute.
- FilterClient - Class in org.elasticsearch.client
-
A
Client
that contains another
Client
which it
uses as its basic source, possibly transforming the requests / responses along the
way or providing additional functionality.
- FilterClient(Client) - Constructor for class org.elasticsearch.client.FilterClient
-
Creates a new FilterClient
- filtered(Query, Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
- 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.
- filteredNodes() - Method in class org.elasticsearch.client.transport.TransportClientNodesService
-
- filteredQuery(QueryBuilder, QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- filteredQuery() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- FilteredQueryBuilder - Class in org.elasticsearch.index.query
-
- FilteredQueryBuilder(QueryBuilder, QueryBuilder) - Constructor for class org.elasticsearch.index.query.FilteredQueryBuilder
-
Deprecated.
A query that applies a filter to the results of another query.
- FilteredQueryParser - Class in org.elasticsearch.index.query
-
Deprecated.
- FilteredQueryParser() - Constructor for class org.elasticsearch.index.query.FilteredQueryParser
-
Deprecated.
- FilteredSearchContext - Class in org.elasticsearch.search.internal
-
- FilteredSearchContext(SearchContext) - Constructor for class org.elasticsearch.search.internal.FilteredSearchContext
-
- filterFound - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- filterFound() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- FilterFunction(Query, ScoreFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
-
- 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(String[]) - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- filteringAliases() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
-
- filteringAliases() - Method in class org.elasticsearch.action.exists.ShardExistsRequest
-
- filteringAliases(ClusterState, String, 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.
- filteringAliases() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
-
- filteringAliases() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
-
Deprecated.
- filteringAliases() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- filteringAliases() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
- filteringAliases() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
-
- filteringRequired() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- filterNodeIds(DiscoveryNodes, String[]) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
- filterNodeIds(DiscoveryNodes, String[]) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
- FilterParser - Class in org.elasticsearch.search.aggregations.bucket.filter
-
- FilterParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterParser
-
- FilterPath - Class in org.elasticsearch.common.xcontent.support.filtering
-
- FilterPath(String, String, FilterPath) - Constructor for class org.elasticsearch.common.xcontent.support.filtering.FilterPath
-
- FilterPathBasedFilter - Class in org.elasticsearch.common.xcontent.support.filtering
-
- FilterPathBasedFilter(FilterPath[]) - Constructor for class org.elasticsearch.common.xcontent.support.filtering.FilterPathBasedFilter
-
- FilterPathBasedFilter(String[]) - Constructor for class org.elasticsearch.common.xcontent.support.filtering.FilterPathBasedFilter
-
- filters() - Method in class org.elasticsearch.action.support.ActionFilters
-
Returns the action filters that have been injected
- filters(String) - 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.filters
-
A multi bucket aggregation where the buckets are defined by a set of filters (a bucket per filter).
- Filters.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.filters
-
A bucket associated with a specific filter (identified by its key)
- FILTERS_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.filters.FiltersParser
-
- FiltersAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.filters
-
Builder for the
Filters
aggregation.
- FiltersAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregationBuilder
-
Sole constructor.
- FiltersAggregator - Class in org.elasticsearch.search.aggregations.bucket.filters
-
- FiltersAggregator(String, AggregatorFactories, String[], Weight[], boolean, String, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator
-
- FiltersAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.filters
-
- 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() - 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
-
- filterSettings(ToXContent.Params, Settings) - Static method in class org.elasticsearch.common.settings.SettingsFilter
-
- filterSettings(String, Settings) - Static method in class org.elasticsearch.common.settings.SettingsFilter
-
- FiltersFunctionScoreQuery - Class in org.elasticsearch.common.lucene.search.function
-
A query that allows for a pluggable boost function / filter.
- FiltersFunctionScoreQuery(Query, FiltersFunctionScoreQuery.ScoreMode, FiltersFunctionScoreQuery.FilterFunction[], float, Float) - Constructor for class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
-
- FiltersFunctionScoreQuery.FilterFunction - Class in org.elasticsearch.common.lucene.search.function
-
- FiltersFunctionScoreQuery.ScoreMode - Enum in org.elasticsearch.common.lucene.search.function
-
- FiltersParser - Class in org.elasticsearch.search.aggregations.bucket.filters
-
- FiltersParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.filters.FiltersParser
-
- FilterStreamInput - Class in org.elasticsearch.common.io.stream
-
- FilterStreamInput(StreamInput) - Constructor for class org.elasticsearch.common.io.stream.FilterStreamInput
-
- FINALIZE - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
-
- finalizeRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
-
perform the last stages of recovery once all translog operations are done.
- finalizeRecovery() - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
finalizes the recovery process
- finalizeSnapshot(SnapshotId, List<String>, long, String, int, List<SnapshotShardFailure>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Finalizes snapshotting process
- finalizeSnapshot(SnapshotId, List<String>, long, String, int, List<SnapshotShardFailure>) - Method in interface org.elasticsearch.repositories.Repository
-
Finalizes snapshotting process
- find(BytesRef, int) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Get the id associated with key
- find(BytesRef) - Method in class org.elasticsearch.common.util.BytesRefHash
-
- 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.
- 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.
- findAllIndices() - Method in class org.elasticsearch.env.NodeEnvironment
-
- findAllShardIds(Index) - Method in class org.elasticsearch.env.NodeEnvironment
-
Tries to find all allocated shards for the given index
on the current node.
- 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
-
- findForcedDeletesMerges(SegmentInfos, IndexWriter) - Method in class org.elasticsearch.index.shard.ElasticsearchMergePolicy
-
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, IndexWriter) - Method in class org.elasticsearch.index.shard.ElasticsearchMergePolicy
-
- findHeaderByName(String) - Method in class org.elasticsearch.common.Table
-
- findMappings(String[], String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- findMerges(MergeTrigger, SegmentInfos, IndexWriter) - Method in class org.elasticsearch.index.shard.ElasticsearchMergePolicy
-
- findNameFile(String) - Method in class org.elasticsearch.index.shard.CommitPoint
-
- findNameFile(String) - Method in class org.elasticsearch.index.shard.CommitPoints
-
- findNameFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Finds reference to a snapshotted file by its snapshot name
- findNameIndexFile(String) - Method in class org.elasticsearch.index.shard.CommitPoint
-
- findNameTranslogFile(String) - Method in class org.elasticsearch.index.shard.CommitPoint
-
- 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.
- findNextDelayedAllocationIn(ClusterState) - Static method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Finds the next (closest) delay expiration of an unassigned shard in nanoseconds.
- findParentObjectMapper(ObjectMapper) - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
Returns the parent
ObjectMapper
instance of the specified object mapper or
null
if there
isn't any.
- findPhysicalIndexFile(String) - Method in class org.elasticsearch.index.shard.CommitPoint
-
- findPhysicalIndexFile(String) - Method in class org.elasticsearch.index.shard.CommitPoints
-
- 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
- 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.
- findScopeAnnotation(Errors, Annotation[]) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Returns the scoping annotation, or null if there isn't one.
- findSmallestDelayedAllocationSettingNanos(Settings, ClusterState) - Static method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Finds the smallest delay expiration setting in nanos of all unassigned shards that are still delayed.
- findTemplate(ContentPath, String, String) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
-
- findTemplateBuilder(ParseContext, String, String) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
-
- findTemplateBuilder(ParseContext, String, String, String) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
-
- findWarmers(String[], String[], String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- finishConstruction() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
-
- finishHim() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
-
- 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
-
- FinnishAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- FinnishAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.FinnishAnalyzerProvider
-
- firstOperationOffset - Variable in class org.elasticsearch.index.translog.TranslogReader
-
- fiveMinuteEWMA() - Static method in class org.elasticsearch.common.metrics.EWMA
-
Creates a new EWMA which is equivalent to the UNIX five minute load average and which expects to be ticked every
5 seconds.
- fiveMinuteRate() - Method in class org.elasticsearch.common.metrics.MeterMetric
-
- fixedSourceDistance(double, double, DistanceUnit) - Method in enum org.elasticsearch.common.geo.GeoDistance
-
- FixedSourceDistanceBase(double, double, DistanceUnit) - Constructor for class org.elasticsearch.common.geo.GeoDistance.FixedSourceDistanceBase
-
- fixNegativeQueryIfNeeded(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
- fixWeightedFragInfo(FieldMapper, Field[], FieldFragList.WeightedFragInfo) - Static method in class org.elasticsearch.search.highlight.vectorhighlight.FragmentBuilderHelper
-
Fixes problems with broken analysis chains if positions and offsets are messed up that can lead to
StringIndexOutOfBoundsException
in the
FastVectorHighlighter
- FLAG_CACHE - Static variable in class org.elasticsearch.search.lookup.IndexLookup
-
- FLAG_FREQUENCIES - Static variable in class org.elasticsearch.search.lookup.IndexLookup
-
- FLAG_OFFSETS - Static variable in class org.elasticsearch.search.lookup.IndexLookup
-
- FLAG_PAYLOADS - Static variable in class org.elasticsearch.search.lookup.IndexLookup
-
- FLAG_POSITIONS - Static variable in class org.elasticsearch.search.lookup.IndexLookup
-
- 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
-
- Float() - Constructor for class org.elasticsearch.action.fieldstats.FieldStats.Float
-
- Float(long, long, long, long, float, float) - Constructor for class org.elasticsearch.action.fieldstats.FieldStats.Float
-
- FLOAT - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- FloatArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of double values.
- FloatArrayIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- FloatArrayIndexFieldData(Index, Settings, MappedFieldType.Names, FieldDataType, IndexFieldDataCache, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.FloatArrayIndexFieldData
-
- FloatArrayIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
-
- floatField(FieldInfo, float) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
-
- floatField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- FloatFieldMapper - Class in org.elasticsearch.index.mapper.core
-
- FloatFieldMapper(String, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper
-
- FloatFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
-
- FloatFieldMapper.CustomFloatNumericDocValuesField - Class in org.elasticsearch.index.mapper.core
-
- FloatFieldMapper.CustomFloatNumericField - Class in org.elasticsearch.index.mapper.core
-
- FloatFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
-
- FloatFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
-
- floatToBytes(float) - Static method in class org.elasticsearch.common.Numbers
-
Converts a float to a byte array.
- floatValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- floatValue(boolean) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- floatValue(boolean) - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- floatValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- 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
-
- floor(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- floor(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- floor(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- floor(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- floor(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- FLUSH - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest.Defaults
-
- flush() - 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.forcemerge.ForceMergeRequest
-
Should flush be performed after the merge.
- flush - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- flush(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- 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(FlushRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly flush one or more indices (releasing memory from the node).
- flush(FlushRequest, ActionListener<FlushResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly flush one or more indices (releasing memory from the node).
- flush() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Flush the stream.
- 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.common.xcontent.json.JsonXContentGenerator
-
- flush() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- flush() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
-
- flush(boolean, boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Flushes the state of the engine including the transaction log, clearing memory.
- 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.engine.InternalEngine
-
- flush(boolean, boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
-
- flush() - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- flush(boolean, boolean) - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- flush() - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Flush the flushBuffer
to the breaker, incrementing the total
bytes and resetting the buffer.
- flush(FlushRequest) - Method in class org.elasticsearch.index.shard.IndexShard
-
- flush() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
-
- flush() - Method in class org.elasticsearch.index.translog.BufferingTranslogWriter
-
- flush() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Flushes the buffer if the translog is buffered.
- 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.
- flushBase64() - Method in class org.elasticsearch.common.Base64.OutputStream
-
Method added by PHIL.
- FlushFailedEngineException - Exception in org.elasticsearch.index.engine
-
- FlushFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.FlushFailedEngineException
-
- FlushFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.FlushFailedEngineException
-
- FlushNotAllowedEngineException - Exception in org.elasticsearch.index.engine
-
- FlushNotAllowedEngineException(ShardId, String) - Constructor for exception org.elasticsearch.index.engine.FlushNotAllowedEngineException
-
- FlushNotAllowedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.FlushNotAllowedEngineException
-
- FlushRequest - Class in org.elasticsearch.action.admin.indices.flush
-
A flush request to flush one or more indices.
- FlushRequest() - Constructor for class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
- FlushRequest(ActionRequest) - Constructor for class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
Copy constructor that creates a new flush request that is a copy of the one provided as an argument.
- FlushRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
Constructs a new flush request against one or more indices.
- flushRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a flush indices request.
- 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 - Class in org.elasticsearch.index.flush
-
- FlushStats() - Constructor for class org.elasticsearch.index.flush.FlushStats
-
- FlushStats(long, long) - Constructor for class org.elasticsearch.index.flush.FlushStats
-
- flushStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
- flyweight() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- flyweight() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- flyweight(boolean) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- flyweight() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- fmix(long) - Static method in enum org.elasticsearch.common.hash.MurmurHash3
-
- fmix(long) - Static method in class org.elasticsearch.common.util.BloomFilter
-
- forAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Scoping
-
- forAnyOrigin() - Static method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
Creates a Builder instance with it's origin set to '*'.
- forbidClosedIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
-
- 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_LOCAL_SETTING - Static variable in class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
-
- FORCE_MERGE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- FORCE_MULTI_ORDINALS - Static variable in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Whether to for the use of
MultiOrdinals
to store the ordinals for testing purposes.
- forceCheck() - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
-
check if any shards active status changed, now.
- forcedAnalyzer() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- forcedAnalyzer(Analyzer) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- forcedQuoteAnalyzer() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- forcedQuoteAnalyzer(Analyzer) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- forceMerge(ForceMergeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly force merge one or more indices into a the number of segments.
- forceMerge(ForceMergeRequest, ActionListener<ForceMergeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly force merge one or more indices into a the number of segments.
- forceMerge(boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Optimizes 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.ShadowEngine
-
- forceMerge(ForceMergeRequest) - Method in class org.elasticsearch.index.shard.IndexShard
-
- ForceMergeAction - Class in org.elasticsearch.action.admin.indices.forcemerge
-
- ForceMergeRequest - Class in org.elasticsearch.action.admin.indices.forcemerge
-
A request to force merging the segments of one or more indices.
- ForceMergeRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Constructs a merge request over one or more indices.
- ForceMergeRequest() - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
- forceMergeRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a force merge request.
- 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.
- forceNewTranslog() - Method in class org.elasticsearch.index.engine.EngineConfig
-
if true the engine will start even if the translog id in the commit point can not be found
- forcePut(E) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
Forces adding an element to the queue, without doing size checks.
- forceSource(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
Forces the highlighting to highlight this field based on the source even if this field is stored separately.
- forceSource(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
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.highlight.SearchContextHighlight
-
- 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(TypeLiteral<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns a new injection point for the injectable constructor of type
.
- forConstructorOf(Class<?>) - 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.ImmutableOpenIntMap.Builder
-
- forEach(T) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.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(TypeLiteral<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns all instance method and field injection points on type
.
- forInstanceMethodsAndFields(Class<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns all instance method and field injection points on type
.
- format(Passage[], String) - Method in class org.apache.lucene.search.postingshighlight.CustomPassageFormatter
-
- format() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
-
- format(String, Object...) - Static method in class org.elasticsearch.common.inject.internal.Errors
-
- 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() - Method in class org.elasticsearch.common.joda.FormatDateTimeFormatter
-
- format(String, Object...) - Static method in class org.elasticsearch.common.logging.support.LoggerMessageFormat
-
- format(String, String, Object...) - Static method in class org.elasticsearch.common.logging.support.LoggerMessageFormat
-
- format(InetAddress) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address (with optional host) for display purposes.
- format(InetSocketAddress) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address and port for display purposes.
- format() - Method in class org.elasticsearch.common.unit.TimeValue
-
- format(PeriodType) - Method in class org.elasticsearch.common.unit.TimeValue
-
- format() - Method in class org.elasticsearch.gateway.MetaDataStateFormat
-
Returns the
XContentType
used to serialize xcontent on write.
- format(String) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
-
- FORMAT - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
-
- format(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
In case of date field, we can set the format to be used instead of the mapper format
- FORMAT - Static variable in class org.elasticsearch.index.shard.ShardStateMetaData
-
- format(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
-
Set the format to use for dates.
- format(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
-
Set the format to use to display values.
- format(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
-
Set the format to use to display values.
- format(String) - Method in class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
-
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsBuilder
-
- FORMAT - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsParser
-
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptBuilder
-
- FORMAT - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptParser
-
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumBuilder
-
- FORMAT - Static variable in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumParser
-
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativeBuilder
-
- FORMAT - Static variable in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativeParser
-
- FORMAT - Static variable in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorParser
-
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgBuilder
-
- FORMAT - Static variable in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
-
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffBuilder
-
- FORMAT - Static variable in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffParser
-
- format(String, DateTimeZone) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueFormat.DateTime
-
- format(String) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueFormat.Number
-
- format(long) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.BooleanFormatter
-
- format(double) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.BooleanFormatter
-
- format(long) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
-
- format(double) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
-
- format(long) - Method in interface org.elasticsearch.search.aggregations.support.format.ValueFormatter
-
Formats the given millis time value (since the epoch) to string.
- format(double) - Method in interface org.elasticsearch.search.aggregations.support.format.ValueFormatter
-
- format(long) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.GeoHash
-
- format(double) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.GeoHash
-
- format(long) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.IPv4Formatter
-
- format(double) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.IPv4Formatter
-
- format(long) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Number
-
- format(double) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Number
-
- format(long) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Raw
-
- format(double) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Raw
-
- format() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- format1Decimals(double, String) - Static method in class org.elasticsearch.common.Strings
-
Format the double value with a single decimal points, trimming trailing '.0'.
- FORMAT_KEY - Static variable in class org.elasticsearch.index.fielddata.FieldDataType
-
- formatAddress(InetAddress) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address for display purposes.
- formatAddress(InetSocketAddress) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address and port for display purposes.
- FormatDateTimeFormatter - Class in org.elasticsearch.common.joda
-
A simple wrapper around DateTimeFormatter
that retains the
format that was used to create it.
- FormatDateTimeFormatter(String, DateTimeFormatter, Locale) - Constructor for class org.elasticsearch.common.joda.FormatDateTimeFormatter
-
- FormatDateTimeFormatter(String, DateTimeFormatter, DateTimeFormatter, Locale) - Constructor for class org.elasticsearch.common.joda.FormatDateTimeFormatter
-
- formatInjectionPoint(Formatter, Dependency<?>, InjectionPoint) - Static method in class org.elasticsearch.common.inject.internal.Errors
-
- formatNoCFSRatio(double) - Static method in class org.elasticsearch.index.shard.MergePolicyConfig
-
- formatSource(Formatter, Object) - Static method in class org.elasticsearch.common.inject.internal.Errors
-
- formattable(boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser.Builder
-
- formatter(ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.BucketStreamContext
-
- formatter() - Method in class org.elasticsearch.search.aggregations.bucket.BucketStreamContext
-
- formatter - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
- formatter - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- formatter - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- formatter - Variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
-
- formatter - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.AbstractHDRPercentilesAggregator
-
- formatter - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.AbstractTDigestPercentilesAggregator
-
- formatter - Variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
-
- formatter() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormat
-
- formatter() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- 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.builders.ShapeBuilder.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.
- forOrigin(String) - Static method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
- forOrigins(String...) - Static method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
- forPattern(String) - Static method in class org.elasticsearch.common.joda.Joda
-
- forPattern(String, Locale) - 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(Pattern) - Static method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
- forStaticMethodsAndFields(TypeLiteral) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns all static method and field injection points on type
.
- forStaticMethodsAndFields(Class<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns all static method and field injection points on type
.
- forType(Class<?>) - Static method in class org.elasticsearch.common.inject.internal.StackTraceElements
-
- found() - Method in class org.elasticsearch.index.engine.Engine.Delete
-
- foundParents() - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- fpp - Variable in class org.elasticsearch.common.util.BloomFilter.Factory.Entry
-
- 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.
- FQueryFilterParser - Class in org.elasticsearch.index.query
-
Deprecated.
- FQueryFilterParser() - Constructor for class org.elasticsearch.index.query.FQueryFilterParser
-
Deprecated.
- FragmentBuilderHelper - Class in org.elasticsearch.search.highlight.vectorhighlight
-
Simple helper class for FastVectorHighlighter
FragmentsBuilder
implemenations.
- fragmentCharSize() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- fragmenter(String) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
Sets what fragmenter to use to break up text that is eligible for highlighting.
- fragmenter(String) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
Sets what fragmenter to use to break up text that is eligible for highlighting.
- fragmenter() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- fragmentOffset(int) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
- fragmentOffset() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- fragments() - Method in class org.elasticsearch.search.highlight.HighlightField
-
The highlighted fragments.
- fragmentSize(int) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
- fragmentSize(Integer) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
Sets the size of a fragment in characters (defaults to 100)
- FREE_CONTEXT_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- FREE_CONTEXT_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- freeAllScrollContexts() - Method in class org.elasticsearch.search.SearchService
-
- freeContext(long) - Method in class org.elasticsearch.search.SearchService
-
- freeDiskPercentageAfterShardAssigned(DiskUsage, Long) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Given the DiskUsage for a node and the size of the shard, return the
percentage of free disk if the shard were to be allocated to the node.
- freeze() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- freeze() - Method in class org.elasticsearch.index.query.support.XContentStructure
-
"Freeze" the parsing content, which means copying the current parser's
structure into an internal
BytesReference
to be parsed later.
- 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.
- FrenchAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- FrenchAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.FrenchAnalyzerProvider
-
- FrenchStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- FrenchStemTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.FrenchStemTokenFilterFactory
-
- freq() - Method in class org.elasticsearch.index.search.child.ConstantScorer
-
- freq - Variable in class org.elasticsearch.search.lookup.PositionIterator
-
- 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.index.fielddata.plain.AbstractIndexOrdinalsFieldData
-
- frequency(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
-
- frequency - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
-
- 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 - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion
-
- Frequency() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Frequency
-
- frequency() - Method in class org.elasticsearch.watcher.WatcherHandle
-
- from(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- from(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- from(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- from(int) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- from(long) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- from(float) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- from(double) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- from() - Method in class org.elasticsearch.percolator.PercolateContext
-
- from(int) - Method in class org.elasticsearch.percolator.PercolateContext
-
- from - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- from - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
-
- FROM - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
-
- from(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
From index to start the search from.
- from() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- from(int) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- from() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- from(int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- from() - Method in class org.elasticsearch.search.internal.SearchContext
-
- from(int) - Method in class org.elasticsearch.search.internal.SearchContext
-
- from() - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- from(int) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- from() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- from(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- FROM_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
-
- fromByte(byte) - Static method in class org.elasticsearch.common.Priority
-
- fromBytes(byte[], DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
-
- fromDiff(boolean) - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- fromEdits(int) - Static method in class org.elasticsearch.common.unit.Fuzziness
-
Creates a
Fuzziness
instance from an edit distance.
- fromGeohash(String) - Static method in class org.elasticsearch.common.geo.GeoPoint
-
- fromGeohash(long) - 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.index.IndexRequest.OpType
-
Constructs the operation type from its internal representation.
- 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.action.WriteConsistencyLevel
-
- 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(byte) - Static method in enum org.elasticsearch.indices.recovery.RecoveryState.Type
-
- fromId(byte) - Static method in enum org.elasticsearch.search.suggest.Suggest.Suggestion.Sort
-
- fromId(int) - Static method in class org.elasticsearch.Version
-
- fromIndexLong(long) - Static method in class org.elasticsearch.common.geo.GeoPoint
-
- fromMap(Map<String, Object>, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
-
- fromMap(Map<String, Object>) - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom
-
- fromMap(Map<String, Object>) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData
-
- fromMeters(double) - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Convert a value given in meters to a value of this unit
- fromName(String) - Static method in enum org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
-
- 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, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
-
- fromParameters(Object, Object, Object, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
-
- FromParseElement - Class in org.elasticsearch.search.query
-
- FromParseElement() - Constructor for class org.elasticsearch.search.query.FromParseElement
-
- fromRequest(RestRequest, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
-
- fromRequest(RestRequest, ClearIndicesCacheRequest, ParseFieldMatcher) - Static method in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction
-
- fromRestContentType(String) - Static method in enum org.elasticsearch.common.xcontent.XContentType
-
- fromStatus(int) - Static method in enum org.elasticsearch.common.cli.CliTool.ExitStatus
-
- fromString(String) - Static method in enum org.apache.lucene.store.StoreRateLimiting.Type
-
- fromString(String) - Static method in enum org.elasticsearch.action.index.IndexRequest.OpType
-
- fromString(String, ParseFieldMatcher) - Static method in enum org.elasticsearch.action.search.SearchType
-
- fromString(String) - Static method in enum org.elasticsearch.action.WriteConsistencyLevel
-
- 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.GeoDistance
-
- fromString(String) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
-
- fromString(String) - Static method in enum org.elasticsearch.index.fielddata.IndexFieldData.CommonSettings.MemoryStorageFormat
-
- fromString(String) - Static method in enum org.elasticsearch.index.mapper.object.DynamicTemplate.MatchType
-
- fromString(String) - Static method in enum org.elasticsearch.index.search.child.ScoreType
-
- fromString(String) - Static method in enum org.elasticsearch.index.translog.TranslogWriter.Type
-
- fromString(String) - Static method in enum org.elasticsearch.index.VersionType
-
- fromString(String, VersionType) - Static method in enum org.elasticsearch.index.VersionType
-
- fromString(String, ParseFieldMatcher) - Static method in enum org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
-
- fromString(String, ParseFieldMatcher) - Static method in enum org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory.ExecutionMode
-
- fromString(String, ParseFieldMatcher) - Static method in enum org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
-
- fromString(String) - Static method in enum org.elasticsearch.search.MultiValueMode
-
- 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
- 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.cluster.health.ClusterHealthStatus
-
- fromValue(byte) - Static method in enum org.elasticsearch.cluster.metadata.AliasAction.Type
-
- 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(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.cluster.metadata.AliasMetaData.Builder
-
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- fromXContent(XContentParser) - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom
-
- fromXContent(XContentParser, ParseFieldMatcher) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- fromXContent(XContentParser) - Method in interface org.elasticsearch.cluster.metadata.MetaData.Custom
-
- fromXContent(XContentParser, ParseFieldMatcher) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- fromXContent(XContentParser) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- fromXContent(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand.Factory
-
- fromXContent(XContentParser) - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand.Factory
-
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
- fromXContent(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand.Factory
-
- fromXContent(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand.Factory
-
- fromXContent(XContentParser, ParseFieldMatcher) - Method in interface org.elasticsearch.common.xcontent.FromXContentBuilder
-
Parses an object with the type T from parser
- 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(byte[]) - Static method in class org.elasticsearch.index.shard.CommitPoints
-
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Parses JSON that represents file info
- fromXContent(XContentParser, ParseFieldMatcher) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Parses shard snapshot metadata
- fromXContent(XContentParser, ParseFieldMatcher) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
- fromXContent(XContentParser) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData
-
- fromXContent(XContentParser, ParseFieldMatcher) - Method in class org.elasticsearch.snapshots.Snapshot
-
- fromXContent(XContentParser) - Static method in class org.elasticsearch.snapshots.Snapshot
-
- fromXContent(XContentParser) - Static method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
Deserializes snapshot failure information from JSON
- FromXContentBuilder<T> - Interface in org.elasticsearch.common.xcontent
-
Indicates that the class supports XContent deserialization.
- 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.
- FsBlobContainer - Class in org.elasticsearch.common.blobstore.fs
-
- FsBlobContainer(FsBlobStore, BlobPath, Path) - Constructor for class org.elasticsearch.common.blobstore.fs.FsBlobContainer
-
- FsBlobStore - Class in org.elasticsearch.common.blobstore.fs
-
- FsBlobStore(Settings, Path) - Constructor for class org.elasticsearch.common.blobstore.fs.FsBlobStore
-
- FsDirectoryService - Class in org.elasticsearch.index.store
-
- FsDirectoryService(IndexSettingsService, IndexStore, ShardPath) - Constructor for class org.elasticsearch.index.store.FsDirectoryService
-
- FsDirectoryService(Settings, IndexStore, ShardPath) - Constructor for class org.elasticsearch.index.store.FsDirectoryService
-
- FsInfo - Class in org.elasticsearch.monitor.fs
-
- FsInfo(long, FsInfo.Path[]) - Constructor for class org.elasticsearch.monitor.fs.FsInfo
-
- FsInfo.Path - Class in org.elasticsearch.monitor.fs
-
- FsProbe - Class in org.elasticsearch.monitor.fs
-
- FsProbe(Settings, NodeEnvironment) - Constructor for class org.elasticsearch.monitor.fs.FsProbe
-
- FsRepository - Class in org.elasticsearch.repositories.fs
-
Shared file system implementation of the BlobStoreRepository
- FsRepository(RepositoryName, RepositorySettings, IndexShardRepository, Environment) - Constructor for class org.elasticsearch.repositories.fs.FsRepository
-
Constructs new shared file system repository
- FsService - Class in org.elasticsearch.monitor.fs
-
- FsService(Settings, FsProbe) - Constructor for class org.elasticsearch.monitor.fs.FsService
-
- fsService() - Method in class org.elasticsearch.monitor.MonitorService
-
- fullName() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
-
- fullName() - Method in class org.elasticsearch.index.mapper.MappedFieldType.Names
-
The full name, including dot path.
- fullName(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
- fullPath() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- fullPathAsText(String) - Method in class org.elasticsearch.index.mapper.ContentPath
-
- function - Variable in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
-
- functionParsers - Variable in class org.elasticsearch.index.query.functionscore.ScoreFunctionParserMapper
-
- FunctionScoreQuery - Class in org.elasticsearch.common.lucene.search.function
-
A query that allows for a pluggable boost function to be applied to it.
- FunctionScoreQuery(Query, ScoreFunction, Float) - Constructor for class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- FunctionScoreQuery(Query, ScoreFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- functionScoreQuery(QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that allows to define a custom scoring function.
- functionScoreQuery() - 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, ScoreFunctionBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that allows to define a custom scoring 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(QueryBuilder) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Creates a function_score query that executes on documents that match query a query.
- FunctionScoreQueryBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
- FunctionScoreQueryBuilder(ScoreFunctionBuilder) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Creates a function_score query that will execute the function scoreFunctionBuilder on all documents.
- FunctionScoreQueryParser - Class in org.elasticsearch.index.query.functionscore
-
- FunctionScoreQueryParser(ScoreFunctionParserMapper) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryParser
-
- 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 - 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(Fuzziness) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
-
- 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.QueryStringQueryBuilder
-
Set the edit distance for fuzzy queries.
- fuzziness - Variable in class org.elasticsearch.index.search.MatchQuery
-
- fuzzyCompletionSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a fuzzy completion suggestion lookup query with the provided name
- fuzzyMaxExpansions() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- fuzzyMaxExpansions(int) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- fuzzyMaxExpansions(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
- fuzzyPrefixLength() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- fuzzyPrefixLength(int) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- fuzzyPrefixLength(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set the minimum prefix length for fuzzy queries.
- fuzzyPrefixLength - Variable in class org.elasticsearch.index.search.MatchQuery
-
- fuzzyQuery(Object, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- fuzzyQuery(Object, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.DoubleFieldType
-
- fuzzyQuery(Object, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- fuzzyQuery(Object, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.LongFieldType
-
- fuzzyQuery(Object, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.NumberFieldType
-
- fuzzyQuery(Object, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- fuzzyQuery(Object, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- fuzzyQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents using fuzzy query.
- fuzzyQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents using fuzzy query.
- FuzzyQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that does fuzzy matching for a specific value.
- 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(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, float) - 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, boolean) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Constructs a new fuzzy query.
- FuzzyQueryParser - Class in org.elasticsearch.index.query
-
- FuzzyQueryParser() - Constructor for class org.elasticsearch.index.query.FuzzyQueryParser
-
- fuzzyRewrite(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
- fuzzyRewrite(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
- fuzzyRewrite(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
- fuzzyRewriteMethod() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- fuzzyRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- fuzzyRewriteMethod - Variable in class org.elasticsearch.index.search.MatchQuery
-
- fuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
- GalicianAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- GalicianAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GalicianAnalyzerProvider
-
- gamma(double) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
-
- GAP_POLICY - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptParser
-
- GAP_POLICY - Static variable in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumParser
-
- GAP_POLICY - Static variable in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativeParser
-
- GAP_POLICY - Static variable in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorParser
-
- GAP_POLICY - Static variable in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
-
- GAP_POLICY - Static variable in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffParser
-
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsBuilder
-
- gapPolicy - Variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
-
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptBuilder
-
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativeBuilder
-
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorBuilder
-
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgBuilder
-
Defines what should be done when a gap in the series is discovered
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffBuilder
-
- Gateway - Class in org.elasticsearch.gateway
-
- Gateway(Settings, ClusterService, NodeEnvironment, GatewayMetaState, TransportNodesListGatewayMetaState, ClusterName) - Constructor for class org.elasticsearch.gateway.Gateway
-
- Gateway.GatewayStateRecoveredListener - Interface in org.elasticsearch.gateway
-
- GATEWAY_TYPE_KEY - Static variable in class org.elasticsearch.gateway.GatewayModule
-
- GatewayAllocator - Class in org.elasticsearch.gateway
-
- GatewayAllocator(Settings, 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, DanglingIndicesState, TransportNodesListGatewayMetaState, MetaDataIndexUpgradeService) - Constructor for class org.elasticsearch.gateway.GatewayMetaState
-
- GatewayMetaState.IndexMetaWriteInfo - Class in org.elasticsearch.gateway
-
- GatewayModule - Class in org.elasticsearch.gateway
-
- GatewayModule(Settings) - Constructor for class org.elasticsearch.gateway.GatewayModule
-
- GatewayService - Class in org.elasticsearch.gateway
-
- GatewayService(Settings, Gateway, AllocationService, ClusterService, DiscoveryService, ThreadPool) - Constructor for class org.elasticsearch.gateway.GatewayService
-
- gaussDecayFunction(String, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- gaussDecayFunction(String, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- GaussDecayFunctionBuilder - Class in org.elasticsearch.index.query.functionscore.gauss
-
- GaussDecayFunctionBuilder(String, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.gauss.GaussDecayFunctionBuilder
-
- GaussDecayFunctionParser - Class in org.elasticsearch.index.query.functionscore.gauss
-
- GaussDecayFunctionParser() - Constructor for class org.elasticsearch.index.query.functionscore.gauss.GaussDecayFunctionParser
-
- gb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- gbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- GcNames - Class in org.elasticsearch.monitor.jvm
-
- GcNames() - Constructor for class org.elasticsearch.monitor.jvm.GcNames
-
- generateClusterUuidIfNeeded() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- generateKey(double, double, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- generateNodeId(Settings) - Static method in class org.elasticsearch.discovery.DiscoveryService
-
- generatesCharacterTokenStream(Analyzer, String) - Static method in class org.elasticsearch.index.analysis.Analysis
-
Check whether TokenStream
s generated with analyzer
provide with character terms.
- generation - Variable in class org.elasticsearch.index.translog.Translog.Location
-
- generation - Variable in class org.elasticsearch.index.translog.TranslogReader
-
- generator - Variable in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
-
Generator used to write content
- generator() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- generic() - Method in class org.elasticsearch.threadpool.ThreadPool
-
- 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_HASH_PRECISION - Static variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Defaults
-
- 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
-
- GeoBoundingBoxQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
- GeoBoundingBoxQueryParser - Class in org.elasticsearch.index.query
-
- GeoBoundingBoxQueryParser() - Constructor for class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- 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.
- GeoBoundsAggregator - Class in org.elasticsearch.search.aggregations.metrics.geobounds
-
- GeoBoundsAggregator(String, AggregationContext, Aggregator, ValuesSource.GeoPoint, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
-
- GeoBoundsAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.geobounds
-
- GeoBoundsBuilder - Class in org.elasticsearch.search.aggregations.metrics.geobounds
-
- GeoBoundsBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsBuilder
-
Sole constructor.
- GeoBoundsParser - Class in org.elasticsearch.search.aggregations.metrics.geobounds
-
- GeoBoundsParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsParser
-
- 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
-
- GeoCentroidAggregator - Class in org.elasticsearch.search.aggregations.metrics.geocentroid
-
A geo metric aggregator that computes a geo-centroid from a geo_point
type field
- GeoCentroidAggregator(String, AggregationContext, Aggregator, ValuesSource.GeoPoint, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidAggregator
-
- GeoCentroidAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.geocentroid
-
- GeoCentroidBuilder - Class in org.elasticsearch.search.aggregations.metrics.geocentroid
-
- GeoCentroidBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidBuilder
-
- GeoCentroidParser - Class in org.elasticsearch.search.aggregations.metrics.geocentroid
-
- GeoCentroidParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidParser
-
- 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
- geoDisjointQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- GeoDistance - Enum in org.elasticsearch.common.geo
-
Geo distance calculation.
- geoDistance(GeoDistance) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
- geoDistance(GeoDistance) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- geoDistance() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeQuery
-
- geoDistance(String) - 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.search.sort.GeoDistanceSortBuilder
-
The geo distance type used to compute the distance.
- GeoDistance.ArcFixedSourceDistance - Class in org.elasticsearch.common.geo
-
- GeoDistance.DistanceBoundingCheck - Interface in org.elasticsearch.common.geo
-
- GeoDistance.FactorFixedSourceDistance - Class in org.elasticsearch.common.geo
-
- GeoDistance.FixedSourceDistance - Interface in org.elasticsearch.common.geo
-
- GeoDistance.FixedSourceDistanceBase - Class in org.elasticsearch.common.geo
-
- GeoDistance.Meridian180DistanceBoundingCheck - Class in org.elasticsearch.common.geo
-
- GeoDistance.PlaneFixedSourceDistance - Class in org.elasticsearch.common.geo
-
- GeoDistance.SimpleDistanceBoundingCheck - Class in org.elasticsearch.common.geo
-
- GeoDistance.SloppyArcFixedSourceDistance - Class in org.elasticsearch.common.geo
-
- GeoDistanceBuilder - Class in org.elasticsearch.search.aggregations.bucket.range.geodistance
-
- GeoDistanceBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
Sole constructor.
- GeoDistanceBuilder.Range - Class in org.elasticsearch.search.aggregations.bucket.range.geodistance
-
A range of values.
- GeoDistanceParser - Class in org.elasticsearch.search.aggregations.bucket.range.geodistance
-
- GeoDistanceParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceParser
-
- 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
-
- GeoDistanceQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
- GeoDistanceQueryParser - Class in org.elasticsearch.index.query
-
{
"name.lat" : 1.1,
"name.lon" : 1.2,
}
- GeoDistanceQueryParser() - Constructor for class org.elasticsearch.index.query.GeoDistanceQueryParser
-
- geoDistanceRangeQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter based on a specific range from a specific geo location / point.
- GeoDistanceRangeQuery - Class in org.elasticsearch.index.search.geo
-
- GeoDistanceRangeQuery(GeoPoint, Double, Double, boolean, boolean, GeoDistance, BaseGeoPointFieldMapper.GeoPointFieldType, IndexGeoPointFieldData, String) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceRangeQuery
-
- GeoDistanceRangeQueryBuilder - Class in org.elasticsearch.index.query
-
- GeoDistanceRangeQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- GeoDistanceRangeQueryParser - Class in org.elasticsearch.index.query
-
{
"name.lat" : 1.1,
"name.lon" : 1.2,
}
- GeoDistanceRangeQueryParser() - Constructor for class org.elasticsearch.index.query.GeoDistanceRangeQueryParser
-
- geoDistanceSort(String) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
A geo distance based sort.
- GeoDistanceSortBuilder - Class in org.elasticsearch.search.sort
-
A geo distance based sorting on a geo point like field.
- GeoDistanceSortBuilder(String) - Constructor for class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Constructs a new distance based sort on a geo point like field.
- GeoDistanceSortParser - Class in org.elasticsearch.search.sort
-
- GeoDistanceSortParser() - Constructor for class org.elasticsearch.search.sort.GeoDistanceSortParser
-
- geohash() - Method in class org.elasticsearch.common.geo.GeoPoint
-
- GEOHASH - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
- GEOHASH - Static variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Names
-
- geohash(String) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
- geohash(String) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- geohash(String) - Method in class org.elasticsearch.index.query.GeohashCellQuery.Builder
-
- geohash(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
Set the point to calculate distances from using its geohash.
- GEOHASH - Static variable in interface org.elasticsearch.search.aggregations.support.format.ValueFormatter
-
- GeoHash() - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormatter.GeoHash
-
- GEOHASH_LEVELS - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
-
- geoHashCellHeight(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the height (in meters) of geohash cells at a specific level
- GeohashCellQuery - Class in org.elasticsearch.index.query
-
A geohash cell filter that filters
GeoPoint
s by their geohashes.
- GeohashCellQuery() - Constructor for class org.elasticsearch.index.query.GeohashCellQuery
-
- geoHashCellQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter based on a bounding box defined by geohash.
- geoHashCellQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter based on a bounding box defined by geohash.
- geoHashCellQuery(String, GeoPoint) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter based on a bounding box defined by geohash.
- geoHashCellQuery(String, String, boolean) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter based on a bounding box defined by geohash.
- GeohashCellQuery.Builder - Class in org.elasticsearch.index.query
-
Builder for a geohashfilter.
- GeohashCellQuery.Parser - Class in org.elasticsearch.index.query
-
- 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
-
- geohashDistanceInKm(String) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- geohashDistanceInMiles(String) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- geohashes(String...) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The geohash of the geo point to create the range distance facets from.
- geoHashFieldType - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- geoHashFieldType() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- 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.
- GeoHashGridAggregator(String, AggregatorFactories, GeoHashGridParser.GeoGridFactory.CellIdSource, int, int, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
-
- GeoHashGridBuilder - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Creates an aggregation based on bucketing points into GeoHashes
- GeoHashGridBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridBuilder
-
Sole constructor.
- GeoHashGridParser - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Aggregates Geo information into cells determined by geohashes of a given precision.
- GeoHashGridParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridParser
-
- 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.
- geoHashMapper - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- geoHashPrecision - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- geoHashPrecision(int) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- geoHashPrecision - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- geoHashPrecision() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- geoHashPrefix(boolean) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- geoHashPrefixEnabled - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- geoIntersectionQuery(String, ShapeBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter indexed shapes intersecting with shapes
- geoIntersectionQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- GeolocationContextMapping - Class in org.elasticsearch.search.suggest.context
-
- GeolocationContextMapping(String, int[], boolean, Collection<String>, String) - Constructor for class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- GeolocationContextMapping.Builder - Class in org.elasticsearch.search.suggest.context
-
- GeometryCollectionBuilder - Class in org.elasticsearch.common.geo.builders
-
- GeometryCollectionBuilder() - Constructor for class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- GeometryCollectionBuilder(ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- GeoPoint - Class in org.elasticsearch.common.geo
-
- GeoPoint() - Constructor for class org.elasticsearch.common.geo.GeoPoint
-
- GeoPoint(String) - Constructor for class org.elasticsearch.common.geo.GeoPoint
-
Create a new Geopointform a string.
- GeoPoint(double, double) - Constructor for class org.elasticsearch.common.geo.GeoPoint
-
- geoPoint() - Method in class org.elasticsearch.search.aggregations.support.GeoPointParser
-
- GeoPoint() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
-
- geoPoint(String, InternalAggregation.Type, SearchContext) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
-
- GeoPointArrayAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- GeoPointArrayAtomicFieldData() - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointArrayAtomicFieldData
-
- GeoPointArrayAtomicFieldData.Single - Class in org.elasticsearch.index.fielddata.plain
-
- GeoPointArrayIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
Loads FieldData for an array of GeoPoints supporting both long encoded points and backward compatible double arrays
- GeoPointArrayIndexFieldData(Index, Settings, MappedFieldType.Names, FieldDataType, IndexFieldDataCache, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointArrayIndexFieldData
-
- GeoPointArrayIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
-
- GeoPointArrayLegacyAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- GeoPointArrayLegacyAtomicFieldData() - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointArrayLegacyAtomicFieldData
-
- GeoPointArrayLegacyAtomicFieldData.Single - Class in org.elasticsearch.index.fielddata.plain
-
Assumes unset values are marked in bitset, and docId is used as the index to the value array.
- GeoPointDVIndexFieldData(Index, MappedFieldType.Names, FieldDataType, boolean) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractGeoPointDVIndexFieldData.GeoPointDVIndexFieldData
-
- GeoPointFieldMapper - Class in org.elasticsearch.index.mapper.geo
-
Parsing: We handle:
- GeoPointFieldMapper(String, MappedFieldType, MappedFieldType, Settings, ContentPath.Type, DoubleFieldMapper, DoubleFieldMapper, StringFieldMapper, FieldMapper.MultiFields, Explicit<Boolean>, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
-
- GeoPointFieldMapper.Builder - Class in org.elasticsearch.index.mapper.geo
-
Concrete builder for indexed GeoPointField type
- GeoPointFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.geo
-
- GeoPointFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.geo
-
- GeoPointFieldMapperLegacy - Class in org.elasticsearch.index.mapper.geo
-
Parsing: We handle:
- GeoPointFieldMapperLegacy(String, MappedFieldType, MappedFieldType, Settings, ContentPath.Type, DoubleFieldMapper, DoubleFieldMapper, StringFieldMapper, FieldMapper.MultiFields, Explicit<Boolean>, Explicit<Boolean>, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy
-
- GeoPointFieldMapperLegacy.Builder - Class in org.elasticsearch.index.mapper.geo
-
Concrete builder for legacy GeoPointField
- GeoPointFieldMapperLegacy.CustomGeoPointDocValuesField - Class in org.elasticsearch.index.mapper.geo
-
- GeoPointFieldMapperLegacy.Defaults - Class in org.elasticsearch.index.mapper.geo
-
- GeoPointFieldMapperLegacy.Encoding - Class in org.elasticsearch.index.mapper.geo
-
A byte-aligned fixed-length encoding for latitudes and longitudes.
- GeoPointFieldMapperLegacy.Names - Class in org.elasticsearch.index.mapper.geo
-
- GeoPointParser - Class in org.elasticsearch.search.aggregations.support
-
- GeoPointParser(String, InternalAggregation.Type, SearchContext, ParseField) - Constructor for class org.elasticsearch.search.aggregations.support.GeoPointParser
-
- GeoPoints(MultiGeoPointValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- GeoPointValues - Class in org.elasticsearch.index.fielddata
-
Per-document geo-point values.
- GeoPointValues() - Constructor for class org.elasticsearch.index.fielddata.GeoPointValues
-
- 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
-
- geoPolygonQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter based on a polygon defined by a set of locations / points.
- GeoPolygonQuery - Class in org.elasticsearch.index.search.geo
-
- GeoPolygonQuery(IndexGeoPointFieldData, GeoPoint...) - Constructor for class org.elasticsearch.index.search.geo.GeoPolygonQuery
-
- GeoPolygonQueryBuilder - Class in org.elasticsearch.index.query
-
- GeoPolygonQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
- GeoPolygonQueryParser - Class in org.elasticsearch.index.query
-
{
"pin.location" : {
"points" : [
{ "lat" : 12, "lon" : 40},
{}
]
}
}
- GeoPolygonQueryParser() - Constructor for class org.elasticsearch.index.query.GeoPolygonQueryParser
-
- geoShapeField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- GeoShapeFieldMapper - Class in org.elasticsearch.index.mapper.geo
-
FieldMapper for indexing Shape
s.
- GeoShapeFieldMapper(String, MappedFieldType, Explicit<Boolean>, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
-
- GeoShapeFieldMapper.Builder - Class in org.elasticsearch.index.mapper.geo
-
- GeoShapeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.geo
-
- GeoShapeFieldMapper.GeoShapeFieldType - Class in org.elasticsearch.index.mapper.geo
-
- GeoShapeFieldMapper.Names - Class in org.elasticsearch.index.mapper.geo
-
- GeoShapeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.geo
-
- GeoShapeFieldType() - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- GeoShapeFieldType(GeoShapeFieldMapper.GeoShapeFieldType) - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- geoShapeQuery(String, ShapeBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Query that matches Documents based on the relationship between the given shape and
indexed shapes
- geoShapeQuery(String, ShapeBuilder, ShapeRelation) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter based on the relationship of a shape and indexed shapes
- geoShapeQuery(String, String, String, ShapeRelation) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- geoShapeQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- GeoShapeQueryBuilder - Class in org.elasticsearch.index.query
-
- GeoShapeQueryBuilder(String, ShapeBuilder) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Creates a new GeoShapeQueryBuilder whose Filter will be against the
given field name using the given Shape
- GeoShapeQueryBuilder(String, ShapeBuilder, ShapeRelation) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Creates a new GeoShapeQueryBuilder whose Filter will be against the
given field name using the given Shape
- GeoShapeQueryBuilder(String, String, String, ShapeRelation) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Creates a new GeoShapeQueryBuilder whose Filter will be against the given field name
and will use the Shape found with the given ID in the given type
- GeoShapeQueryParser - Class in org.elasticsearch.index.query
-
- GeoShapeQueryParser() - Constructor for class org.elasticsearch.index.query.GeoShapeQueryParser
-
- GeoShapeQueryParser.DEFAULTS - Class in org.elasticsearch.index.query
-
- GeoUtils - Class in org.elasticsearch.common.geo
-
- geoWithinQuery(String, ShapeBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter indexed shapes that are contained by a shape
- geoWithinQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- GermanAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- GermanAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GermanAnalyzerProvider
-
- GermanNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory for GermanNormalizationFilter
- GermanNormalizationFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GermanNormalizationFilterFactory
-
- GermanStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- GermanStemTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GermanStemTokenFilterFactory
-
- 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() - Method in class org.elasticsearch.action.ActionRequestBuilder
-
Short version of execute().actionGet().
- get(TimeValue) - Method in class org.elasticsearch.action.ActionRequestBuilder
-
Short version of execute().actionGet().
- get(String) - Method in class org.elasticsearch.action.ActionRequestBuilder
-
Short version of execute().actionGet().
- get - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- get(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- get() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- 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, 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) - Method in class org.elasticsearch.client.support.AbstractClient
-
- get(GetRequest, ActionListener<GetResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
- get() - Method in class org.elasticsearch.cluster.AbstractDiffable
-
- get(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- get(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a node by its id
- get(int) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
- get(int) - Method in class org.elasticsearch.common.bytes.BytesArray
-
- get(int) - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns the byte at the specified index.
- get(int) - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- get(int) - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- get(Object) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
- get(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- get(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
- get(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- get(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
- get(K) - Method in class org.elasticsearch.common.collect.MapBuilder
-
- get() - Method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider
-
- get() - Method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider2
-
- get(K, Errors) - Method in class org.elasticsearch.common.inject.internal.FailableCache
-
- 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() - 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(Class<T>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type.
- 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(Class<T>, Annotation) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation.
- get(Type) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type.
- 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(Type, Annotation) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation.
- get(TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type.
- 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(TypeLiteral<T>, Annotation) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation.
- 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(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() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup.ProviderImpl
-
- get(Type) - Static method in class org.elasticsearch.common.inject.TypeLiteral
-
Gets type literal for the given Type
instance.
- get(Class<T>) - Static method in class org.elasticsearch.common.inject.TypeLiteral
-
Gets type literal for the given Class
instance.
- get(String, String...) - Static method in class org.elasticsearch.common.io.PathUtils
-
Returns a Path
from name components.
- get(URI) - Static method in class org.elasticsearch.common.io.PathUtils
-
Returns a Path
from a URI
- get(Path[], String) - Static method in class org.elasticsearch.common.io.PathUtils
-
Tries to resolve the given path against the list of available roots.
- get(Path[], URI) - Static method in class org.elasticsearch.common.io.PathUtils
-
Tries to resolve the given file uri against the list of available roots.
- 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.common.settings.Settings
-
Returns the setting value associated with the first setting key.
- get(String, String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value associated with the setting key.
- get(String[], String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value associated with the first setting key, if none exists,
returns the default value provided.
- get(long) - Method in interface org.elasticsearch.common.util.ByteArray
-
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, BytesRef) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Return the key at 0 <= index <= capacity()
.
- get(int) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Gets the current value at position i
.
- get(long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- get() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- get(long) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- get(Object) - 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 if key
was not present in the hash table.
- get(long) - Method in interface org.elasticsearch.common.util.ObjectArray
-
Get an element given its index.
- get() - Method in interface org.elasticsearch.index.analysis.AnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.ArabicAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.ArmenianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.BasqueAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.BrazilianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.BulgarianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.CatalanAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.ChineseAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.CjkAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.CustomAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.CzechAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.DanishAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.DutchAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.EnglishAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.FinnishAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.FrenchAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.GalicianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.GermanAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.GreekAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.HindiAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.HungarianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.IndonesianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.IrishAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.ItalianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.KeywordAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.LatvianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.LithuanianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.NorwegianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.PatternAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.PersianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.PortugueseAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.RomanianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.RussianAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.SimpleAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.SnowballAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.SoraniAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.SpanishAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.StandardAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.StandardHtmlStripAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.StopAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.SwedishAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.ThaiAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.TurkishAnalyzerProvider
-
- get() - Method in class org.elasticsearch.index.analysis.WhitespaceAnalyzerProvider
-
- get(Engine.Get) - Method in class org.elasticsearch.index.engine.Engine
-
- Get(boolean, Term) - Constructor for class org.elasticsearch.index.engine.Engine.Get
-
- get(Engine.Get) - Method in class org.elasticsearch.index.engine.InternalEngine
-
- get() - Method in class org.elasticsearch.index.engine.RecoveryCounter
-
- get(Engine.Get) - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- get(int) - Method in class org.elasticsearch.index.fielddata.GeoPointValues
-
- get(int) - Method in class org.elasticsearch.index.fielddata.NumericDoubleValues
-
Returns the numeric value for the specified document ID.
- 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(String, String, String[], boolean, long, VersionType, FetchSourceContext, boolean) - Method in class org.elasticsearch.index.get.ShardGetService
-
- get(Engine.GetResult, String, String, String[], FetchSourceContext, boolean) - Method in class org.elasticsearch.index.get.ShardGetService
-
- get(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
- get(QueryParseContext, String) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionParserMapper
-
- get(Engine.Get) - Method in class org.elasticsearch.index.shard.IndexShard
-
- get() - Method in class org.elasticsearch.index.similarity.BM25SimilarityProvider
-
Returns the Similarity
the Provider is for
- get() - Method in class org.elasticsearch.index.similarity.DefaultSimilarityProvider
-
Returns the Similarity
the Provider is for
- get() - Method in class org.elasticsearch.index.similarity.DFISimilarityProvider
-
- get() - Method in class org.elasticsearch.index.similarity.DFRSimilarityProvider
-
Returns the Similarity
the Provider is for
- get() - Method in class org.elasticsearch.index.similarity.IBSimilarityProvider
-
Returns the Similarity
the Provider is for
- get() - Method in class org.elasticsearch.index.similarity.LMDirichletSimilarityProvider
-
Returns the Similarity
the Provider is for
- get() - Method in class org.elasticsearch.index.similarity.LMJelinekMercerSimilarityProvider
-
Returns the Similarity
the Provider is for
- get() - Method in class org.elasticsearch.index.similarity.PreBuiltSimilarityProvider.Factory
-
- get() - Method in class org.elasticsearch.index.similarity.PreBuiltSimilarityProvider
-
Returns the Similarity
the Provider is for
- get() - Method in interface org.elasticsearch.index.similarity.SimilarityProvider
-
Returns the Similarity
the Provider is for
- get(String) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
- get(Version) - Method in interface org.elasticsearch.indices.analysis.PreBuiltCacheFactory.PreBuiltCache
-
- get(String) - Method in interface org.elasticsearch.search.aggregations.Aggregations
-
Returns the aggregation that is associated with the specified name.
- get(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicParserMapper
-
- get(String) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- get(String) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModelParserMapper
-
- get(String) - Method in class org.elasticsearch.search.highlight.Highlighters
-
- get(Object, int) - Method in class org.elasticsearch.search.lookup.IndexField
-
- get(Object) - Method in class org.elasticsearch.search.lookup.IndexField
-
- 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.LeafIndexLookup
-
- get(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- get(String) - Method in class org.elasticsearch.search.suggest.Suggesters
-
- GET - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- getAction() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- GetAction - Class in org.elasticsearch.action.get
-
- getAction() - Method in class org.elasticsearch.tasks.Task
-
Returns task action
- getAction() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
-
- getActions() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
Return the list of action masks for the actions that should be returned
- getActive() - Method in class org.elasticsearch.index.shard.IndexShard
-
- 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
- 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
-
- getAdditionalScriptParameters() - Method in class org.elasticsearch.script.AbstractScriptParser
-
Deprecated.
- 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.DummyTransportAddress
-
- getAddress() - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- getAddress() - Method in class org.elasticsearch.common.transport.LocalTransportAddress
-
- getAddress() - Method in interface org.elasticsearch.common.transport.TransportAddress
-
Returns the address string for this transport address
- 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
-
- getAggregations() - Method in class org.elasticsearch.action.percolate.PercolateResponse
-
- getAggregations() - Method in class org.elasticsearch.action.search.SearchResponse
-
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters.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.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
-
- 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(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.
- getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- GetAliasesAction - Class in org.elasticsearch.action.admin.indices.alias.get
-
- GetAliasesRequest - Class in org.elasticsearch.action.admin.indices.alias.get
-
- GetAliasesRequest(String[]) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
-
- GetAliasesRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
-
- GetAliasesRequest() - 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
-
- getAllEntries() - Method in class org.elasticsearch.common.lucene.all.AllField
-
Returns the
AllEntries
containing the original text fields for the document.
- getAllFieldStats() - Method in class org.elasticsearch.action.fieldstats.FieldStatsResponse
-
- getAllMetaFields() - Static method in class org.elasticsearch.index.mapper.MapperService
-
- getAllNames() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModelParserMapper
-
- getAllNamesIncludedDeprecated() - Method in class org.elasticsearch.common.ParseField
-
- getAllocatedProcessors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
-
- getAllocatedProcessors() - Method in class org.elasticsearch.monitor.os.OsInfo
-
- getAllocation() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
The allocation status of the store.
- 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.
- getAllocationDelayTimeoutSettingNanos(Settings, Settings) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
The allocation delay value in nano seconds associated with the index (defaulting to node settings if not set).
- getAllocationService() - Method in class org.elasticsearch.cluster.routing.RoutingService
-
- getAllStats() - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
-
- 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(MappedFieldType) - Method in class org.elasticsearch.index.search.MatchQuery
-
- getAnalyzer(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
- getAnalyzer() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- 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
-
- getArch() - Method in class org.elasticsearch.monitor.os.OsInfo
-
- getArgs(ShapeBuilder, ShapeRelation) - Static method in class org.elasticsearch.index.query.GeoShapeQueryParser
-
- getAsArray(String) - Method in class org.elasticsearch.common.settings.Settings
-
The values associated with a setting prefix as an array.
- getAsArray(String, String[]) - Method in class org.elasticsearch.common.settings.Settings
-
The values associated with a setting prefix as an array.
- getAsArray(String, String[], Boolean) - Method in class org.elasticsearch.common.settings.Settings
-
The values associated with a setting prefix as an array.
- getAsBoolean(String, Boolean) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as boolean) associated with the setting key.
- getAsBoolean(String[], Boolean) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as boolean) associated with the setting key.
- getAsBytesSize(String, ByteSizeValue) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as size) associated with the setting key.
- 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.
- getAsDouble(String[], Double) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as double) associated with teh first setting key, if none
exists, returns the default value provided.
- getAsFloat(String, Float) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as float) associated with the setting key.
- getAsFloat(String[], Float) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as float) associated with teh first setting key, if none
exists, returns the default value provided.
- getAsInt(String, Integer) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as int) associated with the setting key.
- getAsInt(String[], Integer) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as int) associated with the first setting key.
- getAsLong(String, Long) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as long) associated with the setting key.
- 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.settings.Settings
-
The settings as a flat
Map
.
- getAsMap() - Method in class org.elasticsearch.common.Table
-
- getAsMap() - Method in interface org.elasticsearch.search.aggregations.Aggregations
-
- getAsMap() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- getAsMemory(String, String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as size) associated with the setting key.
- 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(String, String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as a RatioValue) associated with the setting key.
- getAsRatio(String[], String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as a RatioValue) associated with the setting key.
- 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
- getAsSize(String, SizeValue) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as size) associated with the setting key.
- getAsSize(String[], SizeValue) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as size) associated with the setting key.
- getAsStructuredMap() - Method in class org.elasticsearch.common.settings.Settings
-
The settings as a structured
Map
.
- getAsTime(String, TimeValue) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as time) associated with the setting key.
- 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.cluster.stats.ClusterStatsResponse
-
- 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.action.support.nodes.BaseNodesResponse
-
- getAt(int) - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- getAt(int) - Method in interface org.elasticsearch.search.SearchHits
-
Return the hit as the provided position.
- getAtomicFieldData(String) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildAtomicFieldData
-
- getAttributes() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
-
- getAttributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The node attributes.
- getAvailable() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
-
- getAvailableMemory() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
-
- getAvailableProcessors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
-
- getAvailableProcessors() - Method in class org.elasticsearch.monitor.os.OsInfo
-
- getAvg() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- 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 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(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
-
- getBackgroundFrequency(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
-
- getBanCount() - Method in class org.elasticsearch.tasks.TaskManager
-
Returns the number of currently banned tasks.
- getBigArrays() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns a BigArrays instance for this engine
- getBinaryValue(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
- getBinding(Key<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the binding for the given injection key.
- getBinding(Class<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the binding for the given type.
- getBinding(Injector, Key<?>) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns the binding for the given key or null if there is no such binding
- getBinding() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
- getBindingFromNewInjector(Method, Object[]) - Method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider2
-
Creates a child injector that binds the args, and returns the binding for the method's result.
- getBindings() - Method in interface org.elasticsearch.common.inject.Injector
-
Returns all explicit bindings.
- getBindingsOf(Injector, Matcher<Class>) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns a collection of all of the bindings matching the given matcher
- getBindingsOf(Injector, Class<?>) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns a collection of all bindings of the given base type
- 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
-
- getblock(byte[], int, int) - Static method in enum org.elasticsearch.common.hash.MurmurHash3
-
- getblock(byte[], int, int) - Static method in class org.elasticsearch.common.util.BloomFilter
-
- getBlocks() - Method in class org.elasticsearch.cluster.ClusterState
-
- getBlocks() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- getBooleanQuery(List<BooleanClause>, boolean) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- getBoost() - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
-
Deprecated.
- 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
-
- 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.postingshighlight.CustomPostingsHighlighter
-
- getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.filters.Filters
-
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
- 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.terms.InternalTerms
-
- 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.
- getBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
-
- getBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- getBucketOrd(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator.WithHash
-
- getBucketOrd(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
-
- getBucketOrd(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.WithHash
-
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.filters.Filters
-
The buckets created by this aggregation.
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- 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 interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
-
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation
-
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- 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.InternalSignificantTerms
-
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms
-
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms
-
Return the sorted list of the buckets in this terms aggregation.
- getBucketsPaths() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorFactory
-
- getBucketStreamContext(B) - Method in interface org.elasticsearch.search.aggregations.bucket.BucketStreams.Stream
-
- getBufferPools() - Method in class org.elasticsearch.monitor.jvm.JvmStats
-
- getBufferSize() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Retruns the current translog buffer size.
- getBuild() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
The build version of the node.
- getByGcName(String, String) - Static method in class org.elasticsearch.monitor.jvm.GcNames
-
- getByKey(Object) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
- getByMemoryPoolName(String, String) - Static method in class org.elasticsearch.monitor.jvm.GcNames
-
- getByPrefix(String) - Method in class org.elasticsearch.common.settings.Settings
-
A settings that are filtered (and key is removed) with the specified prefix.
- getByteLimit() - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
-
- getBytes() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- getBytesRef() - Method in class org.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttributeImpl
-
- getBytesValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
-
- 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 class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
-
- getCacheCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of DocIdSet
s that have been cached.
- getCachedStream() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
-
- getCacheEvictions() - Method in class org.elasticsearch.script.ScriptStats
-
- getCacheSize() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of DocIdSet
s that are in the cache.
- 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
- getCause() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- 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.search.ShardSearchFailure
-
- getCause() - Method in interface org.elasticsearch.action.ShardOperationFailedException
-
The cause of this failure.
- getCause() - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
-
- 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
-
- getCause() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
- getChannel() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
- getChannel() - Method in class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
-
- getChannel() - Method in class org.elasticsearch.transport.DelegatingTransportChannel
-
- getChannel() - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
-
Returns the underlying netty channel.
- getChannelEvent() - Method in class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
-
- getChannelType() - Method in class org.elasticsearch.transport.DelegatingTransportChannel
-
- getChannelType() - Method in class org.elasticsearch.transport.local.LocalTransportChannel
-
- getChannelType() - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
-
- getChannelType() - Method in interface org.elasticsearch.transport.TransportChannel
-
- getCharFilterFactory(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltCharFilters
-
- 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(String) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
-
- getChild() - Method in class org.elasticsearch.search.internal.InternalSearchHit.InternalNestedIdentity
-
- getChild() - Method in interface org.elasticsearch.search.SearchHit.NestedIdentity
-
Returns the next child nested level if there is any, otherwise null
is returned.
- getChildJoinFieldType() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- getChildResources() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
-
Deprecated.
- 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.GeoPointArrayAtomicFieldData.Single
-
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointArrayLegacyAtomicFieldData.Single
-
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
-
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildAtomicFieldData
-
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.GlobalFieldData
-
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVBytesAtomicFieldData
-
- getChildResources() - Method in class org.elasticsearch.index.translog.Translog.Location
-
- getChildResources() - Method in class org.elasticsearch.indices.cache.request.IndicesRequestCache.Key
-
- getChildResources() - Method in class org.elasticsearch.indices.cache.request.IndicesRequestCache.Value
-
- getChronology() - Method in class org.joda.time.base.BaseDateTime
-
Gets the chronology of the datetime.
- getClasses() - Method in class org.elasticsearch.monitor.jvm.JvmStats
-
- getClassname() - Method in class org.elasticsearch.plugins.PluginInfo
-
- getClassPath() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
- getClient() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
-
- 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
-
- getClusterName() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
- getClusterName() - Method in class org.elasticsearch.cluster.ClusterState
-
- getClusterNameAsString() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
- getCodec() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the Codec
used in the engines IndexWriter
- getCollectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
-
- getCollectionMode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- getCollectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
-
- getCollector() - Method in class org.elasticsearch.search.profile.Profiler
-
Return the current root Collector for this search
- getCollectorResult() - Method in class org.elasticsearch.search.profile.ProfileShardResult
-
- getCollectors() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
-
- getCollectorTree() - Method in class org.elasticsearch.search.profile.InternalProfileCollector
-
- getColumnNumber() - Method in exception org.elasticsearch.index.query.QueryParsingException
-
Column number of the location of the error
- getColumnNumber() - Method in exception org.elasticsearch.search.SearchParseException
-
Column number of the location of the error
- getCommitStats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
-
- getCommitUserData() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
- getComparison() - Method in class org.elasticsearch.action.fieldstats.IndexConstraint
-
- 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
-
- getCompletionField(ContextMapping.Context, String, BytesRef) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- getConcreteAllClosedIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- getConcreteAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- getConcreteAllOpenIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- getConcreteIndexAndAliasMetaDatas() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
-
Returns the unique alias metadata per concrete index.
- getConfig() - Method in class org.elasticsearch.index.translog.Translog
-
- 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 that will be used when generating a document from user provided objects like Maps.
- getContentType() - Method in class org.elasticsearch.script.Template
-
- getContext() - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- getContext() - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- getContext() - Method in interface org.elasticsearch.common.HasContext
-
- getContext() - Method in class org.elasticsearch.percolator.PercolateContext
-
- getContextFactory() - Method in class org.elasticsearch.search.fetch.FetchSubPhaseParseElement
-
Return the ContextFactory for this FetchSubPhase.
- getContextFactory() - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsParseElement
-
- getContextMapping() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
Get the context mapping associated with this completion field
- getContextParser() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggester
-
- getContextParser() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
-
- getContextParser() - Method in class org.elasticsearch.search.suggest.Suggester
-
- getContextParser() - Method in class org.elasticsearch.search.suggest.term.TermSuggester
-
- getContextQueries() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- getCoreCacheKey() - 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(TokenStream, CandidateGenerator, float, int, WordScorer, float, int) - Method in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
-
- getCorrections(Analyzer, BytesRef, CandidateGenerator, float, int, IndexReader, String, WordScorer, float, int) - Method in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
-
- getCorsConfig() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- getCount() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
- getCount() - Method in class org.elasticsearch.action.count.CountResponse
-
Deprecated.
The count of documents matching the query provided.
- getCount() - Method in class org.elasticsearch.action.percolate.PercolateResponse
-
- 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.percolator.stats.PercolateStats
-
- getCount() - Method in class org.elasticsearch.index.shard.DocsStats
-
- getCount() - Method in class org.elasticsearch.index.suggest.stats.SuggestStats
-
- 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 interface org.elasticsearch.search.aggregations.metrics.stats.Stats
-
- getCountAsString() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- getCountAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
-
- getCounts() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
-
- getCpu() - Method in class org.elasticsearch.monitor.process.ProcessStats
-
- getCpuPercent() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
-
Cpu usage in percentages - 100 is 1 core.
- getCpuPercent() - Method in class org.elasticsearch.monitor.os.OsStats
-
- 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.
- getCurrent() - Method in class org.elasticsearch.index.merge.MergeStats
-
The current number of merges executing.
- getCurrent() - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- getCurrent() - Method in class org.elasticsearch.index.suggest.stats.SuggestStats
-
- getCurrent() - Method in class org.elasticsearch.search.profile.Profilers
-
Get the current profiler.
- getCurrentNanoTime() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
returns the nano time captured at the beginning of the allocation.
- getCurrentNumDocs() - Method in class org.elasticsearch.index.merge.MergeStats
-
- 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.ClusterState.Builder
-
- getCustom(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- getCustom(String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- getCustom(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- getCustoms() - Method in class org.elasticsearch.cluster.ClusterState
-
- getCustoms() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- getCustoms() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- getCustoms() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- getCutoffScore() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
-
- getData() - Method in class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
-
- getDataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the discovered data nodes arranged by their ids
- getDataOnly() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
-
- getDataPath() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
-
- 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.
- getDataPath() - Method in class org.elasticsearch.index.shard.ShardPath
-
- getDate() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
-
- getDays() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getDaysFrac() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getDecayFunction() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionParser
-
Override this function if you want to produce your own scorer.
- getDecayFunction() - Method in class org.elasticsearch.index.query.functionscore.exp.ExponentialDecayFunctionParser
-
- getDecayFunction() - Method in class org.elasticsearch.index.query.functionscore.gauss.GaussDecayFunctionParser
-
- getDecayFunction() - Method in class org.elasticsearch.index.query.functionscore.lin.LinearDecayFunctionParser
-
- getDeclaringClass() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper.TypeParser
-
- getDefault(Settings, MappedFieldType, String) - Method in interface org.elasticsearch.index.mapper.MetadataFieldMapper.TypeParser
-
- getDefaultBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParametersParser
-
- getDefaultBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- getDefaultBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsParametersParser
-
- getDefaultFileSystem() - Static method in class org.elasticsearch.common.io.PathUtils
-
Returns the default FileSystem.
- getDefaultIndexOption() - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- getDefaultIndexOption() - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Builder
-
- getDefaultScoreCombiner() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
-
- getDefaultScriptLang() - Method in class org.elasticsearch.script.AbstractScriptParser
-
- getDefaultScriptParameterValue() - Method in class org.elasticsearch.script.ScriptParameterParser
-
- getDefaultValues() - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- getDefaultWrapped() - Method in class org.elasticsearch.index.codec.postingsformat.Elasticsearch090PostingsFormat
-
Deprecated.
- getDeferringCollector() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- 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.
- getDelegate() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsConsumer
-
Deprecated.
- getDelegate() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
-
Deprecated.
- getDelegatedFromInstigator(Instigator) - Method in class org.elasticsearch.action.support.DelegatingActionListener
-
- getDeleteCount() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- getDeleteCurrent() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- getDeleted() - Method in class org.elasticsearch.index.shard.DocsStats
-
- getDeletedDocs() - Method in class org.elasticsearch.index.engine.Segment
-
- getDeleteTime() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- getDeleteTimeInMillis() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- getDeletionPolicy() - Method in class org.elasticsearch.index.engine.EngineConfig
-
- getDensity() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- 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
-
- getDeprecationLogger(String) - Static method in class org.elasticsearch.common.logging.ESLoggerFactory
-
- getDeprecationLogger(String, String) - Static method in class org.elasticsearch.common.logging.ESLoggerFactory
-
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- getDescription() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
- getDescription() - Method in class org.elasticsearch.plugins.PluginInfo
-
- getDescription() - Method in class org.elasticsearch.tasks.Task
-
Generates task description
- getDescription() - Method in class org.elasticsearch.transport.TransportRequest
-
Returns optional description of the request to be displayed by the task manager
- 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.
- getDfs() - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyResponse
-
- getDictionary(String) - Method in class org.elasticsearch.indices.analysis.HunspellService
-
Returns the hunspell dictionary for the given locale.
- getDirectMemoryMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
-
- getDirectory() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
-
- getDirectoryReader() - Method in class org.elasticsearch.index.engine.Engine.Searcher
-
- getDirectoryReader() - Method in class org.elasticsearch.indices.IndicesWarmer.WarmerContext
-
- getDirectoryReader() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
- getDirectSpellChecker(DirectSpellcheckerSettings) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- getDiscoveryNode() - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
-
- 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.DecayFunctionParser.AbstractDistanceScoreFunction
-
- getDocCount() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- getDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.BestDocsDeferringCollector
-
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters.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.range.InternalRange.Bucket
-
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
- getDocCount() - Method in interface org.elasticsearch.search.aggregations.bucket.SingleBucketAggregation
-
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
-
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
-
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- getDocCountError() - Method in class 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.
- getDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
- getDocId() - Method in class org.elasticsearch.search.lookup.LeafIndexLookup
-
- 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
-
- getDocumentMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapperForType
-
- 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.
- getDurabilty() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the current durability mode of this translog.
- 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
- getElasticsearchDirectoryReader(DirectoryReader) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
- getElasticsearchLeafReader(LeafReader) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
-
- getElements() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
-
- getElements(Module...) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Records the elements executed by modules
.
- getElements(Stage, Module...) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Records the elements executed by modules
.
- getElements(Iterable<? extends 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
.
- getElements() - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns the configuration information in this private environment.
- getElementsMutable() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
-
- getEmptyHighlight(String, BreakIterator, int) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
-
- getEndOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
-
- getEntries() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
- getError() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
-
- getErrorMessage() - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse.Item
-
- 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
-
- 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
-
- 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
.
- getExecutionHint() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- getExecutor() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
-
- 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
-
- 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.decider.Decision.Single
-
Returns the explanation string, fully formatted.
- getExplanation() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getExplanation() - Method in interface org.elasticsearch.search.SearchHit
-
If enabled, the explanation of the search hit.
- getExplanations() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
-
- getExponent(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- getExponent(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- 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.
- getExtension(String) - Method in class org.elasticsearch.common.util.ExtensionPoint.ClassMap
-
Returns the extension for the given key or null
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Bucket
-
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange
-
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
-
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Bucket
-
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
-
- getFailed() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- getFailedEngineListener() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a listener that should be called on engine failure
- 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.percolate.MultiPercolateResponse.Item
-
- 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.routing.UnassignedInfo
-
Returns additional failure exception details if exists.
- 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.ActionWriteResponse.ShardInfo
-
- getFailures() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
-
- getFetchCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
-
- getFetchCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
-
- getFetchSubPhaseContext(FetchSubPhase.ContextFactory<SubPhaseContext>) - Method in class org.elasticsearch.percolator.PercolateContext
-
- getFetchSubPhaseContext(FetchSubPhase.ContextFactory<SubPhaseContext>) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- getFetchSubPhaseContext(FetchSubPhase.ContextFactory<SubPhaseContext>) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- getFetchSubPhaseContext(FetchSubPhase.ContextFactory<SubPhaseContext>) - Method in class org.elasticsearch.search.internal.SearchContext
-
- 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.elasticsearch.action.fieldstats.IndexConstraint
-
- getField(String) - Method in class org.elasticsearch.action.get.GetResponse
-
- getField() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
- GetField - Class in org.elasticsearch.index.get
-
- GetField(String, List<Object>) - Constructor for class org.elasticsearch.index.get.GetField
-
- getField(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
- getField() - Method in class org.elasticsearch.search.internal.InternalSearchHit.InternalNestedIdentity
-
- getField() - Method in interface org.elasticsearch.search.SearchHit.NestedIdentity
-
Returns the nested field in the source this hit originates from
- getField() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
-
- getField() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- 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
-
- getFieldDataType() - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
The field data type.
- getFieldDataType() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
-
- getFieldDataType() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
-
- getFieldDataType() - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
-
- getFieldDataType() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.GlobalFieldData
-
- getFieldMappings(GetFieldMappingsRequest, ActionListener<GetFieldMappingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the mappings of specific fields
- getFieldMappings(GetFieldMappingsRequest) - 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
- GetFieldMappingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
- GetFieldMappingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.get
-
- 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
-
- GetFieldMappingsResponse.FieldMappingMetaData - Class in org.elasticsearch.action.admin.indices.mapping.get
-
- getFieldName() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionParser.AbstractDistanceScoreFunction
-
- getFieldName() - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- 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 interface org.elasticsearch.index.fielddata.IndexFieldData
-
The field name.
- getFieldNames() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
-
- getFieldNames() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
-
- getFieldNames() - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
-
- getFieldNames() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.GlobalFieldData
-
- getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- getFields() - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequest
-
- getFields() - Method in class org.elasticsearch.action.fieldstats.FieldStatsShardRequest
-
- 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(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
- getFields(IndexReader, int, String) - Method in class org.elasticsearch.search.highlight.vectorhighlight.SourceScoreOrderFragmentsBuilder
-
- getFields(IndexReader, int, String) - Method in class org.elasticsearch.search.highlight.vectorhighlight.SourceSimpleFragmentsBuilder
-
- getFields() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getFields() - Method in interface 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
-
- getFieldsFor(MultiTermVectorsResponse) - Static method in class org.elasticsearch.index.search.morelikethis.MoreLikeThisFetchService
-
- getFieldStats() - Method in class org.elasticsearch.action.fieldstats.FieldStatsShardResponse
-
- getFieldType(Field) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic type of field
.
- getFilename(long) - Static method in class org.elasticsearch.index.translog.Translog
-
package private for testing
- getFileNames() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
-
- getFilePointer() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
-
Deprecated.
- getFilePointer() - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
-
- getFilePointer() - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
-
- getFiles() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommit
-
- getFileStore(Path) - Static method in class org.elasticsearch.env.Environment
-
Looks up the filestore associated with a Path.
- getFilter() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- getFilter() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredTerms
-
Deprecated.
- getFilter() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParametersParser
-
- getFilterFunctions() - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
-
- getFinalizingShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with the snapshot in the finalizing stage
- getFirstAliasMetaData() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
-
- getFirstErrorFailure(CreationException) - Static method in class org.elasticsearch.common.inject.Injectors
-
- getFirstOperationOffset() - Method in class org.elasticsearch.index.translog.TranslogReader
-
- 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.
- getFlag(int, Settings, String, boolean) - Method in class org.elasticsearch.index.analysis.WordDelimiterTokenFilterFactory
-
- getFlags() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- getFlags() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- getFlush() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- getFlush() - Method in class org.elasticsearch.indices.NodeIndicesStats
-
- getFollow() - Method in class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
Gets whether the appender honors reassignments of System.out
or System.err made after configuration.
- getForField(MappedFieldType) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
-
- getForField(MappedFieldType) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- getFormat(Settings) - Method in class org.elasticsearch.index.fielddata.FieldDataType
-
- getFormatter(String) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
-
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- getFragments() - Method in class org.elasticsearch.search.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
-
- getFreeBytesThresholdHigh() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- getFreeBytesThresholdLow() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- getFreeDiskAsPercentage() - Method in class org.elasticsearch.cluster.DiskUsage
-
- getFreeDiskThresholdHigh() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- getFreeDiskThresholdLow() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- 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.search.suggest.term.TermSuggestion.Entry.Option
-
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Bucket
-
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- getFrom() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
-
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Bucket
-
- getFromAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
-
- getFromContext(Object) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- getFromContext(Object, V) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- getFromContext(Object) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- getFromContext(Object, V) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- getFromContext(Object) - Method in interface org.elasticsearch.common.HasContext
-
- getFromContext(Object, V) - Method in interface org.elasticsearch.common.HasContext
-
- getFromContext(Object) - Method in class org.elasticsearch.percolator.PercolateContext
-
- getFromContext(Object, V) - Method in class org.elasticsearch.percolator.PercolateContext
-
- getFromSearcher(Engine.Get) - 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
-
- getFunction() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- getFuture() - Method in class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
-
- getFuzziness() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- getFuzziness() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
- getFuzzyEditDistance() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- getFuzzyMinLength() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- getFuzzyMinLength() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
- getFuzzyPrefixLength() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- getFuzzyPrefixLength() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
- getFuzzyQuery(String, String, String) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- 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
-
- getGcDeletesInMillis() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the GC deletes cycle in milliseconds.
- getGeneration() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
-
- 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.Translog
-
Returns the current generation of this translog.
- getGeneration() - Method in class org.elasticsearch.index.translog.TranslogReader
-
- 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
.
- getGeohash() - Method in class org.elasticsearch.common.geo.GeoPoint
-
- getGeoPointValues() - Method in interface org.elasticsearch.index.fielddata.AtomicGeoPointFieldData
-
Return geo-point values.
- getGeoPointValues() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointArrayAtomicFieldData.Single
-
- getGeoPointValues() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointArrayLegacyAtomicFieldData.Single
-
- 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
-
- getGlobalOrd(long) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalMapping
-
- getGlobalSettings() - Static method in class org.elasticsearch.node.settings.NodeSettingsService
-
Returns the global (static) settings last updated by a node.
- 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
-
- getHeader(String) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- getHeader(String) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- getHeader(String) - Method in interface org.elasticsearch.common.HasHeaders
-
- getHeader(String) - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the list of header values for the given key or null
if not header for the
given key exists.
- getHeader(String) - Method in class org.elasticsearch.percolator.PercolateContext
-
- 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.ContextAndHeaderHolder
-
- getHeaders() - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- getHeaders() - Method in interface org.elasticsearch.common.HasHeaders
-
- getHeaders() - Method in class org.elasticsearch.common.Table
-
- getHeaders() - Method in class org.elasticsearch.percolator.PercolateContext
-
- getHeaders() - Method in class org.elasticsearch.rest.RestResponse
-
Returns custom headers that have been added, or null if none have been set.
- 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
-
- getHighlighted() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
-
- getHighlightFields() - Method in class org.elasticsearch.action.percolate.PercolateResponse.Match
-
- getHighlightFields() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getHighlightFields() - Method in interface org.elasticsearch.search.SearchHit
-
A map of highlighted fields.
- 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.search.aggregations.metrics.tophits.InternalTopHits
-
- getHits() - Method in interface org.elasticsearch.search.aggregations.metrics.tophits.TopHits
-
- getHits() - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- getHits() - Method in interface 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.common.transport.DummyTransportAddress
-
- getHost() - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- getHost() - Method in class org.elasticsearch.common.transport.LocalTransportAddress
-
- getHost() - Method in interface org.elasticsearch.common.transport.TransportAddress
-
Returns the host string for this transport address
- 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
-
- getHours() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getHoursFrac() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getHttp() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
- getHttp() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
- getId() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- 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 class org.elasticsearch.action.delete.DeleteResponse
-
The id of the document deleted.
- getId() - Method in class org.elasticsearch.action.explain.ExplainResponse
-
- getId() - Method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Comparison
-
- getId() - Method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Property
-
- 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.index.IndexResponse
-
The id of the document indexed.
- getId() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
-
The id of the document deleted.
- getId() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptResponse
-
The id of the document.
- getId() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
-
The id of the document indexed.
- getId() - Method in class org.elasticsearch.action.percolate.PercolateResponse.Match
-
- 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.action.update.UpdateResponse
-
The id of the document indexed.
- getId() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
-
- 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(Class<? extends ElasticsearchException>) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns the serialization id the given exception.
- 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.shard.ShardId
-
- getId() - Method in class org.elasticsearch.indices.cache.query.terms.TermsLookup
-
- getId() - Method in class org.elasticsearch.monitor.process.ProcessInfo
-
The process id.
- getId() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getId() - Method in interface org.elasticsearch.search.SearchHit
-
The id of the document.
- getId() - Method in class org.elasticsearch.tasks.Task
-
Returns task id
- getId() - Method in class org.elasticsearch.tasks.TaskId
-
- getIgnoreAbove() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- getIgnoreNodes(ShardId) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
- getIncludeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- getIndex() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
-
- 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(String) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
-
- 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.delete.DeleteResponse
-
The index the document was deleted from.
- 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.index.IndexResponse
-
The index the document was indexed into.
- getIndex() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
-
The index the document was deleted from.
- getIndex() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
-
The index the document was indexed into.
- getIndex() - Method in class org.elasticsearch.action.percolate.PercolateResponse.Match
-
- 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.action.update.UpdateResponse
-
The index the document was indexed into.
- 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.
- getIndex() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
-
- getIndex() - Method in class org.elasticsearch.cluster.metadata.AliasOrIndex.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 class org.elasticsearch.cluster.routing.ShardRouting
-
The index name.
- 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.shard.ShardId
-
- getIndex() - Method in class org.elasticsearch.indices.cache.query.terms.TermsLookup
-
- getIndex() - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
- getIndex() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getIndex() - Method in interface org.elasticsearch.search.SearchHit
-
The index of the hit.
- getIndex() - Method in class org.elasticsearch.search.SearchShardTarget
-
- getIndex() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- GetIndexAction - Class in org.elasticsearch.action.admin.indices.get
-
- getIndexAnalyzer(String) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
-
- getIndexBalance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
Returns the index related weight factor.
- getIndexConstraints() - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequest
-
- getIndexCount() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
-
- getIndexCount() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- getIndexCreatedVersion() - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- getIndexCurrent() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- getIndexedScript(GetIndexedScriptRequest, ActionListener<GetIndexedScriptResponse>) - Method in interface org.elasticsearch.client.Client
-
Get an indexed script
- getIndexedScript(GetIndexedScriptRequest) - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type and id.
- getIndexedScript(GetIndexedScriptRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
- getIndexedScript(GetIndexedScriptRequest, ActionListener<GetIndexedScriptResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
- GetIndexedScriptAction - Class in org.elasticsearch.action.indexedscripts.get
-
- GetIndexedScriptRequest - Class in org.elasticsearch.action.indexedscripts.get
-
A request to get an indexed script (its source) based on its language (optional) and id.
- GetIndexedScriptRequest() - Constructor for class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
Constructs a new get request against the script index.
- GetIndexedScriptRequest(String, String) - Constructor for class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
Constructs a new get request against the script index with the type and id.
- GetIndexedScriptRequestBuilder - Class in org.elasticsearch.action.indexedscripts.get
-
A get document action request builder.
- GetIndexedScriptRequestBuilder(ElasticsearchClient, GetIndexedScriptAction) - Constructor for class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequestBuilder
-
- GetIndexedScriptResponse - Class in org.elasticsearch.action.indexedscripts.get
-
The response of a get script action.
- getIndexFailedCount() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- 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.
- getIndexingBufferSize() - Method in class org.elasticsearch.index.shard.IndexShard
-
- getIndexingService() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a
ShardIndexingService
used inside the engine to inform about
pre and post index and create operations.
- GetIndexRequest - Class in org.elasticsearch.action.admin.indices.get
-
A request to delete 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 delete index action.
- getIndexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- getIndexSearcher() - Method in class org.elasticsearch.search.lookup.LeafIndexLookup
-
- getIndexSettings(String) - Method in class org.elasticsearch.gateway.PriorityComparator
-
- getIndexSettings() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the latest index settings directly from the index settings service.
- getIndexSettings() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the current index settings
- getIndexShardOperationsCounter(ShardId) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- getIndexShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
-
- 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
-
- getIndexTime() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- getIndexTimeInMillis() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- getIndexToSettings() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
- getIndexUUID() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- getIndexUUID() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
-
- getIndexUUID() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
-
- getIndexUUID() - Method in class org.elasticsearch.index.shard.ShardPath
-
- getIndexWriterMaxMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- getIndexWriterMaxMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Maximum memory index writer may use before it must write buffered documents to a new segment.
- 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
-
- getIndicesMergedFieldStats() - Method in class org.elasticsearch.action.fieldstats.FieldStatsResponse
-
- getIndicesRouting() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- 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.
- getInfo() - Method in class org.elasticsearch.index.translog.ImmutableTranslogReader
-
- 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
-
- 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.
- getInnerFactory() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
-
- getInnerFilter() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- getInnerHits() - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext
-
- getInnerHits() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getInnerHits() - Method in interface org.elasticsearch.search.SearchHit
-
- getInnerQuery() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- getInputArguments() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
- getInsertOrder() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
-
- 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()
.
- 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(Injector, Class<T>, String) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns an instance of the given type with the
Named
annotation value.
- 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
-
- getInstancesOf(Injector, Class<T>) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns a collection of all instances of the given base type
- getInstancesOf(Injector, Matcher<Class>) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns a collection of all instances matching the given matcher
- getInternalFactory() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
-
- getInternalValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
-
- getInternalValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
-
- getInternalValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
-
- 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
-
- getItems() - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse
-
- 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 interface org.elasticsearch.common.inject.Binding
-
Returns the key for this binding.
- 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() - 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 interface org.elasticsearch.script.ScriptContext
-
- getKey() - Method in class org.elasticsearch.script.ScriptContext.Plugin
-
- getKey() - Method in enum org.elasticsearch.script.ScriptContext.Standard
-
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters.Bucket
-
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
- getKey() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
-
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
-
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
-
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
-
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
-
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.Terms.Bucket
-
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters.Bucket
-
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
- getKeyAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
-
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
-
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.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
-
- getKeyType(Key<?>) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns the key type of the given key
- 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
-
Method for getting language.
- getLargest() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
- 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.ShadowEngine
-
- getLastComputedLeftDelayNanos() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
The delay in nanoseconds until this unassigned shard can be reassigned.
- getLastEmittedDocPerShard(SearchRequest, ScoreDoc[], int) - Method in class org.elasticsearch.search.controller.SearchPhaseController
-
- getLastEmittedDocPerShard(ScoreDoc[], int) - Method in class org.elasticsearch.search.controller.SearchPhaseController
-
- 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
-
- getLeaf(Directory, Class<T>) - Static method in class org.elasticsearch.index.store.DirectoryUtils
-
Tries to extract the leaf of the Directory
if the directory is a FilterDirectory
and cast
it to the given target class or returns null
if the leaf is not assignable to the target class.
- getLeaf(Directory, Class<T>, T) - Static method in class org.elasticsearch.index.store.DirectoryUtils
-
Tries to extract the leaf of the Directory
if the directory is a FilterDirectory
and cast
it to the given target class or returns the given default value, if the leaf is not assignable to the target class.
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
-
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.BestDocsDeferringCollector
-
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator
-
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
-
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
-
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.filters.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.histogram.HistogramAggregator
-
- 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.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.GlobalOrdinalsSignificantTermsAggregator.WithHash
-
- 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.terms.GlobalOrdinalsStringTermsAggregator
-
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.LowCardinality
-
- 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) - Method in class org.elasticsearch.search.aggregations.BucketCollector
-
- 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.geocentroid.GeoCentroidAggregator
-
- 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.NonCollectingAggregator
-
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.profile.InternalProfileCollector
-
- getLeafDocLookup(LeafReaderContext) - Method in class org.elasticsearch.search.lookup.DocLookup
-
- getLeafFieldsLookup(LeafReaderContext) - Method in class org.elasticsearch.search.lookup.FieldsLookup
-
- getLeafIndexLookup(LeafReaderContext) - Method in class org.elasticsearch.search.lookup.IndexLookup
-
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
-
Deprecated.
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
-
- 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.DecayFunctionParser.AbstractDistanceScoreFunction
-
- getLeafSearchLookup(LeafReaderContext) - Method in class org.elasticsearch.search.lookup.SearchLookup
-
- getLeafSearchScript(LeafReaderContext) - Method in interface org.elasticsearch.script.SearchScript
-
- getLength() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
-
- getLevel() - Method in interface org.elasticsearch.common.logging.ESLogger
-
Returns the current logger level
If the level is null, it means that the logger inherits its level
from its nearest ancestor with a specific (non-null) level value.
- getLevel() - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- getLevel() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- getLevel() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- 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.MemoryCircuitBreaker
-
- 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
-
- getLineNumber() - Method in exception org.elasticsearch.index.query.QueryParsingException
-
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.
- getListInstalledPlugins() - Method in class org.elasticsearch.plugins.PluginManager
-
- getLoadAndScaleToPercent(Method, OperatingSystemMXBean) - Static method in class org.elasticsearch.monitor.Probes
-
- getLoadAverage() - Method in class org.elasticsearch.monitor.os.OsStats
-
- getLoadedClassCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
-
- getLoading() - Method in class org.elasticsearch.index.fielddata.FieldDataType
-
- getLocalAddress() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
Returns the local address where this request channel is bound to.
- getLocalAddress() - Method in class org.elasticsearch.rest.RestRequest
-
- getLocalAddresses() - Method in class org.elasticsearch.transport.local.LocalTransport
-
- getLocalAddresses() - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- getLocalAddresses() - Method in interface org.elasticsearch.transport.Transport
-
- getLocalAddresses() - Method in class org.elasticsearch.transport.TransportService
-
- getLocalNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the local node
- getLocalNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the id of the local node
- getLogger(String, String) - Static method in class org.elasticsearch.common.logging.ESLoggerFactory
-
- getLogger(String) - Static method in class org.elasticsearch.common.logging.ESLoggerFactory
-
- getLogger(Class, Settings, ShardId, String...) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(String, Settings, ShardId, String...) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(Class, Settings, Index, String...) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(Class, Settings, String...) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(String, Settings, String...) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(ESLogger, String) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(String) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(Class) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(Class, String...) - Static method in class org.elasticsearch.common.logging.Loggers
-
- getLogger(String, 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
-
- getLookup(CompletionFieldMapper.CompletionFieldType, CompletionSuggestionContext) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionTerms
-
- getLookup(CompletionFieldMapper.CompletionFieldType, CompletionSuggestionContext) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.LookupFactory
-
- getLowerBounds() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
-
- getLowFreqMinimumNumberShouldMatchSpec() - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
- getMapper(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
-
Returns the mapper for the given field
- getMapper(String) - Method in class org.elasticsearch.index.mapper.object.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
-
- 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(GetMappingsRequest, ActionListener<GetMappingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- getMappings(GetMappingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- 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
-
- getMasterData() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
-
- 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
- getMasterOnly() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
-
- getMatchedQueries() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getMatchedQueries() - Method in interface org.elasticsearch.search.SearchHit
-
The set of query and filter names the query matched with.
- getMatches() - Method in class org.elasticsearch.action.percolate.PercolateResponse
-
- getMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
-
- getMax() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- getMax() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.Stats
-
- getMax() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
-
- 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 interface org.elasticsearch.search.aggregations.metrics.stats.Stats
-
- getMaxBoost() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- getMaxContentLength() - Method in class org.elasticsearch.http.HttpInfo
-
- getMaxDoc() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- 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.
- getMaxEventsHeld() - Method in class org.elasticsearch.http.netty.pipelining.HttpPipeliningHandler
-
- 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
-
- 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
- getMaxMergeCount() - Method in class org.elasticsearch.index.shard.MergeSchedulerConfig
-
Returns maxMergeCount
.
- 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.
- getMaxScore() - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- getMaxScore() - Method in interface org.elasticsearch.search.SearchHits
-
The maximum score of this query.
- getMaxShingleSize() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
-
- getMaxTaskWaitTime() - Method in interface org.elasticsearch.cluster.ClusterService
-
Returns the maximum wait time for tasks in the queue
- getMaxTaskWaitTime() - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- 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
-
- getMaxThreadCount() - Method in class org.elasticsearch.index.shard.MergeSchedulerConfig
-
Returns maxThreadCount
.
- getMaxUpTime() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
The maximum uptime of a node in the cluster
- getMaxValue() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- getMaxValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Date
-
- getMaxValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Double
-
- getMaxValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Float
-
- getMaxValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- getMaxValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Long
-
- getMaxValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Text
-
- 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
-
- getMega() - Method in class org.elasticsearch.common.unit.SizeValue
-
- getMegaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
-
- 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(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
-
- 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(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(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(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(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
-
- getMembersInjector() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
-
Returns the looked up members injector.
- 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
.
- 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
.
- getMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
- 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.
- 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
-
- getMemorySize() - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- 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
-
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- getMemoryStorageHint(FieldDataType) - Static method in class org.elasticsearch.index.fielddata.IndexFieldData.CommonSettings
-
Gets a memory storage hint that should be honored if possible but is not mandatory
- 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.
- getMergeInstance() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
-
Deprecated.
- getMergePolicy() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the MergePolicy
for the engines IndexWriter
- getMergePolicy() - Method in class org.elasticsearch.index.shard.MergePolicyConfig
-
- getMergeSchedulerConfig() - Method in class org.elasticsearch.index.engine.EngineConfig
-
- 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.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
-
- 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 class org.elasticsearch.cluster.ClusterState
-
- getMetaData() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- getMetadata() - Method in class org.elasticsearch.index.store.Store
-
Returns a new MetadataSnapshot for the latest commit in this store.
- getMetadata(IndexCommit) - Method in class org.elasticsearch.index.store.Store
-
Returns a new MetadataSnapshot for the given commit.
- 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.InternalAggregation
-
- getMetadataMapperParsers() - Method in class org.elasticsearch.indices.mapper.MapperRegistry
-
Return a map of the meta mappers that have been registered.
- getMetadataOrEmpty() - Method in class org.elasticsearch.index.store.Store
-
Returns a new MetadataSnapshot for the latest commit in this store or
an empty snapshot if no index exists or can not be opened.
- getMethod() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
-
- getMicros() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getMicrosFrac() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getMillis() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getMillis() - Method in class org.joda.time.base.BaseDateTime
-
Gets the milliseconds of the datetime instant from the Java epoch
of 1970-01-01T00:00:00Z.
- getMillisFrac() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getMin() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- 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 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.
- getMinimumCompatibleVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Return the Version
of the oldest lucene segment in the index
- 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.
- 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
- getMinOpenFileDescriptors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
-
- 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
-
- getMinutes() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getMinutesFrac() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getMinValue() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- getMinValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Date
-
- getMinValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Double
-
- getMinValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Float
-
- getMinValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- getMinValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Long
-
- getMinValueAsString() - Method in class org.elasticsearch.action.fieldstats.FieldStats.Text
-
- 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
-
- 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
- getMoreLikeFields() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- getMount() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
-
- 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.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.MemoryCircuitBreaker
-
- getName() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
-
- getName() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
-
- getName() - Method in interface org.elasticsearch.common.logging.ESLogger
-
- getName() - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- getName() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- getName() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- getName() - Method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
-
- getName() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
-
gets the name of this instance
- getName() - Method in class org.elasticsearch.index.engine.Segment
-
- getName() - Method in class org.elasticsearch.index.get.GetField
-
- getName() - Method in class org.elasticsearch.index.Index
-
- getName() - Method in class org.elasticsearch.index.query.functionscore.exp.ExponentialDecayFunctionBuilder
-
- getName() - Method in class org.elasticsearch.index.query.functionscore.factor.FactorBuilder
-
Deprecated.
- getName() - Method in class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionBuilder
-
- getName() - Method in class org.elasticsearch.index.query.functionscore.gauss.GaussDecayFunctionBuilder
-
- getName() - Method in class org.elasticsearch.index.query.functionscore.lin.LinearDecayFunctionBuilder
-
- getName() - Method in class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionBuilder
-
- getName() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
- getName() - Method in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionBuilder
-
- getName() - Method in class org.elasticsearch.index.query.functionscore.weight.WeightBuilder
-
- getName() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
-
- getName() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
-
- 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
-
- getName() - Method in class org.elasticsearch.repositories.RepositoryName
-
- getName() - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Return the name of the aggregation that is being built.
- getName() - Method in interface org.elasticsearch.search.aggregations.Aggregation
-
- getName() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicStreams.Stream
-
- getName() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
- getName() - Method in enum org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
-
- getName() - Method in enum org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Return the english-formatted name of the GapPolicy
- getName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel.SingleExpModelParser
-
- getName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel.DoubleExpModelParser
-
- getName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelParser
-
- 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.pipeline.movavg.models.LinearModel.LinearModelParser
-
- getName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel.AbstractModelParser
-
Returns the name of the model
- getName() - Method in interface org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModelStreams.Stream
-
- getName() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel.SimpleModelParser
-
- getName() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorFactory
-
- getName() - Method in interface org.elasticsearch.search.fetch.FetchSubPhase.ContextFactory
-
The name of the context.
- getName() - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsSubSearchContext
-
- getName() - Method in class org.elasticsearch.search.highlight.HighlightField
-
The name of the field highlighted.
- getName() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- getName() - Method in class org.elasticsearch.search.profile.CollectorResult
-
- getName() - Method in class org.elasticsearch.search.profile.InternalProfileCollector
-
- getName() - Method in interface org.elasticsearch.search.SearchHitField
-
The name of the field.
- getName() - Method in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- getName() - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionLookupProvider
-
- getName() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
- getName() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
-
- getName() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
- getNames() - Method in class org.elasticsearch.index.query.functionscore.exp.ExponentialDecayFunctionParser
-
- getNames() - Method in class org.elasticsearch.index.query.functionscore.factor.FactorParser
-
Deprecated.
- getNames() - Method in class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionParser
-
- getNames() - Method in class org.elasticsearch.index.query.functionscore.gauss.GaussDecayFunctionParser
-
- getNames() - Method in class org.elasticsearch.index.query.functionscore.lin.LinearDecayFunctionParser
-
- getNames() - Method in class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionParser
-
- getNames() - Method in interface org.elasticsearch.index.query.functionscore.ScoreFunctionParser
-
Returns the name of the function, for example "linear", "gauss" etc.
- getNames() - Method in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionParser
-
- getNames() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare.ChiSquareParser
-
- getNames() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDParser
-
- getNames() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore.JLHScoreParser
-
- getNames() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation.MutualInformationParser
-
- getNames() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore.PercentageScoreParser
-
- getNames() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicParser
-
- getNames() - Method in interface org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicParser
-
- getNanos() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getNestedIdentity() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getNestedIdentity() - Method in interface org.elasticsearch.search.SearchHit
-
If this is a nested hit then nested reference information is returned otherwise null
is returned.
- getNestedObjectMapper() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- getNewMetaData() - Method in class org.elasticsearch.gateway.GatewayMetaState.IndexMetaWriteInfo
-
- getNode() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- 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.
- 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.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.search.SearchShardTarget
-
- getNodeId() - Method in class org.elasticsearch.tasks.TaskId
-
- 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.
- 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.cluster.DiskUsage
-
- 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.admin.cluster.stats.ClusterStatsResponse
-
- getNodes() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
- 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
- getNodesIds() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
- getNodesMap() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
-
- getNodesMap() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
- getNodesStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
-
- getNoMasterBlock() - Method in class org.elasticsearch.discovery.DiscoveryService
-
- getNoMasterBlock() - Method in class org.elasticsearch.discovery.DiscoverySettings
-
- 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
-
- getNoopUpdateCount() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- 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.
- getNumberOfFiles() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns number of files in the snapshot
- 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
-
- getNumberOfSearch() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
-
- getNumberOfShards() - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
-
- 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
-
- getNumDocs() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
-
- getNumDocs(SegmentInfos) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns the number of documents in the index referenced by this SegmentInfos
- 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
- getNumDocsWithValue() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number distinct of document IDs with one or more values.
- getNumericType() - Method in interface org.elasticsearch.index.fielddata.IndexNumericFieldData
-
- getNumericType() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVNumericIndexFieldData
-
- getNumericType() - Method in class org.elasticsearch.index.fielddata.plain.DoubleArrayIndexFieldData
-
- getNumericType() - Method in class org.elasticsearch.index.fielddata.plain.FloatArrayIndexFieldData
-
- getNumericType() - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData
-
- getNumericType() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
-
- getNumFreed() - Method in class org.elasticsearch.action.search.ClearScrollResponse
-
- getNumHashFunctions() - Method in class org.elasticsearch.common.util.BloomFilter
-
- 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.
- getNumPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns the number of non-ignored unassigned primaries
- getNumQueries() - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- getNumSingleValuedDocs() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number distinct of document IDs associated with exactly one value.
- getObjectMapper(String, String[]) - Method in class org.elasticsearch.index.mapper.MapperService
-
- getObjectMapper(String) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- getObjectMapper() - Method in class org.elasticsearch.index.query.support.NestedScope
-
- getObjectMapper(String) - Method in class org.elasticsearch.percolator.PercolateContext
-
- getObjectMapper(String) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- 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.internal.InternalSearchHit.InternalNestedIdentity
-
- getOffset() - Method in interface 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
-
- 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
.
- 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.RecoveryStatus
-
- getOperation() - Method in class org.elasticsearch.script.ScriptContext.Plugin
-
- getOperationsCount() - Method in class org.elasticsearch.index.shard.IndexShard
-
- getOptionalFormat() - Method in class org.elasticsearch.action.fieldstats.IndexConstraint
-
- 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").
- getOrDefault(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- getOrDefault(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- getOrDefault(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
- 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(String, PreBuiltCharFilters) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltCharFilters
-
Get a pre built CharFilter by its name or fallback to the default one
- getOrDefault(String, PreBuiltTokenFilters) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltTokenFilters
-
Get a pre built TokenFilter by its name or fallback to the default one
- getOrDefault(String, PreBuiltTokenizers) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
-
Get a pre built Tokenizer by its name or fallback to the default one
- getOrder() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- getOrderedUpstreamMessageEvent() - Method in class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
-
- getOrderElements() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsParametersParser
-
- getOrdinalMap(IndexParentChildFieldData, String) - Static method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
-
Returns the global ordinal map for the specified type
- getOrdinalsValues() - Method in interface org.elasticsearch.index.fielddata.AtomicOrdinalsFieldData
-
Return the ordinals values for the current atomic reader.
- getOrdinalsValues(String) - Method in interface org.elasticsearch.index.fielddata.AtomicParentChildFieldData
-
Return the mapping for the given type.
- getOrdinalsValues() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
-
- getOrdinalsValues(String) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildAtomicFieldData
-
- getOrdinalsValues() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVBytesAtomicFieldData
-
- getOriginNanoTime() - Method in class org.elasticsearch.percolator.PercolateContext
-
- getOriginNanoTime() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- 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
-
- 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.MemoryCircuitBreaker
-
- 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.script.Script
-
Method for getting the parameters.
- getParent() - Method in interface org.elasticsearch.common.inject.Injector
-
Returns this injector's parent, or null
if this is a top-level injector.
- getParent() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
Return the parent document, or null if this is the root document.
- getParentJoinFieldType() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- getParentObjectMapper() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- getParentReader() - Method in class org.elasticsearch.search.lookup.LeafIndexLookup
-
- getParentTaskId() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
Returns the parent task id
- 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
- getParentTypes() - Method in class org.elasticsearch.index.mapper.MapperService
-
- getParseContext() - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- getParseField() - Method in enum org.elasticsearch.script.ScriptService.ScriptType
-
- getPartialValue() - Method in exception org.elasticsearch.common.inject.ConfigurationException
-
Returns a value that was only partially computed due to this exception.
- 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.query.support.NestedInnerQueryParseSupport
-
- getPath() - Method in class org.elasticsearch.indices.cache.query.terms.TermsLookup
-
- getPath() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
-
- getPathElements() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
- getPathElementsAsStringList() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
- getPattern() - Method in class org.elasticsearch.index.analysis.PatternReplaceCharFilterFactory
-
- getPatterns() - Method in class org.elasticsearch.common.settings.SettingsFilter
-
- getPayload() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
-
- getPayloadAsDouble() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
-
- getPayloadAsLong() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
-
- getPayloadAsMap() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
-
- getPayloadAsString() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
-
- 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
-
- getPendingTasks() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
-
The pending cluster tasks
- 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.InternalPercentile
-
- getPercent() - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.Percentile
-
- getPercolate() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
-
- getPercolate() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- getPercolate() - Method in class org.elasticsearch.indices.NodeIndicesStats
-
- 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.ClusterUpdateSettingsResponse
-
- 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.
- 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.
- getPipeline() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport.HttpChannelPipelineFactory
-
- getPipeline() - Method in class org.elasticsearch.transport.netty.NettyTransport.ClientChannelPipelineFactory
-
- getPipeline() - Method in class org.elasticsearch.transport.netty.NettyTransport.ServerChannelPipelineFactory
-
- getPluginInfos() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
-
Returns an ordered list based on plugins name
- getPluginName() - Method in class org.elasticsearch.script.ScriptContext.Plugin
-
- getPlugins() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
- getPlugins() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
-
- getPort() - Method in class org.elasticsearch.common.transport.DummyTransportAddress
-
- getPort() - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- getPort() - Method in class org.elasticsearch.common.transport.LocalTransportAddress
-
- getPort() - Method in interface org.elasticsearch.common.transport.TransportAddress
-
Returns the port of this transport address if applicable
- getPosition() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
-
- getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
-
- getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
- getPositionIncrementGap() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- 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
-
- getPreferredName() - Method in class org.elasticsearch.common.ParseField
-
- getPrefix() - Method in interface org.elasticsearch.common.logging.ESLogger
-
- getPrefix() - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- getPrefix() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
Return a prefix that all fields in this document should have.
- getPrefixQuery(String, String) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- getPreservePositionsIncrements() - Method in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- getPreserveSep() - Method in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- 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
-
- 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.
- getProcessedFiles() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns number of files in the snapshot that were processed so far
- 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
- getProfileAddresses() - Method in class org.elasticsearch.transport.TransportInfo
-
- getProfiledChildren() - Method in class org.elasticsearch.search.profile.CollectorResult
-
- getProfileName() - Method in class org.elasticsearch.transport.DelegatingTransportChannel
-
- getProfileName() - Method in class org.elasticsearch.transport.local.LocalTransportChannel
-
- getProfileName() - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
-
- 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.
- getProfilers() - Method in class org.elasticsearch.percolator.PercolateContext
-
- getProfilers() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- 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.
- getProfilers() - Method in class org.elasticsearch.search.profile.Profilers
-
Return the list of all created
Profiler
s so far.
- getProperty() - Method in class org.elasticsearch.action.fieldstats.IndexConstraint
-
- getProperty(String) - Method in interface org.elasticsearch.search.aggregations.Aggregation
-
Get the value of specified path in the aggregation.
- getProperty(String) - Method in interface org.elasticsearch.search.aggregations.Aggregations
-
Get the value of specified path in the aggregation.
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
- getProperty(String, List<String>) - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
-
- getProperty(String) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
- getProperty(String) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
- getProperty(String, List<String>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation.InternalBucket
-
- 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
-
- getPrototype(Class<T>, String) - Method in class org.elasticsearch.common.io.stream.NamedWriteableRegistry
-
Returns a prototype of the
NamedWriteable
object identified by the name provided as argument and its category
- getProvidedKey() - Method in interface org.elasticsearch.common.inject.spi.ProviderBinding
-
- getProvider(Key<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
-
- getProvider(Class<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(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the provider used to obtain instances for the given injection type.
- getProvider() - Method in interface org.elasticsearch.common.inject.Binding
-
Returns the scoped provider guice uses to fulfill requests for this
binding.
- getProvider(Key<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the provider used to obtain instances for the given injection key.
- getProvider(Class<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the provider used to obtain instances for the given type.
- getProvider() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
-
- getProvider() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
-
- getProvider(Key<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
-
- getProvider(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
-
- getProvider() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
-
Returns the looked up provider.
- getProvider(Key<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the provider used to obtain instances for the given injection key.
- getProvider(Class<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the provider used to obtain instances for the given injection type.
- 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
-
- getProvidersOf(Injector, Matcher<Class>) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns a collection of all of the providers matching the given matcher
- getProvidersOf(Injector, Class<T>) - Static method in class org.elasticsearch.common.inject.Injectors
-
Returns a collection of all providers of the given base type
- getPublishDiff() - Method in class org.elasticsearch.discovery.DiscoverySettings
-
- getPublishTimeout() - Method in class org.elasticsearch.discovery.DiscoverySettings
-
Returns the current publish timeout
- getQueryBreakdown(Query) - Method in class org.elasticsearch.search.profile.Profiler
-
Get the
ProfileBreakdown
for the given query, potentially creating it if it did not exist.
- 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
-
- 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.
- getQueryParseContext() - Method in class org.elasticsearch.indices.cache.query.terms.TermsLookup
-
- getQueryResults() - Method in class org.elasticsearch.search.profile.ProfileShardResult
-
- getQueryTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
-
- getQueryTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
-
- getQueryTree() - Method in class org.elasticsearch.search.profile.Profiler
-
- getQueue() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
- getQueueSize() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
-
- getRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- getRateLimiter() - Method in class org.apache.lucene.store.StoreRateLimiting
-
- 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
- getRawType(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
- 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.
- getReaderContext() - Method in class org.elasticsearch.search.lookup.LeafIndexLookup
-
- 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.search.profile.CollectorResult
-
- getReason() - Method in class org.elasticsearch.search.profile.InternalProfileCollector
-
- getReasonCancelled() - Method in class org.elasticsearch.tasks.CancellableTask
-
The reason the task was cancelled or null if it hasn't been cancelled.
- getRecoveredTypes() - Method in class org.elasticsearch.index.shard.TranslogRecoveryPerformer
-
Returns the recovered types modifying the mapping during the recovery
- getRecoveryStats() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- getRecoveryStats() - Method in class org.elasticsearch.indices.NodeIndicesStats
-
- 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.monitor.os.OsInfo
-
- getRefreshInterval() - Method in class org.elasticsearch.monitor.process.ProcessInfo
-
- getRegexpQuery(String, String) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- getRejected() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
- getRelationByName(String) - Static method in enum org.elasticsearch.common.geo.ShapeRelation
-
- getRelationName() - Method in enum org.elasticsearch.common.geo.ShapeRelation
-
- getRelevantIndices(ClusterState, ClusterState, ImmutableSet<String>) - Static method in class org.elasticsearch.gateway.GatewayMetaState
-
- getRelevantIndicesForMasterEligibleNode(ClusterState) - Static method in class org.elasticsearch.gateway.GatewayMetaState
-
- getRelevantIndicesOnDataOnlyNode(ClusterState, ClusterState, ImmutableSet<String>) - 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.
- getRemoteAddress() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
Returns the remote address where this rest request channel is "connected to".
- getRemoteAddress() - Method in class org.elasticsearch.rest.RestRequest
-
- getReplacement() - Method in class org.elasticsearch.index.analysis.PatternReplaceCharFilterFactory
-
- 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
- getRepositories(GetRepositoriesRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Gets repositories.
- getRepositories(GetRepositoriesRequest, ActionListener<GetRepositoriesResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Gets repositories.
- 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.cluster.metadata.SnapshotId
-
Returns repository name
- getRepositoryRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Gets snapshot repository
- 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(GetRequest, ActionRequest) - Constructor for class org.elasticsearch.action.get.GetRequest
-
Copy constructor that creates a new get request that is a copy of the one provided as an argument.
- GetRequest(String) - Constructor for class org.elasticsearch.action.get.GetRequest
-
Constructs a new get request against the specified index.
- GetRequest(ActionRequest, String) - Constructor for class org.elasticsearch.action.get.GetRequest
-
Constructs a new get request starting from the provided request, meaning that it will
inherit its headers and context, and 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.
- getRequest() - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- getRequest(GetRequest) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
This defines where to fetch the document to be percolated from, which is an alternative of defining the document
to percolate in the request body.
- 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.
- 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.TransportService.Adapter
-
- getRequestHandler(String) - Method in class org.elasticsearch.transport.TransportService
-
- getRequestHandler(String) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
-
- getRequestId() - Method in class org.elasticsearch.transport.DelegatingTransportChannel
-
- getRequestId() - Method in class org.elasticsearch.transport.local.LocalTransportChannel
-
- getRequestId() - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
-
- getRequestId() - Method in interface org.elasticsearch.transport.TransportChannel
-
- getRequests() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
-
- getRequiredSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
-
- getRerouteInterval() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- getResourceId() - Method in exception org.elasticsearch.ElasticsearchException
-
- getResourceType() - Method in exception org.elasticsearch.ElasticsearchException
-
- getResponse() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
- GetResponse - Class in org.elasticsearch.action.get
-
The response of a get action.
- GetResponse(GetResult) - Constructor for class org.elasticsearch.action.get.GetResponse
-
- 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.percolate.MultiPercolateResponse.Item
-
- 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.
- 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
-
- getRestContent(RestRequest) - Static method in class org.elasticsearch.rest.action.support.RestActions
-
Get Rest content from either payload or source parameter
- 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
-
- getRestoreSource() - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
- GetResult(boolean, long, Translog.Source) - Constructor for class org.elasticsearch.index.engine.Engine.GetResult
-
- GetResult(Engine.Searcher, Versions.DocIdAndVersion) - Constructor for class org.elasticsearch.index.engine.Engine.GetResult
-
- GetResult - Class in org.elasticsearch.index.get
-
- GetResult(String, String, String, long, boolean, BytesReference, Map<String, GetField>) - Constructor for class org.elasticsearch.index.get.GetResult
-
- getReturnType(Method) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic return type of method
.
- getRewriteTime() - Method in class org.elasticsearch.search.profile.Profiler
-
- getRewriteTime() - Method in class org.elasticsearch.search.profile.ProfileShardResult
-
- 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.
- getRootLogger() - Static method in class org.elasticsearch.common.logging.ESLoggerFactory
-
- getRootStatePath() - Method in class org.elasticsearch.index.shard.ShardPath
-
Returns the state-path root for this shard.
- getRounding() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
- getRouting() - Method in class org.elasticsearch.indices.cache.query.terms.TermsLookup
-
- getRoutingHashFunction() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- getRoutingNodes() - Method in class org.elasticsearch.cluster.ClusterState
-
Returns a built (on demand) routing nodes view of the routing table.
- getRoutingTable() - Method in class org.elasticsearch.cluster.ClusterState
-
- getRoutingTable() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- getRoutingUseType() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Return whether routing should use the _type in addition to the _id in
order to decide which shard a document should go to.
- getRows() - Method in class org.elasticsearch.common.Table
-
- getRunningTimeNanos() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
Returns the task running time
- getRxCount() - Method in class org.elasticsearch.transport.TransportStats
-
- getRxSize() - Method in class org.elasticsearch.transport.TransportStats
-
- getScope() - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
-
- getScopeAnnotation() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns the scope annotation, or null
if that isn't known for this instance.
- 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.postingshighlight.Snippet
-
- getScore() - Method in class org.elasticsearch.action.percolate.PercolateResponse.Match
-
- 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
-
- getScore() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getScore() - Method in interface org.elasticsearch.search.SearchHit
-
The score.
- getScore() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
-
- getScoreTerm(Term) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
-
- getScript() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptResponse
-
The source of the document (as a string).
- getScript() - Method in class org.elasticsearch.script.Script
-
Method for getting the script.
- getScriptFieldName() - Method in class org.elasticsearch.rest.action.script.RestGetIndexedScriptAction
-
- getScriptFieldName() - Method in class org.elasticsearch.rest.action.template.RestGetSearchTemplateAction
-
- getScriptFromResponse(GetResponse) - Static method in class org.elasticsearch.script.ScriptService
-
- getScriptLang() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptResponse
-
The type of the document.
- getScriptLang() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
-
The type of the document indexed.
- getScriptLang(RestRequest) - Method in class org.elasticsearch.rest.action.script.RestDeleteIndexedScriptAction
-
- getScriptLang(RestRequest) - Method in class org.elasticsearch.rest.action.script.RestGetIndexedScriptAction
-
- getScriptLang(RestRequest) - Method in class org.elasticsearch.rest.action.script.RestPutIndexedScriptAction
-
- getScriptLang(RestRequest) - Method in class org.elasticsearch.rest.action.template.RestDeleteSearchTemplateAction
-
- getScriptLang(RestRequest) - Method in class org.elasticsearch.rest.action.template.RestGetSearchTemplateAction
-
- getScriptLang(RestRequest) - Method in class org.elasticsearch.rest.action.template.RestPutSearchTemplateAction
-
- getScriptMode(String, ScriptService.ScriptType, ScriptContext) - Method in class org.elasticsearch.script.ScriptModes
-
Returns the script mode for a script of a certain written in a certain language,
of a certain type and executing as part of a specific operation/api.
- getScriptParameterValue(String) - Method in class org.elasticsearch.script.ScriptParameterParser
-
- getScriptStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
- getScriptValues() - Method in interface org.elasticsearch.index.fielddata.AtomicFieldData
-
Returns a "scripting" based values.
- 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
-
- getScrollIds() - Method in class org.elasticsearch.action.search.ClearScrollRequest
-
- 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.QueryParseContext
-
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
- getSearcherManager() - Method in class org.elasticsearch.index.engine.Engine
-
- getSearcherManager() - Method in class org.elasticsearch.index.engine.InternalEngine
-
- getSearcherManager() - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- getSearchQuoteAnalyzer(MappedFieldType) - Method in class org.elasticsearch.index.query.QueryParseContext
-
Gets the search quote nalyzer 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.action.termvectors.dfs.DfsOnlyRequest
-
- getSearchRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- getSeconds() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getSecondsFrac() - Method in class org.elasticsearch.common.unit.TimeValue
-
- getSecureMungedAddress() - Static method in class org.elasticsearch.common.MacAddressProvider
-
- getSegmentCount() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
-
- getSegmentInfo(SegmentInfos, boolean) - Method in class org.elasticsearch.index.engine.Engine
-
- getSegmentName(MergePolicy.OneMerge) - Static method in class org.apache.lucene.index.OneMergeHelper
-
- getSegments() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
-
- getSegments() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
-
- getSegments() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- getSegments() - Method in class org.elasticsearch.indices.NodeIndicesStats
-
- getSegmentsFile() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the segments file that this metadata snapshot represents or null if the snapshot is empty.
- getSegmentsFileName() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
-
- getSequence() - Method in class org.elasticsearch.http.netty.pipelining.OrderedUpstreamMessageEvent
-
- 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
-
- getServiceAttributes() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
The service attributes of the node.
- getSetting(String, String) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
- 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(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.
- getSettings(GetSettingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Executed a per index settings get request.
- getSettings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- getSettings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- getSettings() - Method in class org.elasticsearch.index.fielddata.FieldDataType
-
- getSettings() - Method in class org.elasticsearch.index.settings.IndexSettingsService
-
- getSettings() - Method in class org.elasticsearch.node.NodeBuilder
-
Set addition settings simply by working directly against the settings builder.
- GetSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.get
-
- GetSettingsAction() - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
-
- getSettingsKey() - Method in enum org.elasticsearch.index.store.IndexStoreModule.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
-
- getSettingsRequireUnits() - Static method in class org.elasticsearch.common.settings.Settings
-
- GetSettingsResponse - Class in org.elasticsearch.action.admin.indices.settings.get
-
- GetSettingsResponse(ImmutableOpenMap<String, Settings>) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
- getShapeAt(int) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- getShard() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getShard() - Method in interface org.elasticsearch.search.SearchHit
-
The shard of the search hit.
- getShard() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- getShardBalance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
Returns the shard related weight factor.
- 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.support.broadcast.BroadcastShardResponse
-
- getShardId() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the shards id
- getShardId(Object) - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Return the
ShardId
that holds the given segment, or
null
if this segment is not tracked.
- 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.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 exception org.elasticsearch.percolator.PercolateException
-
- getShardId() - Method in class org.elasticsearch.search.SearchShardTarget
-
- getShardInfo() - Method in class org.elasticsearch.action.ActionWriteResponse
-
- getShardMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
-
- getShardResults() - Method in class org.elasticsearch.search.profile.InternalProfileShardResults
-
- 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
-
- getShardRouting() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardRoutingEntry
-
- 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
-
- getShards(ClusterState, String, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
-
- getShards(ClusterState, String, int, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
-
- getShardSearchRequest() - Method in class org.elasticsearch.action.termvectors.dfs.ShardDfsOnlyRequest
-
- 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.
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
-
- getShardSize() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- 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
-
- getShardStatePath() - Method in class org.elasticsearch.index.shard.ShardPath
-
- getShingleFilterFactory(Analyzer) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- getSignificanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
-
- getSignificanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParametersParser
-
- getSignificanceScore() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
- getSignificanceScore() - Method in class 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.
- 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.store.StoreStats
-
- getSize() - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
-
- getSize() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- getSizeInBytes() - Method in class org.elasticsearch.common.util.BloomFilter
-
- 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
-
- getSlop() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Sets the phrase slop for this query.
- getSnapshot() - Method in class org.elasticsearch.cluster.metadata.SnapshotId
-
Returns snapshot name
- getSnapshotId() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns snapshot id
- getSnapshotId() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreCompletionResponse
-
- 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.
- 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.
- GetSnapshotsAction - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshots action
- 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, String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Constructs a new get snapshots request with given repository name and list of snapshots
- GetSnapshotsRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Constructs a new get snapshots request with given repository name
- getSnapshotsRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Gets snapshots from repository
- 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
- getSortValues() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getSortValues() - Method in interface org.elasticsearch.search.SearchHit
-
An array of the sort values used.
- getSource() - Method in class org.elasticsearch.action.get.GetResponse
-
- 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.translog.Translog.Create
-
- getSource() - Method in class org.elasticsearch.index.translog.Translog.Delete
-
- getSource() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
-
Deprecated.
- getSource() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- getSource() - Method in interface org.elasticsearch.index.translog.Translog.Operation
-
- getSource() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getSource() - Method in interface org.elasticsearch.search.SearchHit
-
The source of the document as a map (can be null).
- 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.
- getSourceAsString() - Method in class org.elasticsearch.action.get.GetResponse
-
The source of the document (as a string).
- getSourceAsString() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getSourceAsString() - Method in interface org.elasticsearch.search.SearchHit
-
The source of the document as string (can be null).
- getSourceClassName() - Method in class org.elasticsearch.common.logging.jdk.ESLogRecord
-
- 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.
- getSourceMethodName() - Method in class org.elasticsearch.common.logging.jdk.ESLogRecord
-
- getSourceNode() - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
- getSourcePath(String) - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
-
- getSourceRef() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getSourceRef() - Method in interface org.elasticsearch.search.SearchHit
-
Returns bytes reference, also un compress the source if needed.
- getSources() - Method in class org.elasticsearch.common.inject.internal.Errors
-
- getSources() - Method in class org.elasticsearch.common.inject.spi.Message
-
- getSpaceUsedByShard(Path) - Method in class org.elasticsearch.common.util.MultiDataPathUpgrader
-
- getSpins() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
-
- getStage() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns snapshot stage
- 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
- getStartOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
-
- getStartTime() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
Returns the task start time
- getStartTime() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns time when snapshot started
- getStartTime() - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
-
- getStartTime() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
- getStartTime() - Method in class org.elasticsearch.tasks.Task
-
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
-
- getState() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- 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
-
- 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 - Class in org.elasticsearch.index.get
-
- GetStats() - Constructor for class org.elasticsearch.index.get.GetStats
-
- GetStats(long, long, long, long, long) - Constructor for class org.elasticsearch.index.get.GetStats
-
- getStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
- getStats(String) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
-
- getStats(ShardId) - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache
-
Get usage statistics for the given shard.
- getStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
- getStatus() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
The status of the running task.
- 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.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(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
- getStatus(Response) - Method in class org.elasticsearch.rest.action.support.RestToXContentListener
-
- 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.
- getStatusSafe(long, ShardId) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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 the
Directory
used for the engines
IndexWriter
to write it's index files to.
- getStore() - Method in class org.elasticsearch.indices.NodeIndicesStats
-
- 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.
- 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
- getStoreStatuses() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
-
- getStrategyName() - Method in enum org.elasticsearch.common.geo.SpatialStrategy
-
- getStrictStandardDateFormatter() - Static method in class org.elasticsearch.common.joda.Joda
-
- getSubQuery() - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
-
- getSubQuery() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- getSubSearchContext() - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsSubSearchContext
-
- getSubsequence() - Method in class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
-
- getSubsetDf() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
- getSubsetDf() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
-
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
-
- getSuccessful() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- 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.
- getSuggest() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- getSuggest() - Method in class org.elasticsearch.action.search.SearchResponse
-
- getSuggest() - Method in class org.elasticsearch.action.suggest.SuggestResponse
-
The Suggestions of the phrase.
- getSuggest() - Method in class org.elasticsearch.indices.NodeIndicesStats
-
- getSuggester() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- getSuggestion(String) - Method in class org.elasticsearch.search.suggest.Suggest
-
- getSuggestion() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Returns all suggestions with the defined names.
- getSuggestMetric() - Method in class org.elasticsearch.index.shard.IndexShard
-
- getSum() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- 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 interface org.elasticsearch.search.aggregations.metrics.stats.Stats
-
- getSumDocFreq() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- getSumOfOtherDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- 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.
- 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
-
- 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
-
- getSumTotalTermFreq() - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- getSupersetDf() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
- getSupersetDf() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
-
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.Bucket
-
- getSupertype(Class<?>) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the generic form of supertype
.
- 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.
- getSyncInterval() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the current async fsync interval
- getSystemCpuPercent() - Method in class org.elasticsearch.monitor.os.OsProbe
-
- getSystemLoadAverage() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the system load average for the last minute.
- 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.RestThreadPoolAction
-
- getTarget() - Method in class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
Returns the current value of the Target property.
- getTargetNode() - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
- getTask(long) - Method in class org.elasticsearch.tasks.TaskManager
-
Returns a task with given id, or null if the task is not found.
- getTaskFailures() - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
-
The list of task failures exception.
- getTaskId() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- 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
-
- getTaskManager() - Method in interface org.elasticsearch.cluster.ClusterService
-
Returns task manager created in the cluster service
- getTaskManager() - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- 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.
- getTasks() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
- getTasks() - Method in class org.elasticsearch.tasks.TaskManager
-
Returns the list of currently running tasks on the node
- getTb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- getTbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- getTemplate() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- 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.
- getTemplates() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- getTempNameForFile(String) - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
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
-
- 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(TermVectorsRequest, String) - Method in class org.elasticsearch.index.termvectors.ShardTermVectorsService
-
- 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.postingshighlight.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
-
- 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.index.engine.EngineConfig
-
- getThreadPool() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns a
ThreadPool
to schedule async durability operations
- 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
- getThrottleTime() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
Gets the amount of time in a TimeValue that the index has been under merge throttling control
- getThrottleTime() - Method in class org.elasticsearch.index.store.StoreStats
-
- getThrottleTimeInMillis() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
Gets the amount of time in milliseconds 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.common.StopWatch.TaskInfo
-
Return the time this task took.
- getTime() - Method in class org.elasticsearch.index.get.GetStats
-
- getTime() - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- getTime() - Method in class org.elasticsearch.index.suggest.stats.SuggestStats
-
- getTime() - Method in class org.elasticsearch.search.profile.CollectorResult
-
- getTime() - Method in class org.elasticsearch.search.profile.InternalProfileCollector
-
- getTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
-
- getTimeInMillis() - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- getTimeInMillis() - Method in class org.elasticsearch.index.suggest.stats.SuggestStats
-
- getTimeInNanos() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
-
Returns the elapsed time between two successive barrier executions.
- getTimeInQueue() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
-
- getTimeInQueueInMillis() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
-
- getTimeInSeconds() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
-
Returns the elapsed time between two successive barrier executions.
- getTimeout() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
- getTimer() - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
- getTimestamp() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
- 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
-
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Bucket
-
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- getTo() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
-
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Bucket
-
- getToAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
-
- getTokenFilterFactory(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenFilters
-
- getTokenizerFactory(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
-
- getTokenLocation() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- getTokenLocation() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
Used for error reporting to highlight where syntax errors occur in
content being parsed.
- 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
-
- getTook() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
How long the bulk execution took.
- getTook() - Method in class org.elasticsearch.action.percolate.PercolateResponse
-
How long the percolate took.
- getTook() - Method in class org.elasticsearch.action.search.SearchResponse
-
How long the search took.
- getTook() - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyResponse
-
- getTook() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
-
- getTookInMillis() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
How long the bulk execution took in milliseconds.
- getTookInMillis() - Method in class org.elasticsearch.action.percolate.PercolateResponse
-
How long the percolate took in milliseconds.
- getTookInMillis() - Method in class org.elasticsearch.action.search.SearchResponse
-
How long the search took in milliseconds.
- getTookInMillis() - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyResponse
-
- getTookInMillis() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
-
- getTotal() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- 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.index.flush.FlushStats
-
The total number of flush executed.
- getTotal() - Method in class org.elasticsearch.index.indexing.IndexingStats
-
- 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.search.stats.SearchStats
-
- 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
-
- getTotalCapacity() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
-
- getTotalCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The total number of lookups in the cache.
- getTotalHits() - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- getTotalHits() - Method in interface org.elasticsearch.search.SearchHits
-
The total number of hits that matches the search request.
- 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, Percolate, Segments (memory, index writer, version map)
- getTotalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- getTotalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- 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
-
- getTotalPhysicalMemorySize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the total amount of physical memory in bytes.
- 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
-
- getTotalSizeInBytes() - Method in class org.elasticsearch.index.merge.MergeStats
-
- 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.
- 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.
- 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
- 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
-
- getTragicException() - Method in class org.elasticsearch.index.translog.Translog
-
If this Translog
was closed as a side-effect of a tragic exception,
e.g.
- getTragicException() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
If this TranslogWriter
was closed as a side-effect of a tragic exception,
e.g.
- 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.index.engine.Engine
-
returns the translog for this engine
- getTranslog() - Method in class org.elasticsearch.index.engine.InternalEngine
-
- getTranslog() - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- 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.shard.IndexShard
-
Returns the current translog durability mode
- getTranslogGeneration() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the translog generation to open.
- getTranslogLocation() - Method in class org.elasticsearch.index.engine.Engine.Delete
-
- getTranslogLocation() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- getTranslogPath() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the translog path for this engine
- getTranslogRecoveryPerformer() - Method in class org.elasticsearch.index.engine.EngineConfig
-
- getTranslogSizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogStats
-
- getTransport() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
- getTransport() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
- 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.MemoryCircuitBreaker
-
- 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.apache.lucene.store.StoreRateLimiting
-
- getType() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- 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.delete.DeleteResponse
-
The type of the document deleted.
- getType() - Method in class org.elasticsearch.action.explain.ExplainResponse
-
- getType() - Method in class org.elasticsearch.action.get.GetResponse
-
The type of the document.
- getType() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The type of the document.
- getType() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The type of the action.
- getType() - Method in class org.elasticsearch.action.index.IndexResponse
-
The type of the document indexed.
- getType() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
-
The type of the document deleted.
- 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.action.update.UpdateResponse
-
The type of the document indexed.
- 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.fielddata.FieldDataType
-
- 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.translog.TranslogConfig
-
Returns the translog type
- getType() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
-
- getType() - Method in class org.elasticsearch.indices.cache.query.terms.TermsLookup
-
- getType() - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
- getType() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
-
- getType() - Method in class org.elasticsearch.repositories.RepositoryName
-
- getType() - Method in class org.elasticsearch.script.Script
-
Method for getting the type.
- getType() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getType() - Method in class org.elasticsearch.search.rescore.RescoreSearchContext
-
- getType() - Method in interface 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.PhraseSuggestion
-
- getType() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.CandidateGenerator
-
- getType() - Method in class org.elasticsearch.search.suggest.Suggest.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 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
-
- 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() - Static method in class org.elasticsearch.index.query.QueryParseContext
-
- getTypeStats() - Method in class org.elasticsearch.index.indexing.IndexingStats
-
- 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().
- getUnloadedClassCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
-
- getUpgradeVersion() - 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
-
- getUptime() - Method in class org.elasticsearch.monitor.jvm.JvmStats
-
- getUrl() - Method in class org.elasticsearch.plugins.PluginInfo
-
We compute the URL for sites: "/_plugin/" + name + "/"
- getUsabelSpace(NodeEnvironment.NodePath) - Method in class org.elasticsearch.common.util.MultiDataPathUpgrader
-
- 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.MemoryCircuitBreaker
-
- 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
-
- getUsedDiskThresholdHigh() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- getUsedDiskThresholdLow() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- getUsedPercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
-
- getUserData() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
-
- getUserData() - Method in class org.elasticsearch.index.engine.CommitStats
-
- getValidationFailures() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
The validation failures on the cluster level (without index validation failures).
- getValidationFailures() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
-
- getValidationFailures() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
-
- getValue() - Method in class org.elasticsearch.action.fieldstats.IndexConstraint
-
- getValue() - Method in interface org.elasticsearch.common.inject.spi.ConvertedConstantBinding
-
Returns the converted value.
- 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.get.GetField
-
- 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 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.max.InternalMax
-
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.max.Max
-
The maximum.
- 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.percentiles.InternalPercentile
-
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.Percentile
-
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
-
- 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 interface org.elasticsearch.search.aggregations.metrics.valuecount.ValueCount
-
- getValue() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
- getValue() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- getValue() - Method in class org.elasticsearch.search.lookup.FieldLookup
-
- getValue() - Method in interface org.elasticsearch.search.SearchHitField
-
The first value of the hit.
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
-
- getValueAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregation.SingleValue
-
- getValueCount() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalMapping
-
- getValueCount() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number of distinct ordinals in this builder.
- getValueForNormalization() - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
-
Deprecated.
- getValueForNormalization() - Method in class org.elasticsearch.search.profile.ProfileWeight
-
- getValues(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
-
- getValues(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
-
- getValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
-
- getValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
- getValues() - Method in interface 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.fielddata.ScriptDocValues.Longs
-
- getValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
-
- getValues() - Method in class org.elasticsearch.index.get.GetField
-
- 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(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
-
- getValues() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- getValues() - Method in class org.elasticsearch.search.lookup.FieldLookup
-
- getValues() - Method in interface org.elasticsearch.search.SearchHitField
-
The field values.
- getValuesSourceType() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
-
- 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
-
- 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
-
- 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.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
Version of the store, used to select the store that will be
used as a primary.
- getVersion() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The version of the action.
- getVersion() - Method in class org.elasticsearch.action.delete.DeleteResponse
-
The version of the delete operation.
- getVersion() - Method in class org.elasticsearch.action.get.GetResponse
-
The version of the doc.
- getVersion() - Method in class org.elasticsearch.action.index.IndexResponse
-
Returns the current version of the doc indexed.
- getVersion() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
-
The version of the delete operation.
- getVersion() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptResponse
-
The version of the doc.
- getVersion() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
-
Returns the current version of the doc indexed.
- getVersion() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
-
- getVersion() - Method in class org.elasticsearch.action.update.UpdateResponse
-
Returns the current version of the doc indexed.
- getVersion() - Method in class org.elasticsearch.cluster.ClusterState
-
- getVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- 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
-
- getVersion() - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
- 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.monitor.jvm.JvmInfo
-
- getVersion() - Method in class org.elasticsearch.monitor.os.OsInfo
-
- getVersion() - Method in class org.elasticsearch.plugins.PluginInfo
-
- getVersion() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- getVersion() - Method in interface org.elasticsearch.search.SearchHit
-
The version of the 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
- getVersionMapSize() - Method in class org.elasticsearch.index.engine.EngineConfig
-
returns the size of the version map that should trigger a refresh
- getVersionMapSizeSetting() - Method in class org.elasticsearch.index.engine.EngineConfig
-
current setting for the version map size that should trigger a refresh.
- getVersions() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
-
- getVersions() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
- 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
-
- 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
IndicesWarmer
used to warm new searchers before they are used for searching.
- getWarmers() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
-
- getWarmers() - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersResponse
-
- getWarmers(GetWarmersRequest, ActionListener<GetWarmersResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Returns a map of index warmers for the given get request.
- getWarmers(GetWarmersRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Returns a map of index warmers for the given get request.
- GetWarmersAction - Class in org.elasticsearch.action.admin.indices.warmer.get
-
Action for the admin/warmers/get API.
- GetWarmersRequest - Class in org.elasticsearch.action.admin.indices.warmer.get
-
- GetWarmersRequest() - Constructor for class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequest
-
- GetWarmersRequestBuilder - Class in org.elasticsearch.action.admin.indices.warmer.get
-
- GetWarmersRequestBuilder(ElasticsearchClient, GetWarmersAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequestBuilder
-
- GetWarmersResponse - Class in org.elasticsearch.action.admin.indices.warmer.get
-
- getWeight() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
-
- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- getWordList(Environment, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
-
Fetches a list of words from the specified settings file.
- getWordSet(Environment, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
-
- getWrappedAnalyzer(String) - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
-
- getWrappedAnalyzer(String) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
- getWrappingService() - Method in class org.elasticsearch.index.engine.EngineConfig
-
- getWriteableName() - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
-
- getWriteableName() - Method in interface org.elasticsearch.common.io.stream.NamedWriteable
-
Returns the name of the writeable object
- giga() - Method in class org.elasticsearch.common.unit.SizeValue
-
- gigaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
-
- global() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
- global(ClusterBlockLevel) - 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 - Interface in org.elasticsearch.search.aggregations.bucket.global
-
A global
aggregation.
- GlobalAggregator - Class in org.elasticsearch.search.aggregations.bucket.global
-
- GlobalAggregator(String, AggregatorFactories, AggregationContext, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
-
- GlobalAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.global
-
- 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.admin.indices.flush.TransportShardFlushAction
-
- globalBlockLevel() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
-
- globalBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Cluster level block to check before request execution
- GlobalBuilder - Class in org.elasticsearch.search.aggregations.bucket.global
-
Builder for the
Global
aggregation.
- GlobalBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalBuilder
-
Sole constructor.
- globalFieldCaseConversion - Static variable in class org.elasticsearch.common.xcontent.XContentBuilder
-
- globalFieldCaseConversion(XContentBuilder.FieldCaseConversion) - Static method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- globalForceSource(boolean) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight
-
- globalIfd - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- globalMaxOrd(IndexSearcher, String) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
-
- globalMaxOrd(IndexSearcher) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
-
- GlobalOrdinalMapping - Class in org.elasticsearch.index.fielddata.ordinals
-
A RandomAccessOrds
implementation that returns ordinals that are global.
- 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(Index, Settings, MappedFieldType.Names, FieldDataType, long) - Constructor for class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
-
- GlobalOrdinalsSignificantTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- GlobalOrdinalsSignificantTermsAggregator(String, AggregatorFactories, ValuesSource.Bytes.WithOrdinals.FieldData, TermsAggregator.BucketCountThresholds, IncludeExclude.OrdinalsFilter, AggregationContext, Aggregator, SignificantTermsAggregatorFactory, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
-
- GlobalOrdinalsSignificantTermsAggregator.WithHash - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- 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, Terms.Order, TermsAggregator.BucketCountThresholds, IncludeExclude.OrdinalsFilter, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
-
- GlobalOrdinalsStringTermsAggregator.LowCardinality - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Variant of
GlobalOrdinalsStringTermsAggregator
that resolves global ordinals post segment collection
instead of on the fly for each match.This is beneficial for low cardinality fields, because it can reduce
the amount of look-ups significantly.
- GlobalOrdinalsStringTermsAggregator.WithHash - Class in org.elasticsearch.search.aggregations.bucket.terms
-
- globalOrdinalsValues(String, LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
-
- 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
-
- globalOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
-
- GlobalParser - Class in org.elasticsearch.search.aggregations.bucket.global
-
- GlobalParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalParser
-
- globalSettings() - Method in class org.elasticsearch.repositories.RepositorySettings
-
- GND - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- GND(boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
-
- GND.GNDBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- GND.GNDParser - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- GNDBuilder(boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDBuilder
-
- GNDParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDParser
-
- gramSize(int) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the gram size for the n-gram model used for this suggester.
- GreekAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- GreekAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GreekAnalyzerProvider
-
- GroovyScriptCompilationException - Exception in org.elasticsearch.script.groovy
-
- GroovyScriptCompilationException(String, Throwable) - Constructor for exception org.elasticsearch.script.groovy.GroovyScriptCompilationException
-
Deprecated.
- GroovyScriptCompilationException(StreamInput) - Constructor for exception org.elasticsearch.script.groovy.GroovyScriptCompilationException
-
Deprecated.
- GroovyScriptExecutionException - Exception in org.elasticsearch.script.groovy
-
- GroovyScriptExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.script.groovy.GroovyScriptExecutionException
-
Deprecated.
- GroovyScriptExecutionException(StreamInput) - Constructor for exception org.elasticsearch.script.groovy.GroovyScriptExecutionException
-
Deprecated.
- group(Map<String, List<Suggest.Suggestion>>, Suggest) - Static method in class org.elasticsearch.search.suggest.Suggest
-
- groupBy(ShardOperationFailedException[]) - Static method in class org.elasticsearch.ExceptionsHelper
-
Deduplicate the failures by exception message and index.
- groupByAllIt() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
A groups shards iterator where each groups is a single
ShardRouting
and a group
is created for each shard routing.
- groupByShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
A group shards iterator where each group (
ShardIterator
is an iterator across shard replication group.
- groupDismax - Variable in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
-
- groups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Sets specific search group stats to retrieve the stats for.
- groups() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- groups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Sets specific search group stats to retrieve the stats for.
- groups() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- GroupShardsIterator - Class in org.elasticsearch.cluster.routing
-
- GroupShardsIterator(List<ShardIterator>) - Constructor for class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Constructs a enw GroupShardsIterator from the given list.
- groupStats() - Method in class org.elasticsearch.percolator.PercolateContext
-
- groupStats(List<String>) - Method in class org.elasticsearch.percolator.PercolateContext
-
- groupStats() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- groupStats(List<String>) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- groupStats() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- groupStats(List<String>) - 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.SearchContext
-
- groupStats(List<String>) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- 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(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(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(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.
- grow() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
- grow(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Ensure there are at least maxBucketOrd
buckets available.
- gt(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- gt(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gt(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gt(int) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gt(long) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gt(float) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gt(double) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gte(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- gte(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gte(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gte(int) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gte(long) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gte(float) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- gte(double) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- guardedRamBytesUsed(Accountable) - Static method in class org.elasticsearch.index.engine.Engine
-
Returns 0 in the case where accountable is null, otherwise returns ramBytesUsed()
- guessBodyContentType(RestRequest) - Static method in class org.elasticsearch.rest.action.support.RestActions
-
guesses the content type from either payload or source parameter
- guessRootCauses() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
-
- guessRootCauses() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the root cause of this exception or mupltiple if different shards caused different exceptions
- guessRootCauses(Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns the root cause of this exception or mupltiple if different shards caused different exceptions.
- Guice - Class in org.elasticsearch.common.inject
-
The entry point to the Guice framework.
- GZIP - Static variable in class org.elasticsearch.common.Base64
-
Specify that data should be gzip-compressed in second bit.
- IBSimilarityProvider - Class in org.elasticsearch.index.similarity
-
- IBSimilarityProvider(String, Settings) - Constructor for class org.elasticsearch.index.similarity.IBSimilarityProvider
-
- 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(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Sets the id of the document to delete.
- id() - Method in interface org.elasticsearch.action.DocumentRequest
-
Get the id of the document for this request
- id() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- 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() - 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(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the id of the indexed document.
- id() - Method in enum org.elasticsearch.action.index.IndexRequest.OpType
-
The internal representation of the operation type.
- id() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
The id of the document to delete.
- id(String) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
Sets the id of the document to delete.
- id - Variable in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- id(String) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
Sets the id of the script to fetch.
- id() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- id() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
The id of the indexed document.
- id(String) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets 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(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets 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(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the id of the indexed document.
- id() - Method in enum org.elasticsearch.action.WriteConsistencyLevel
-
- id() - Method in class org.elasticsearch.cluster.block.ClusterBlock
-
- id() - Method in enum org.elasticsearch.cluster.block.ClusterBlockLevel
-
- id() - Method in enum org.elasticsearch.cluster.ClusterState.ClusterStateStatus
-
- id() - Method in enum org.elasticsearch.cluster.metadata.IndexMetaData.State
-
- id() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
- Id(String) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.Id
-
- id() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
The id value parsed, null if does not require parsing, or not resolved.
- id() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The unique id of the node.
- 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.FactorRounding
-
- id() - Method in class org.elasticsearch.common.rounding.Rounding
-
- id() - Method in class org.elasticsearch.common.rounding.Rounding.Interval
-
- id() - Method in class org.elasticsearch.common.rounding.Rounding.OffsetRounding
-
- id() - Method in class org.elasticsearch.common.transport.LocalTransportAddress
-
- id() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
-
an always increasing unique identifier for this ping response.
- id() - Method in exception org.elasticsearch.index.AlreadyExpiredException
-
- id() - Method in exception org.elasticsearch.index.engine.CreateFailedEngineException
-
- id() - Method in class org.elasticsearch.index.engine.Engine.Delete
-
- id() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- id() - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
-
- id() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- id(String) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Really, just the id mapper should set this.
- id() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- id(String) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
Really, just the id mapper should set this.
- id() - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- id() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- id(String) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- id() - Method in class org.elasticsearch.index.mapper.Uid
-
- ID - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item.Field
-
- id() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- id(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- 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.Create
-
- 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 enum org.elasticsearch.indices.recovery.RecoveryState.Type
-
- id() - Method in class org.elasticsearch.percolator.PercolateContext
-
- id() - Method in class org.elasticsearch.search.action.SearchServiceTransportAction.ScrollFreeContextRequest
-
- id() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.BooleanFormatter
-
- id() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
-
- id() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.GeoHash
-
- id() - Method in interface org.elasticsearch.search.aggregations.support.format.ValueFormatter
-
Uniquely identifies this formatter (used for efficient serialization)
- id() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.IPv4Formatter
-
- id() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Number.Pattern
-
- id() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Raw
-
- id() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- id() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
-
- id() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
-
- id() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
-
- id() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- 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.InternalSearchHit
-
- id() - Method in class org.elasticsearch.search.internal.SearchContext
-
- id() - Method in class org.elasticsearch.search.query.QuerySearchRequest
-
- id() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- id() - Method in exception org.elasticsearch.search.SearchContextMissingException
-
- id() - Method in interface org.elasticsearch.search.SearchHit
-
The id of the document.
- id() - Method in interface org.elasticsearch.search.SearchPhaseResult
-
- id() - Method in enum org.elasticsearch.search.suggest.Suggest.Suggestion.Sort
-
- id - Variable in class org.elasticsearch.Version
-
- 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.
- idFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- IdFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
- IdFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- IdFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- IdFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- idParsingStillNeeded() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Is id parsing still needed?
- idResolved() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Has id been resolved during the parsing phase.
- ids(String[]) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
-
- ids(String...) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Adds ids to the filter.
- ids(Collection<String>) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Adds ids to the filter.
- ids(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Deprecated.
- IDS - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryParser.Field
-
- idsEqual(byte[]) - Method in class org.elasticsearch.index.engine.Engine.CommitId
-
- 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(String...) - Constructor for class org.elasticsearch.index.query.IdsQueryBuilder
-
- IdsQueryParser - Class in org.elasticsearch.index.query
-
- IdsQueryParser() - Constructor for class org.elasticsearch.index.query.IdsQueryParser
-
- IEEEremainder(Short, Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- IEEEremainder(Integer, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- IEEEremainder(Float, Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- IEEEremainder(Long, Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- IEEEremainder(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- ifd - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- IGNORE_ABOVE - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
-
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
-
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Defaults
-
- IGNORE_MALFORMED - Static variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Names
-
- IGNORE_SYSTEM_PROPERTIES_SETTING - Static variable in class org.elasticsearch.node.internal.InternalSettingsPreparer
-
- IGNORE_UNMAPPED - Static variable in class org.elasticsearch.search.sort.SortParseElement
-
- ignoreAbove - Variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
-
- ignoreAbove(int) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
-
- 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).
- ignoreDisable(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
- ignoreDisable() - 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
- ignoreErrorsOnGeneratedFields(boolean) - Method in class org.elasticsearch.action.get.GetRequest
-
- ignoreErrorsOnGeneratedFields() - Method in class org.elasticsearch.action.get.GetRequest
-
- ignoreErrorsOnGeneratedFields - Variable in class org.elasticsearch.action.get.MultiGetRequest
-
- ignoreErrorsOnGeneratedFields(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- ignoreErrorsOnGeneratedFields(Boolean) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
- ignoreErrorsOnGeneratedFields() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
- ignoreException() - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsContext.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(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
- 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() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns index settings that that shouldn't be restored
- ignoreLike(MoreLikeThisQueryBuilder.Item...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
- ignoreLike(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
-
- ignoreMalformed(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
-
- ignoreMalformed - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- ignoreMalformed - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- ignoreMalformed(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- ignoreMalformed - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- ignoreMalformed(boolean) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
- ignoreMalformed(boolean) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
- ignoreMissing() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
-
- ignoreMissing(boolean) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
-
- ignoreMissing() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- IgnoreOnRecoveryEngineException - Interface in org.elasticsearch.index.engine
-
Exceptions implementing this interface will be ignored during recovery.
- 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)
- ignoreReplicaException(Throwable) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Should an exception be ignored when the operation is performed on the replica.
- ignoreShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Marks a shard as temporarily ignored and adds it to the ignore unassigned list.
- ignoreUnassignedIfDelayed(RoutingNodes.UnassignedShards.UnassignedIterator, ShardRouting) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
Check if the allocation of the replica is to be delayed.
- ignoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Set to true to ignore unavailable snapshots
- ignoreUnavailable() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
- ignoreUnavailable() - Method in class org.elasticsearch.action.support.IndicesOptions
-
- ignoreUnmapped(boolean) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
- IllegalIndexShardStateException - Exception in org.elasticsearch.index.shard
-
- IllegalIndexShardStateException(ShardId, IndexShardState, String) - Constructor for exception org.elasticsearch.index.shard.IllegalIndexShardStateException
-
- IllegalIndexShardStateException(ShardId, IndexShardState, String, Throwable) - Constructor for exception org.elasticsearch.index.shard.IllegalIndexShardStateException
-
- IllegalIndexShardStateException(StreamInput) - 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 - Static variable in class org.elasticsearch.common.Priority
-
- immutableMap() - Method in class org.elasticsearch.common.collect.MapBuilder
-
- 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
-
- immutableReader() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
returns a new immutable reader which only exposes the current written operation *
- ImmutableTranslogReader - Class in org.elasticsearch.index.translog
-
a translog reader which is fixed in length
- ImmutableTranslogReader(long, ChannelReference, long, long, int) - Constructor for class org.elasticsearch.index.translog.ImmutableTranslogReader
-
Create a snapshot of translog file channel.
- 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
-
- in(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
See the EDSL examples at
Binder
.
- in(Scope) - 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 class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
- INACTIVE_SHARD_INDEXING_BUFFER - Static variable in class org.elasticsearch.indices.memory.IndexingMemoryController
-
Once a shard becomes inactive, we reduce the IndexWriter
buffer to this value (500 KB) to let active shards use the heap instead.
- INACTIVE_SHARD_TRANSLOG_BUFFER - Static variable in class org.elasticsearch.indices.memory.IndexingMemoryController
-
Once a shard becomes inactive, we reduce the Translog
buffer to this value (1 KB) to let active shards use the heap instead.
- 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
-
- include(boolean) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Whether to include the input documents.
- INCLUDE - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryParser.Field
-
- include(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
-
- include(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Define a regular expression that will determine what terms should be aggregated.
- include(String, int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Define a regular expression that will determine what terms should be aggregated.
- include(String[]) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Define a set of terms that should be aggregated.
- include(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Define a set of terms that should be aggregated.
- include(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Define a regular expression that will determine what terms should be aggregated.
- include(String[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Define a set of terms that should be aggregated.
- include(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Define a set of terms that should be aggregated.
- include(double[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Define a set of terms that should be aggregated.
- INCLUDE_NEGATIVES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
-
- includeAliases(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
If set to true the restore procedure will restore aliases
- includeAliases() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns true if aliases should be restored from this snapshot
- includeAliases() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns true if aliases should be restore during this restore operation
- 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(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
- includeExclude - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
-
- IncludeExclude - Class in org.elasticsearch.search.aggregations.bucket.terms.support
-
Defines the include/exclude regular expression filtering for string terms aggregation.
- IncludeExclude(RegExp, RegExp) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude
-
- IncludeExclude(SortedSet<BytesRef>, SortedSet<BytesRef>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude
-
- includeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude.Parser
-
- IncludeExclude.LongFilter - Class in org.elasticsearch.search.aggregations.bucket.terms.support
-
- IncludeExclude.OrdinalsFilter - Class in org.elasticsearch.search.aggregations.bucket.terms.support
-
- IncludeExclude.Parser - Class in org.elasticsearch.search.aggregations.bucket.terms.support
-
- IncludeExclude.StringFilter - Class in org.elasticsearch.search.aggregations.bucket.terms.support
-
- includeFetch() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
-
- includeFetch() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- includeFetch() - Method in class org.elasticsearch.search.query.QuerySearchResultProvider
-
If both query and fetch happened on the same call.
- includeFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- 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() - 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(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
If set to true the restore procedure will restore global cluster state.
- 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.cluster.SnapshotsInProgress.Entry
-
- includeGlobalState() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns true if global state should be restore during this restore operation
- includeGlobalState(boolean) - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Set to true if global state should be stored as part of the snapshot
- includeGlobalState() - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Returns true if global state should be stored as part of the snapshot
- includeInAll - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- includeInAll - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- includeInAll(Boolean) - Method in interface org.elasticsearch.index.mapper.internal.AllFieldMapper.IncludeInAll
-
If includeInAll
is not null then return a copy of this mapper
that will include values in the _all field according to includeInAll
.
- includeInAll - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
-
- includeInAll(boolean) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
-
- includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- includeInAll(Boolean, FieldMapper) - Method in class org.elasticsearch.index.mapper.ParseContext
-
- includeInAllIfNotSet(Boolean) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- includeInAllIfNotSet(Boolean) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- includeInAllIfNotSet(Boolean) - Method in interface org.elasticsearch.index.mapper.internal.AllFieldMapper.IncludeInAll
-
If includeInAll
is not null and not set on this mapper yet, then
return a copy of this mapper that will include values in the _all field
according to includeInAll
.
- includeInAllIfNotSet(Boolean) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- includeLower(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- 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
-
- IncludeNestedDocsQuery - Class in org.elasticsearch.index.search.nested
-
A special query that accepts a top level parent matching query, and returns the nested docs of the matching parent
doc as well.
- IncludeNestedDocsQuery(Query, BitSetProducer) - Constructor for class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
-
- includeProperty(String) - Method in class org.elasticsearch.common.xcontent.support.filtering.FilterPathBasedFilter
-
- includes(String[]) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
-
- includes() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- includes() - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- includes(String[]) - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- includeUpper(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- includeUpper(boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Should the upper bound be included or not.
- IncompatibleClusterStateVersionException - Exception in org.elasticsearch.cluster
-
- IncompatibleClusterStateVersionException(String) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
-
- IncompatibleClusterStateVersionException(long, String, long, String) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
-
- IncompatibleClusterStateVersionException(StreamInput) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
-
- 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.
- 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)
- incrementOperationCounter() - Method in class org.elasticsearch.index.shard.IndexShard
-
- incrementRecoveredOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.UniqueTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.PrefixAnalyzer.PrefixTokenFilter
-
- incrementToken() - Method in class org.elasticsearch.common.lucene.all.AllTokenStream
-
- incrementToken() - Method in class org.elasticsearch.index.analysis.NumericTokenizer
-
- incrementToken() - Method in class org.elasticsearch.search.suggest.completion.CompletionTokenStream
-
- incrementVersion() - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- index() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- 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(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
- index() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
-
- index() - Method in interface org.elasticsearch.action.DocumentRequest
-
Get the index that this request operates on
- index() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- index(String) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- index() - Method in class org.elasticsearch.action.search.ShardSearchFailure
-
The index the search failed on.
- index() - Method in interface org.elasticsearch.action.ShardOperationFailedException
-
The index the operation failed on.
- index() - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
-
- index - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
-
- index() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
- index(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
- index - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
-
- index() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
-
- index(String) - Method 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() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
- index(String) - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
Sets the index.
- index(IndexRequest) - Method in interface org.elasticsearch.client.Client
-
Index a JSON source associated with a given index and type.
- index(IndexRequest, ActionListener<IndexResponse>) - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- index(IndexRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
- index(IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
- index() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
-
- index(String) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- index() - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- Index(IndexMetaData) - Constructor for class org.elasticsearch.cluster.metadata.AliasOrIndex.Index
-
- index() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- index(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- index(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- index() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Return the index id
- index() - Method in class org.elasticsearch.cluster.routing.RestoreSource
-
- index(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- index() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The index name.
- index - Variable in class org.elasticsearch.common.util.concurrent.AtomicArray.Entry
-
The original index of the value within the array.
- index - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
-
- index() - Method in enum org.elasticsearch.common.xcontent.XContentType
-
- index - Variable in class org.elasticsearch.index.AbstractIndexComponent
-
- index() - Method in class org.elasticsearch.index.AbstractIndexComponent
-
- index() - Method in exception org.elasticsearch.index.AlreadyExpiredException
-
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.Engine
-
- Index(Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.Index
-
- Index(Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long) - Constructor for class org.elasticsearch.index.engine.Engine.Index
-
- Index(Term, ParsedDocument) - Constructor for class org.elasticsearch.index.engine.Engine.Index
-
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
-
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- index - Variable in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
-
- index() - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
-
- index() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.GlobalFieldData
-
- Index - Class in org.elasticsearch.index
-
- Index(String) - Constructor for class org.elasticsearch.index.Index
-
- index() - Method in interface org.elasticsearch.index.IndexComponent
-
- index(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- index(boolean) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Builder
-
Deprecated.
- index() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- index() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- index() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- index(String) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- INDEX - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item.Field
-
- index() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- index(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- index() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- index(Engine.Index) - Method in class org.elasticsearch.index.shard.IndexShard
-
Index a document and return whether it was created, as opposed to just
updated.
- index() - Method in class org.elasticsearch.index.shard.ShardId
-
- index() - Method in class org.elasticsearch.index.shard.SnapshotStatus
-
- Index() - Constructor for class org.elasticsearch.index.shard.SnapshotStatus.Index
-
- Index() - Constructor for class org.elasticsearch.index.translog.Translog.Index
-
- Index(Engine.Index) - Constructor for class org.elasticsearch.index.translog.Translog.Index
-
- Index(String, String, byte[]) - Constructor for class org.elasticsearch.index.translog.Translog.Index
-
- Index() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Index
-
- index() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- index() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- index() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
- index() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
-
- index() - Method in interface org.elasticsearch.search.SearchHit
-
The index of the hit.
- index() - Method in class org.elasticsearch.search.SearchShardTarget
-
- index() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
Returns index where failure occurred
- INDEX - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- INDEX_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.indices.memory.IndexingMemoryController
-
How much heap (% or bytes) we will share across all actively indexing shards on this node (default: 10%).
- INDEX_BYTES_SIZE_SETTINGS - Static variable in class org.elasticsearch.cluster.metadata.MetaDataIndexUpgradeService
-
All known byte-sized settings for an index.
- INDEX_CACHE_REQUEST_ENABLED - Static variable in class org.elasticsearch.indices.cache.request.IndicesRequestCache
-
A setting to enable or disable request caching on an index level.
- INDEX_CLOSED_BLOCK - 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 - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_COMPOUND_ON_FLUSH - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
Index setting for compound file on flush.
- INDEX_CONTENT_TYPE - Static variable in class org.elasticsearch.client.Requests
-
The default content type to use to generate source documents when indexing.
- INDEX_DELAYED_NODE_LEFT_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.routing.UnassignedInfo
-
- INDEX_DELETED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
-
- INDEX_FLUSH_ON_CLOSE - Static variable in class org.elasticsearch.index.shard.IndexShard
-
Index setting to control if a flush is executed before engine is closed
This setting is realtime updateable.
- INDEX_FOLDER_NAME - Static variable in class org.elasticsearch.index.shard.ShardPath
-
- INDEX_FORCE_NEW_TRANSLOG - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
if set to true the engine will start even if the translog id in the commit point can not be found
- INDEX_GC_DELETES_SETTING - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
Index setting to enable / disable deletes garbage collection.
- INDEX_INDEXING_SLOWLOG_LEVEL - Static variable in class org.elasticsearch.index.indexing.IndexingSlowLog
-
- INDEX_INDEXING_SLOWLOG_MAX_SOURCE_CHARS_TO_LOG - Static variable in class org.elasticsearch.index.indexing.IndexingSlowLog
-
- INDEX_INDEXING_SLOWLOG_REFORMAT - Static variable in class org.elasticsearch.index.indexing.IndexingSlowLog
-
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_DEBUG - Static variable in class org.elasticsearch.index.indexing.IndexingSlowLog
-
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_INFO - Static variable in class org.elasticsearch.index.indexing.IndexingSlowLog
-
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_TRACE - Static variable in class org.elasticsearch.index.indexing.IndexingSlowLog
-
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_WARN - Static variable in class org.elasticsearch.index.indexing.IndexingSlowLog
-
- 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_NESTED_FIELDS_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
-
- INDEX_MERGE_ENABLED - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_MERGE_POLICY_EXPUNGE_DELETES_ALLOWED - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_MERGE_POLICY_FLOOR_SEGMENT - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_MERGE_POLICY_MAX_MERGE_AT_ONCE - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_MERGE_POLICY_MAX_MERGE_AT_ONCE_EXPLICIT - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_MERGE_POLICY_MAX_MERGED_SEGMENT - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_MERGE_POLICY_RECLAIM_DELETES_WEIGHT - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_MERGE_POLICY_SEGMENTS_PER_TIER - Static variable in class org.elasticsearch.index.shard.MergePolicyConfig
-
- INDEX_METADATA_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- INDEX_NAME - Static variable in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Defaults
-
- INDEX_NAME - Static variable in class org.elasticsearch.index.query.GeoShapeQueryParser.DEFAULTS
-
- INDEX_OPTIMIZE_AUTOGENERATED_ID_SETTING - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
Setting to control auto generated ID optimizations.
- INDEX_OPTIONS_DOCS - Static variable in class org.elasticsearch.index.mapper.core.TypeParsers
-
- INDEX_OPTIONS_FREQS - Static variable in class org.elasticsearch.index.mapper.core.TypeParsers
-
- INDEX_OPTIONS_OFFSETS - Static variable in class org.elasticsearch.index.mapper.core.TypeParsers
-
- INDEX_OPTIONS_POSITIONS - Static variable in class org.elasticsearch.index.mapper.core.TypeParsers
-
- INDEX_QUERY_CACHE - Static variable in class org.elasticsearch.index.cache.IndexCacheModule
-
- INDEX_READ_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- INDEX_READ_ONLY_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- INDEX_RECOVERY_INITIAL_SHARDS - Static variable in class org.elasticsearch.gateway.PrimaryShardAllocator
-
- INDEX_REFRESH_INTERVAL - Static variable in class org.elasticsearch.index.shard.IndexShard
-
- INDEX_ROUTING_ALLOCATION_DISABLE_ALLOCATION - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
-
Deprecated.
- INDEX_ROUTING_ALLOCATION_DISABLE_NEW_ALLOCATION - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
-
Deprecated.
- INDEX_ROUTING_ALLOCATION_DISABLE_REPLICA_ALLOCATION - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
-
Deprecated.
- INDEX_ROUTING_ALLOCATION_ENABLE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
-
- INDEX_ROUTING_EXCLUDE_GROUP - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
-
- INDEX_ROUTING_INCLUDE_GROUP - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
-
- INDEX_ROUTING_REBALANCE_ENABLE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
-
- INDEX_ROUTING_REQUIRE_GROUP - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
-
- INDEX_SEARCH_SLOWLOG_LEVEL - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_REFORMAT - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_DEBUG - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_INFO - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_TRACE - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_WARN - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_DEBUG - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_INFO - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_TRACE - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_WARN - Static variable in class org.elasticsearch.index.search.stats.SearchSlowLog
-
- INDEX_SETTING_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- INDEX_STORE_DELETED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
-
- INDEX_STORE_STATS_REFRESH_INTERVAL - Static variable in class org.elasticsearch.index.store.Store
-
- INDEX_STORE_THROTTLE_MAX_BYTES_PER_SEC - Static variable in class org.elasticsearch.index.store.IndexStore
-
- INDEX_STORE_THROTTLE_TYPE - Static variable in class org.elasticsearch.index.store.IndexStore
-
- INDEX_TIME_SETTINGS - Static variable in class org.elasticsearch.cluster.metadata.MetaDataIndexUpgradeService
-
All known time settings for an index.
- INDEX_TOTAL_SHARDS_PER_NODE - 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_BUFFER_SIZE - Static variable in class org.elasticsearch.index.translog.TranslogConfig
-
- INDEX_TRANSLOG_DISABLE_FLUSH - Static variable in class org.elasticsearch.index.translog.TranslogService
-
- INDEX_TRANSLOG_DURABILITY - Static variable in class org.elasticsearch.index.translog.TranslogConfig
-
- INDEX_TRANSLOG_FLUSH_INTERVAL - Static variable in class org.elasticsearch.index.translog.TranslogService
-
- INDEX_TRANSLOG_FLUSH_THRESHOLD_OPS - Static variable in class org.elasticsearch.index.translog.TranslogService
-
- INDEX_TRANSLOG_FLUSH_THRESHOLD_PERIOD - Static variable in class org.elasticsearch.index.translog.TranslogService
-
- INDEX_TRANSLOG_FLUSH_THRESHOLD_SIZE - Static variable in class org.elasticsearch.index.translog.TranslogService
-
- INDEX_TRANSLOG_FS_TYPE - Static variable in class org.elasticsearch.index.translog.TranslogConfig
-
- INDEX_TRANSLOG_SYNC_INTERVAL - Static variable in class org.elasticsearch.index.translog.TranslogConfig
-
- INDEX_TTL_DISABLE_PURGE - Static variable in class org.elasticsearch.indices.ttl.IndicesTTLService
-
- INDEX_UUID_NA_VALUE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- INDEX_VERSION_MAP_SIZE - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
The maximum size the version map should grow to before issuing a refresh.
- INDEX_WARMER_ENABLED - Static variable in class org.elasticsearch.indices.IndicesWarmer
-
- INDEX_WRITE_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- IndexAction - Class in org.elasticsearch.action.index
-
- indexAliasesRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates an index aliases request allowing to add and remove aliases.
- IndexAliasesService - Class in org.elasticsearch.index.aliases
-
- IndexAliasesService(Index, IndexSettingsService, IndexQueryParserService) - Constructor for class org.elasticsearch.index.aliases.IndexAliasesService
-
- IndexAliasesServiceModule - Class in org.elasticsearch.index.aliases
-
- IndexAliasesServiceModule() - Constructor for class org.elasticsearch.index.aliases.IndexAliasesServiceModule
-
- IndexAlreadyExistsException - Exception in org.elasticsearch.indices
-
- IndexAlreadyExistsException(Index) - Constructor for exception org.elasticsearch.indices.IndexAlreadyExistsException
-
- IndexAlreadyExistsException(Index, String) - Constructor for exception org.elasticsearch.indices.IndexAlreadyExistsException
-
- IndexAlreadyExistsException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexAlreadyExistsException
-
- 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(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- indexAnalyzer() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- indexAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService
-
- 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.admin.indices.flush.TransportShardFlushAction
-
- indexBlockLevel() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
-
- indexBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Index level block to check before request execution
- indexBoost(String, float) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the boost a specific index will receive when the query is executeed
against it.
- IndexCache - Class in org.elasticsearch.index.cache
-
- IndexCache(Index, IndexSettingsService, QueryCache, BitsetFilterCache) - Constructor for class org.elasticsearch.index.cache.IndexCache
-
- indexCache - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
-
- IndexCacheableQuery - Class in org.elasticsearch.common.lucene
-
Base implementation for a query which is cacheable at the index level but
not the segment level as usually expected.
- IndexCacheableQuery() - Constructor for class org.elasticsearch.common.lucene.IndexCacheableQuery
-
- IndexCacheModule - Class in org.elasticsearch.index.cache
-
- IndexCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.IndexCacheModule
-
- IndexClosedException - Exception in org.elasticsearch.indices
-
Exception indicating that one or more requested indices are closed.
- IndexClosedException(Index) - Constructor for exception org.elasticsearch.indices.IndexClosedException
-
- IndexClosedException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexClosedException
-
- IndexCommitDelegate - Class in org.elasticsearch.common.lucene
-
A simple delegate that delegates all IndexCommit
calls to a delegated
IndexCommit
.
- IndexCommitDelegate(IndexCommit) - Constructor for class org.elasticsearch.common.lucene.IndexCommitDelegate
-
Constructs a new IndexCommit
that will delegate all calls
to the provided delegate.
- IndexComponent - Interface in org.elasticsearch.index
-
- IndexConstraint - Class in org.elasticsearch.action.fieldstats
-
- IndexConstraint(String, IndexConstraint.Property, IndexConstraint.Comparison, String) - Constructor for class org.elasticsearch.action.fieldstats.IndexConstraint
-
- IndexConstraint(String, IndexConstraint.Property, IndexConstraint.Comparison, String, String) - Constructor for class org.elasticsearch.action.fieldstats.IndexConstraint
-
- IndexConstraint.Comparison - Enum in org.elasticsearch.action.fieldstats
-
- IndexConstraint.Property - Enum in org.elasticsearch.action.fieldstats
-
- 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.
- indexCreatedBefore2x - 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(Index, Throwable) - Constructor for exception org.elasticsearch.indices.IndexCreationException
-
- IndexCreationException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexCreationException
-
- IndexDynamicSettings - Annotation Type in org.elasticsearch.index.settings
-
- INDEXED_SUFFIX - Static variable in class org.elasticsearch.script.ScriptParameterParser
-
- IndexedGeoBoundingBoxQuery - Class in org.elasticsearch.index.search.geo
-
- IndexedGeoBoundingBoxQuery() - Constructor for class org.elasticsearch.index.search.geo.IndexedGeoBoundingBoxQuery
-
- indexedShapeIndex(String) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Sets the name of the index where the indexed Shape can be found
- 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
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.BooleanFieldType
-
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.DoubleFieldType
-
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.LongFieldType
-
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the indexed value used to construct search "values".
- 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
-
- IndexFailedEngineException(ShardId, String, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.IndexFailedEngineException
-
- IndexFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.IndexFailedEngineException
-
- indexFailures(String) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- IndexField - Class in org.elasticsearch.search.lookup
-
Script interface to all information regarding a field.
- IndexField(String, LeafIndexLookup) - Constructor for class org.elasticsearch.search.lookup.IndexField
-
- IndexFieldData<FD extends AtomicFieldData> - Interface in org.elasticsearch.index.fielddata
-
- indexFieldData() - Method in class org.elasticsearch.search.aggregations.support.FieldContext
-
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
-
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
-
- 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.Builder - Interface in org.elasticsearch.index.fielddata
-
- IndexFieldData.CommonSettings - Class in org.elasticsearch.index.fielddata
-
- IndexFieldData.CommonSettings.MemoryStorageFormat - Enum 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
-
- IndexFieldDataModule - Class in org.elasticsearch.index.fielddata
-
- IndexFieldDataModule(Settings) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataModule
-
- IndexFieldDataService - Class in org.elasticsearch.index.fielddata
-
- IndexFieldDataService(Index, IndexSettingsService, IndicesFieldDataCache, CircuitBreakerService, MapperService) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataService
-
- indexFieldDataService() - Method in class org.elasticsearch.index.shard.IndexShard
-
- IndexFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- IndexFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
- IndexFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- IndexFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- IndexFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- IndexFieldTerm - Class in org.elasticsearch.search.lookup
-
Holds all information on a particular term in a field.
- IndexFieldTerm(String, String, LeafIndexLookup, int) - Constructor for class org.elasticsearch.search.lookup.IndexFieldTerm
-
- indexFieldTerm - Variable in class org.elasticsearch.search.lookup.PositionIterator
-
- indexFiles() - Method in class org.elasticsearch.index.shard.CommitPoint
-
- 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
-
- indexGet(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- indexGet(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- IndexIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- IndexIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
-
- indexing - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- indexing(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- indexing() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- indexingBufferSize() - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
-
returns the current budget for the total amount of indexing buffers of
active shards on this node
- IndexingMemoryController - Class in org.elasticsearch.indices.memory
-
- IndexingMemoryController(Settings, ThreadPool, IndicesService) - Constructor for class org.elasticsearch.indices.memory.IndexingMemoryController
-
- IndexingMemoryController(Settings, ThreadPool, IndicesService, long) - Constructor for class org.elasticsearch.indices.memory.IndexingMemoryController
-
- IndexingOperation(Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- IndexingOperation(Term, ParsedDocument) - Constructor for class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- IndexingOperationListener - Class in org.elasticsearch.index.indexing
-
An indexing listener for indexing, delete, events.
- IndexingOperationListener() - Constructor for class org.elasticsearch.index.indexing.IndexingOperationListener
-
- indexingService() - Method in class org.elasticsearch.index.shard.IndexShard
-
- IndexingSlowLog - Class in org.elasticsearch.index.indexing
-
- IndexingStats - Class in org.elasticsearch.index.indexing
-
- IndexingStats() - Constructor for class org.elasticsearch.index.indexing.IndexingStats
-
- IndexingStats(IndexingStats.Stats, Map<String, IndexingStats.Stats>) - Constructor for class org.elasticsearch.index.indexing.IndexingStats
-
- indexingStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
-
- IndexingStats.Stats - Class in org.elasticsearch.index.indexing
-
- indexInput(IndexInput) - Method in interface org.elasticsearch.common.compress.Compressor
-
- indexInput(IndexInput) - Method in class org.elasticsearch.common.compress.deflate.DeflateCompressor
-
- indexInput(IndexInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
-
Deprecated.
- 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
-
- indexLookup() - Method in class org.elasticsearch.script.AbstractSearchScript
-
Allows to access statistics on terms and fields.
- IndexLookup - Class in org.elasticsearch.search.lookup
-
- IndexLookup(ImmutableMap.Builder<String, Object>) - Constructor for class org.elasticsearch.search.lookup.IndexLookup
-
- indexLookup() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
-
- indexMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- IndexMetaData - Class in org.elasticsearch.cluster.metadata
-
- IndexMetaData.Builder - Class in org.elasticsearch.cluster.metadata
-
- IndexMetaData.Custom - Interface in org.elasticsearch.cluster.metadata
-
- IndexMetaData.State - Enum in org.elasticsearch.cluster.metadata
-
- indexMetaDataChanged(IndexMetaData) - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the
IndexMetaData
for a given index
has changed between the previous cluster state and the new cluster state.
- IndexMetaWriteInfo(IndexMetaData, IndexMetaData, String) - Constructor for class org.elasticsearch.gateway.GatewayMetaState.IndexMetaWriteInfo
-
- IndexModule - Class in org.elasticsearch.index
-
- IndexModule(Settings) - Constructor for class org.elasticsearch.index.IndexModule
-
- indexModules(Settings) - Method in class org.elasticsearch.plugins.Plugin
-
Per index modules.
- indexModules(Settings) - Method in class org.elasticsearch.plugins.PluginsService
-
- indexName - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- indexName(String) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- indexName - Variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
-
- indexName() - Method in class org.elasticsearch.index.mapper.MappedFieldType.Names
-
The indexed name of the field.
- indexName(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
- 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
-
- IndexNameModule - Class in org.elasticsearch.index
-
- IndexNameModule(Index) - Constructor for class org.elasticsearch.index.IndexNameModule
-
- IndexNotFoundException - Exception in org.elasticsearch.index
-
- IndexNotFoundException(String) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
-
- IndexNotFoundException(String, Throwable) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
-
- IndexNotFoundException(StreamInput) - 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
-
- 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
-
- IndexOutputOutputStream(IndexOutput) - Constructor for class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
-
- IndexParentChildFieldData - Interface in org.elasticsearch.index.fielddata
-
- indexPaths(Index) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all index paths.
- 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.index
-
The index-level query cache.
- IndexQueryCache(Index, IndexSettingsService, IndicesQueryCache) - Constructor for class org.elasticsearch.index.cache.query.index.IndexQueryCache
-
- IndexQueryParserService - Class in org.elasticsearch.index.query
-
- IndexQueryParserService(Index, IndexSettingsService, IndicesQueriesRegistry, ScriptService, AnalysisService, MapperService, IndexCache, IndexFieldDataService, BitsetFilterCache, SimilarityService) - Constructor for class org.elasticsearch.index.query.IndexQueryParserService
-
- indexQueryParserService() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- 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 - 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(ActionRequest) - Constructor for class org.elasticsearch.action.index.IndexRequest
-
Creates an index request caused by some other request, which is provided as an
argument so that its headers and context can be copied to the new request
- IndexRequest(IndexRequest, ActionRequest) - Constructor for class org.elasticsearch.action.index.IndexRequest
-
Copy constructor that creates a new index request that is a copy of the one provided as an argument.
- 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.
- 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.OpType - Enum in org.elasticsearch.action.index
-
Operation type controls if the type of the index operation.
- 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(String, String, String, long, boolean) - Constructor for class org.elasticsearch.action.index.IndexResponse
-
- indexRouting() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the index routing value associated with the alias
- 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() - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- indexRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- indexRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- indexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- IndexRoutingTable - Class in org.elasticsearch.cluster.routing
-
- indexRoutingTable(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
-
- 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.
- IndexSearcherWrapper - Interface in org.elasticsearch.index.engine
-
Extension point to add custom functionality at request time to the
DirectoryReader
and
IndexSearcher
managed by the
Engine
.
- IndexSearcherWrappingService - Class in org.elasticsearch.index.engine
-
- IndexSearcherWrappingService(Set<IndexSearcherWrapper>) - Constructor for class org.elasticsearch.index.engine.IndexSearcherWrappingService
-
- IndexSegments - Class in org.elasticsearch.action.admin.indices.segments
-
- IndexService - Class in org.elasticsearch.index
-
- IndexService(Injector, Index, NodeEnvironment, AnalysisService, MapperService, IndexQueryParserService, SimilarityService, IndexAliasesService, IndexCache, IndexSettingsService, IndexFieldDataService, BitsetFilterCache, IndicesService) - Constructor for class org.elasticsearch.index.IndexService
-
- indexService() - Method in class org.elasticsearch.index.shard.IndexShard
-
- indexService(String) - Method in class org.elasticsearch.indices.IndicesService
-
Returns an IndexService for the specified index if exists otherwise returns null
.
- indexService() - Method in class org.elasticsearch.percolator.PercolateContext
-
- indexServices() - Method in class org.elasticsearch.plugins.Plugin
-
Per index services that will be automatically closed.
- indexServices() - Method in class org.elasticsearch.plugins.PluginsService
-
- indexServiceSafe(String) - Method in class org.elasticsearch.indices.IndicesService
-
- 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(String) - 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() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns settings that should be added/changed in all restored indices
- indexSettings - Variable in class org.elasticsearch.index.AbstractIndexComponent
-
- indexSettings() - Method in class org.elasticsearch.index.AbstractIndexComponent
-
- indexSettings() - Method in class org.elasticsearch.index.IndexService
-
- 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 - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
-
- indexSettings() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
-
- indexSettings() - Method in interface org.elasticsearch.index.shard.IndexShardComponent
-
- indexSettings() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns index settings that should be changed on restore
- IndexSettingsModule - Class in org.elasticsearch.index.settings
-
- IndexSettingsModule(Index, Settings) - Constructor for class org.elasticsearch.index.settings.IndexSettingsModule
-
- IndexSettingsService - Class in org.elasticsearch.index.settings
-
A holds to the latest, updated settings for an index.
- IndexSettingsService(Index, Settings) - Constructor for class org.elasticsearch.index.settings.IndexSettingsService
-
- IndexSettingsService.Listener - Interface in org.elasticsearch.index.settings
-
- IndexShard - Class in org.elasticsearch.index.shard
-
- IndexShard(ShardId, IndexSettingsService, IndicesLifecycle, Store, StoreRecoveryService, ThreadPool, MapperService, IndexQueryParserService, IndexCache, IndexAliasesService, IndicesQueryCache, ShardPercolateService, CodecService, ShardTermVectorsService, IndexFieldDataService, IndexService, IndicesWarmer, SnapshotDeletionPolicy, SimilarityService, EngineFactory, ClusterService, ShardPath, BigArrays, IndexSearcherWrappingService, IndexingMemoryController) - Constructor for class org.elasticsearch.index.shard.IndexShard
-
- indexShard() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- indexShard() - Method in class org.elasticsearch.percolator.PercolateContext
-
- indexShard() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- indexShard() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- indexShard() - Method in class org.elasticsearch.search.internal.SearchContext
-
- IndexShardAlreadyExistsException - Exception in org.elasticsearch.index
-
- IndexShardAlreadyExistsException(String) - Constructor for exception org.elasticsearch.index.IndexShardAlreadyExistsException
-
- IndexShardAlreadyExistsException(StreamInput) - Constructor for exception org.elasticsearch.index.IndexShardAlreadyExistsException
-
- IndexShardClosedException - Exception in org.elasticsearch.index.shard
-
- IndexShardClosedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
-
- IndexShardClosedException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
-
- IndexShardClosedException(ShardId, String) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
-
- IndexShardClosedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
-
- IndexShardComponent - Interface in org.elasticsearch.index.shard
-
- IndexShardModule - Class in org.elasticsearch.index.shard
-
The IndexShardModule
module is responsible for binding the correct
shard id, index shard, engine factory, and warming service for a newly
created shard.
- IndexShardModule(ShardId, boolean, Settings) - Constructor for class org.elasticsearch.index.shard.IndexShardModule
-
- IndexShardNotRecoveringException - Exception in org.elasticsearch.index.shard
-
- IndexShardNotRecoveringException(ShardId, IndexShardState) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotRecoveringException
-
- IndexShardNotRecoveringException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotRecoveringException
-
- IndexShardNotStartedException - Exception in org.elasticsearch.index.shard
-
- IndexShardNotStartedException(ShardId, IndexShardState) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotStartedException
-
- IndexShardNotStartedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotStartedException
-
- IndexShardRecoveringException - Exception in org.elasticsearch.index.shard
-
- IndexShardRecoveringException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveringException
-
- IndexShardRecoveringException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveringException
-
- IndexShardRecoveryException - Exception in org.elasticsearch.index.shard
-
- IndexShardRecoveryException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveryException
-
- IndexShardRecoveryException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveryException
-
- IndexShardRelocatedException - Exception in org.elasticsearch.index.shard
-
- IndexShardRelocatedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
-
- IndexShardRelocatedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
-
- IndexShardRepository - Interface in org.elasticsearch.index.snapshots
-
Shard-level snapshot repository
- indexShardRepository(String) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Returns registered index shard repository
- indexShardRestoreCompleted(SnapshotId, ShardId) - Method in class org.elasticsearch.snapshots.RestoreService
-
This method is used by
StoreRecoveryService
to notify
RestoreService
about shard restore completion.
- IndexShardRestoreException - Exception in org.elasticsearch.index.snapshots
-
Generic shard restore exception
- IndexShardRestoreException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
-
- IndexShardRestoreException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
-
- IndexShardRestoreException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
-
- IndexShardRestoreFailedException - Exception in org.elasticsearch.index.snapshots
-
Thrown when restore of a shard fails
- IndexShardRestoreFailedException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
-
- IndexShardRestoreFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
-
- IndexShardRestoreFailedException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
-
- IndexShardRoutingTable - Class in org.elasticsearch.cluster.routing
-
- IndexShardRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
-
- indexShards(ClusterState, String, 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(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
-
- IndexShardSnapshotException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
-
- IndexShardSnapshotException(StreamInput) - 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(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
-
- IndexShardSnapshotFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
-
- IndexShardSnapshotFailedException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
-
- IndexShardSnapshotStatus - Class in org.elasticsearch.index.snapshots
-
Represent shard snapshot status
- IndexShardSnapshotStatus() - Constructor for class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
- IndexShardSnapshotStatus.Stage - Enum in org.elasticsearch.index.snapshots
-
Snapshot stage
- IndexShardStartedException - Exception in org.elasticsearch.index.shard
-
- IndexShardStartedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardStartedException
-
- IndexShardStartedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardStartedException
-
- IndexShardState - Enum in org.elasticsearch.index.shard
-
- indexShardStateChanged(IndexShard, IndexShardState, IndexShardState, String) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
- indexShardStateChanged(IndexShard, IndexShardState, String) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- 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
-
- IndexStats - Class in org.elasticsearch.action.admin.indices.stats
-
- IndexStats(String, ShardStats[]) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexStats
-
- indexStore - Variable in class org.elasticsearch.index.store.FsDirectoryService
-
- IndexStore - Class in org.elasticsearch.index.store
-
- IndexStore(Index, IndexSettingsService, IndicesStore) - Constructor for class org.elasticsearch.index.store.IndexStore
-
- IndexStoreModule - Class in org.elasticsearch.index.store
-
- IndexStoreModule(Settings) - Constructor for class org.elasticsearch.index.store.IndexStoreModule
-
- IndexStoreModule.Type - Enum in org.elasticsearch.index.store
-
- IndexTemplateAlreadyExistsException - Exception in org.elasticsearch.indices
-
- IndexTemplateAlreadyExistsException(String) - Constructor for exception org.elasticsearch.indices.IndexTemplateAlreadyExistsException
-
- IndexTemplateAlreadyExistsException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexTemplateAlreadyExistsException
-
- IndexTemplateFilter - Interface in org.elasticsearch.cluster.metadata
-
Enables filtering the index templates that will be applied for an index, per create index request.
- IndexTemplateFilter.Compound - Class in org.elasticsearch.cluster.metadata
-
- IndexTemplateMetaData - Class in org.elasticsearch.cluster.metadata
-
- IndexTemplateMetaData(String, int, String, Settings, ImmutableOpenMap<String, CompressedXContent>, ImmutableOpenMap<String, AliasMetaData>, ImmutableOpenMap<String, IndexMetaData.Custom>) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- IndexTemplateMetaData.Builder - Class in org.elasticsearch.cluster.metadata
-
- IndexTemplateMissingException - Exception in org.elasticsearch.indices
-
- IndexTemplateMissingException(String) - Constructor for exception org.elasticsearch.indices.IndexTemplateMissingException
-
- IndexTemplateMissingException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexTemplateMissingException
-
- indexText() - Method in class org.elasticsearch.search.SearchShardTarget
-
- IndexThrottle() - Constructor for class org.elasticsearch.index.engine.Engine.IndexThrottle
-
- indexTokenizeOptionToString(boolean, boolean) - Static method in class org.elasticsearch.index.mapper.FieldMapper
-
- IndexUpgradeStatus - Class in org.elasticsearch.action.admin.indices.upgrade.get
-
- indexUUID() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
-
- indexUUID() - Method in class org.elasticsearch.index.IndexService
-
- indexUUID - Variable in class org.elasticsearch.index.shard.ShardStateMetaData
-
- indexVersion() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns index version
- indexVersion(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Sets index version
- indexVersion() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns index version
- indexVersionCreated() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
-
- indexVersionCreated() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- IndexWarmerMissingException - Exception in org.elasticsearch.search.warmer
-
- IndexWarmerMissingException(String...) - Constructor for exception org.elasticsearch.search.warmer.IndexWarmerMissingException
-
- IndexWarmerMissingException(StreamInput) - Constructor for exception org.elasticsearch.search.warmer.IndexWarmerMissingException
-
- IndexWarmersMetaData - Class in org.elasticsearch.search.warmer
-
- IndexWarmersMetaData(IndexWarmersMetaData.Entry...) - Constructor for class org.elasticsearch.search.warmer.IndexWarmersMetaData
-
- IndexWarmersMetaData.Entry - Class in org.elasticsearch.search.warmer
-
- indexWriterRAMBytesUsed() - Method in class org.elasticsearch.index.engine.Engine
-
How much heap Lucene's IndexWriter is using
- indexWriterRAMBytesUsed() - Method in class org.elasticsearch.index.engine.InternalEngine
-
- indexWriterRAMBytesUsed() - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- indices() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
- indices(String[]) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
- indices() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
- indices(CommonStatsFlags) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
- 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.shards.ClusterSearchShardsRequest
-
Sets the indices the search will be executed on.
- indices() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
The indices
- 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(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() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns 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(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() - 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(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() - 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() - 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(String...) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Sets the indices to be closed
- indices() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
- 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(String[]) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
-
- indices() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
-
- indices(String[]) - 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(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
- indices() - 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() - 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(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() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
-
- indices() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
- 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() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
- indices() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequest
-
Sets the indices this put mapping operation will execute on.
- indices() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequest
-
The indices the mappings will be put.
- indices() - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
- indices(String[]) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
- indices() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
-
- indices() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- indices() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
- indices() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
- indices() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- indices() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- indices() - Method in interface org.elasticsearch.action.IndicesRequest
-
Returns the array of indices that the action relates to
- indices(String[]) - Method in interface org.elasticsearch.action.IndicesRequest.Replaceable
-
- indices() - Method in class org.elasticsearch.action.OriginalIndices
-
- indices() - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
- indices(String...) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
Sets the default indices for any percolate request that doesn't have indices defined.
- indices() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Request
-
- indices(String...) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the indices the search will be executed on.
- indices() - Method in class org.elasticsearch.action.search.SearchRequest
-
The indices
- indices - Variable in class org.elasticsearch.action.support.broadcast.BroadcastRequest
-
- indices() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
-
- indices(String...) - 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(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
-
- 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(String[]) - Method in class org.elasticsearch.cluster.ack.IndicesClusterStateUpdateRequest
-
Sets 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(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
- indices(ImmutableOpenMap<String, IndexMetaData>) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- 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.search.action.SearchServiceTransportAction.SearchFreeContextRequest
-
- 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.RestoreService.RestoreRequest
-
Return the list of indices to be restored
- indices() - Method in class org.elasticsearch.snapshots.Snapshot
-
Returns indices that were included into this snapshot
- indices() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns indices that were included into this snapshot
- indices(String[]) - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Sets the list of indices to be snapshotted
- indices() - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Returns the list of indices to be snapshotted
- INDICES_CACHE_QUERY_CONCURRENCY_LEVEL - Static variable in class org.elasticsearch.indices.cache.request.IndicesRequestCache
-
- INDICES_CACHE_QUERY_COUNT - Static variable in class org.elasticsearch.indices.cache.query.IndicesQueryCache
-
- INDICES_CACHE_QUERY_EXPIRE - Static variable in class org.elasticsearch.indices.cache.request.IndicesRequestCache
-
- INDICES_CACHE_QUERY_SIZE - Static variable in class org.elasticsearch.indices.cache.query.IndicesQueryCache
-
- INDICES_CACHE_QUERY_SIZE - Static variable in class org.elasticsearch.indices.cache.request.IndicesRequestCache
-
- INDICES_CACHE_REQUEST_CLEAN_INTERVAL - Static variable in class org.elasticsearch.indices.cache.request.IndicesRequestCache
-
- 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 - Static variable in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
-
- INDICES_OPTIONS - Static variable in class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
- INDICES_RECOVERY_ACTIVITY_TIMEOUT - 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_COMPRESS - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
- INDICES_RECOVERY_CONCURRENT_SMALL_FILE_STREAMS - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
- INDICES_RECOVERY_CONCURRENT_STREAMS - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
- INDICES_RECOVERY_FILE_CHUNK_SIZE - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
- INDICES_RECOVERY_INTERNAL_ACTION_TIMEOUT - 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 - 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 - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
- INDICES_RECOVERY_MAX_SIZE_PER_SEC - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
Deprecated.
- INDICES_RECOVERY_RETRY_DELAY_NETWORK - 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 - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
how long to wait before retrying after issues cause by cluster state syncing between nodes
i.e., local node is not yet known on remote node, remote shard not yet started etc.
- INDICES_RECOVERY_TRANSLOG_OPS - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
- INDICES_RECOVERY_TRANSLOG_SIZE - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
- 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
-
- INDICES_STORE_THROTTLE_MAX_BYTES_PER_SEC - Static variable in class org.elasticsearch.indices.store.IndicesStore
-
- INDICES_STORE_THROTTLE_TYPE - Static variable in class org.elasticsearch.indices.store.IndicesStore
-
- INDICES_TTL_INTERVAL - Static variable in class org.elasticsearch.indices.ttl.IndicesTTLService
-
- 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
- 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
-
- IndicesAliasesRequestBuilder - Class in org.elasticsearch.action.admin.indices.alias
-
- IndicesAliasesRequestBuilder(ElasticsearchClient, IndicesAliasesAction) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
- IndicesAliasesResponse - Class in org.elasticsearch.action.admin.indices.alias
-
A response for a add/remove alias action.
- IndicesAnalysisService - Class in org.elasticsearch.indices.analysis
-
A node level registry of analyzers, to be reused by different indices which use default analyzers.
- IndicesAnalysisService() - Constructor for class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- IndicesAnalysisService(Settings) - Constructor for class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- indicesBlockedException(ClusterBlockLevel, String[]) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
- IndicesBoostParseElement - Class in org.elasticsearch.search.query
-
{
indicesBoost : {
"index1" : 1.4,
"index2" : 1.5
}
}
- IndicesBoostParseElement() - Constructor for class org.elasticsearch.search.query.IndicesBoostParseElement
-
- IndicesClusterStateService - Class in org.elasticsearch.indices.cluster
-
- IndicesClusterStateService(Settings, IndicesService, ClusterService, ThreadPool, RecoveryTarget, ShardStateAction, NodeIndexDeletedAction, NodeMappingRefreshAction) - Constructor for class org.elasticsearch.indices.cluster.IndicesClusterStateService
-
- 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 - Class in org.elasticsearch.action.admin.indices.exists.indices
-
- IndicesExistsRequest() - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
-
- IndicesExistsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
-
- indicesExistsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates an indices exists request.
- 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
-
- indicesFailures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- IndicesFieldDataCache - Class in org.elasticsearch.indices.fielddata.cache
-
- IndicesFieldDataCache(Settings, IndicesFieldDataCacheListener, ThreadPool) - Constructor for class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
-
- IndicesFieldDataCache.FieldDataCacheCleaner - Class in org.elasticsearch.indices.fielddata.cache
-
FieldDataCacheCleaner is a scheduled Runnable used to clean a Guava cache
periodically.
- IndicesFieldDataCache.FieldDataWeigher - Class in org.elasticsearch.indices.fielddata.cache
-
- IndicesFieldDataCache.Key - Class in org.elasticsearch.indices.fielddata.cache
-
- IndicesFieldDataCacheListener - Class in org.elasticsearch.indices.fielddata.cache
-
A
IndexFieldDataCache.Listener
implementation that updates indices (node) level statistics / service about
field data entries being loaded and unloaded.
- IndicesFieldDataCacheListener(CircuitBreakerService) - Constructor for class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCacheListener
-
- indicesLevelRequest - Variable in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
-
- indicesLifecycle() - Method in class org.elasticsearch.index.IndexService
-
- IndicesLifecycle - Interface in org.elasticsearch.indices
-
A global component allowing to register for lifecycle of an index (create/closed) and
an index shard (created/closed).
- indicesLifecycle() - Method in class org.elasticsearch.indices.IndicesService
-
- IndicesLifecycle.Listener - Class in org.elasticsearch.indices
-
A listener for index and index shard lifecycle events (create/closed).
- IndicesModule - Class in org.elasticsearch.indices
-
Configures classes and services that are shared by indices on each node.
- IndicesModule() - 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(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(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(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(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() - 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(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() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
-
- indicesOptions(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(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(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
- 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(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(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() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
- 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() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequest
-
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
- indicesOptions() - Method in interface org.elasticsearch.action.DocumentRequest
-
Get the options for this request
- indicesOptions() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- indicesOptions() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- 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.percolate.MultiPercolateRequest
-
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
Sets the
IndicesOptions
for all percolate request that don't have this set.
- indicesOptions() - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.search.SearchRequest
-
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.SearchRequest
-
- indicesOptions() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
-
- indicesOptions(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 - 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(IndicesOptions) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
-
- 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.search.action.SearchServiceTransportAction.SearchFreeContextRequest
-
- 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() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns indices option flags
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Sets the indices options
- indicesOptions() - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Returns indices options
- indicesPath - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
-
- IndicesQueriesRegistry - Class in org.elasticsearch.indices.query
-
- IndicesQueriesRegistry(Settings, Set<QueryParser>) - Constructor for class org.elasticsearch.indices.query.IndicesQueriesRegistry
-
- indicesQuery(QueryBuilder, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that will execute the wrapped query only for the specified indices, and "match_all" when
it does not match those indices.
- IndicesQueryBuilder - Class in org.elasticsearch.index.query
-
A query that will execute the wrapped query only for the specified indices, and "match_all" when
it does not match those indices (by default).
- IndicesQueryBuilder(QueryBuilder, String...) - Constructor for class org.elasticsearch.index.query.IndicesQueryBuilder
-
- IndicesQueryCache - Class in org.elasticsearch.indices.cache.query
-
- IndicesQueryCache(Settings) - Constructor for class org.elasticsearch.indices.cache.query.IndicesQueryCache
-
- IndicesQueryParser - Class in org.elasticsearch.index.query
-
- IndicesQueryParser(ClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.index.query.IndicesQueryParser
-
- 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.cache.request
-
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).
- IndicesRequestCache(Settings, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.indices.cache.request.IndicesRequestCache
-
- IndicesRequestCache.Key - Class in org.elasticsearch.indices.cache.request
-
- IndicesRequestCache.Value - Class in org.elasticsearch.indices.cache.request
-
- indicesRouting(ImmutableMap<String, IndexRoutingTable>) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- indicesRouting() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- IndicesSegmentResponse - Class in org.elasticsearch.action.admin.indices.segments
-
- IndicesSegmentsAction - Class in org.elasticsearch.action.admin.indices.segments
-
- IndicesSegmentsRequest - Class in org.elasticsearch.action.admin.indices.segments
-
- IndicesSegmentsRequest() - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
-
- IndicesSegmentsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
-
- indicesSegmentsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
- 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, IndicesLifecycle, IndicesAnalysisService, Injector, NodeEnvironment) - Constructor for class org.elasticsearch.indices.IndicesService
-
- IndicesShardStoreRequestBuilder - Class in org.elasticsearch.action.admin.indices.shards
-
- 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
-
- IndicesShardStoresRequest - Class in org.elasticsearch.action.admin.indices.shards
-
- IndicesShardStoresRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Create a request for shard stores info for indices
- IndicesShardStoresRequest() - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
- indicesShardStoresRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates an indices shard stores info request.
- IndicesShardStoresResponse - Class in org.elasticsearch.action.admin.indices.shards
-
- IndicesShardStoresResponse(ImmutableOpenMap<String, ImmutableOpenIntMap<List<IndicesShardStoresResponse.StoreStatus>>>, List<IndicesShardStoresResponse.Failure>) - 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.Allocation - 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 - Variable in class org.elasticsearch.index.store.IndexStore
-
- IndicesStore - Class in org.elasticsearch.indices.store
-
- IndicesStore(Settings, NodeSettingsService, IndicesService, ClusterService, TransportService) - Constructor for class org.elasticsearch.indices.store.IndicesStore
-
- IndicesStore.ShardActiveRequest - Class in org.elasticsearch.indices.store
-
- IndicesTTLService - Class in org.elasticsearch.indices.ttl
-
A node level service that delete expired docs on node primary shards.
- IndicesTTLService(Settings, ClusterService, IndicesService, NodeSettingsService, TransportBulkAction) - Constructor for class org.elasticsearch.indices.ttl.IndicesTTLService
-
- IndicesWarmer - Class in org.elasticsearch.indices
-
- IndicesWarmer(Settings, ThreadPool, ClusterService, IndicesService) - Constructor for class org.elasticsearch.indices.IndicesWarmer
-
- IndicesWarmer.Listener - Class in org.elasticsearch.indices
-
- IndicesWarmer.TerminationHandle - Interface in org.elasticsearch.indices
-
A handle on the execution of warm-up action.
- IndicesWarmer.WarmerContext - Class in org.elasticsearch.indices
-
- IndicNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory for IndicNormalizationFilter
- IndicNormalizationFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.IndicNormalizationFilterFactory
-
- IndonesianAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- IndonesianAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.IndonesianAnalyzerProvider
-
- InetSocketTransportAddress - Class in org.elasticsearch.common.transport
-
- InetSocketTransportAddress(StreamInput) - Constructor for class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- InetSocketTransportAddress(InetAddress, int) - Constructor for class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- InetSocketTransportAddress(InetSocketAddress) - Constructor for class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- InFlightOpsRequest() - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
-
- InFlightOpsRequest(ShardId) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
-
- info(String, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
-
Logs an INFO level message.
- info(String, Throwable, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
-
Logs an INFO level message.
- info(String, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- info(String, Throwable, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- info() - Method in class org.elasticsearch.http.HttpServer
-
- info() - Method in interface org.elasticsearch.http.HttpServerTransport
-
- info() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- 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.node.service.NodeService
-
- info(boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.node.service.NodeService
-
- info() - Method in class org.elasticsearch.plugins.PluginsService
-
Get information about plugins and modules
- info() - Method in class org.elasticsearch.threadpool.ThreadPool
-
- 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(String) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
-
- info(String, Throwable) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
-
- info() - Method in class org.elasticsearch.transport.TransportService
-
- INGEST_ATTR - Static variable in class org.elasticsearch.cluster.node.DiscoveryNode
-
- init() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
- init() - Method in interface org.elasticsearch.watcher.ResourceWatcher
-
- INIT_SCRIPT - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- INIT_SCRIPT_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- initCounter() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
-
- INITIAL_EVENTS_HELD - Static variable in class org.elasticsearch.http.netty.pipelining.HttpPipeliningHandler
-
- initialize(ShardRouting, String, long) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Moves a shard from unassigned to initialize state
- initialize(String, long, long) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
Initializes the current unassigned shard and moves it from the unassigned list.
- initialize(Injector) - Method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider2
-
At injector-creation time, we initialize the invocation handler.
- initialize() - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder.MapBinderProviderWithDependencies
-
- 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(BlobStore, BlobPath, ByteSizeValue, RateLimiter, RateLimiter, BlobStoreIndexShardRepository.RateLimiterListener, boolean) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
- initialize(Engine.Searcher, ParsedDocument) - Method in class org.elasticsearch.percolator.PercolateContext
-
- initialize(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
-
- initialize(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristic
-
- 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, RestoreSource, 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 a new empty index, as if it was created from an API.
- initializeAsRestore(IndexMetaData, RestoreSource) - 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.
- 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.
- initializeSnapshot(SnapshotId, List<String>, MetaData) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Starts snapshotting process
- initializeSnapshot(SnapshotId, List<String>, MetaData) - Method in interface org.elasticsearch.repositories.Repository
-
Starts snapshotting process
- initializing() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard is initializing (usually recovering either from peer shard
or from gateway).
- InitialStateDiscoveryListener - Interface in org.elasticsearch.discovery
-
A listener that should be called by the
Discovery
component
when the first valid initial cluster state has been submitted and processed by the cluster service.
- initialStateProcessed() - Method in interface org.elasticsearch.discovery.InitialStateDiscoveryListener
-
- initInjector(Injector) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
-
- initReader(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
-
- initScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
-
Set the init script.
- 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 - Interface in org.elasticsearch.common.inject
-
Builds the graphs of objects that make up your application.
- injector() - Method in class org.elasticsearch.index.IndexService
-
- injector() - Method in class org.elasticsearch.node.Node
-
- Injectors - Class in org.elasticsearch.common.inject
-
- Injectors() - Constructor for class org.elasticsearch.common.inject.Injectors
-
- InMemoryGeoBoundingBoxQuery - Class in org.elasticsearch.index.search.geo
-
- InMemoryGeoBoundingBoxQuery(GeoPoint, GeoPoint, IndexGeoPointFieldData) - Constructor for class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxQuery
-
- innerDocs(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
-
Get a DocIdSet
that matches the inner documents.
- innerExecute(String, CompletionSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggester
-
- innerExecute(String, PhraseSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
-
- innerExecute(String, T, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.Suggester
-
- innerExecute(String, TermSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.term.TermSuggester
-
- innerHit(QueryInnerHitBuilder) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
-
Sets inner hit definition in the scope of this query and reusing the defined type and query.
- innerHit(QueryInnerHitBuilder) - Method in class org.elasticsearch.index.query.HasParentQueryBuilder
-
Sets inner hit definition in the scope of this query and reusing the defined type and query.
- innerHit(QueryInnerHitBuilder) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Sets inner hit definition in the scope of this nested query and reusing the defined path and query.
- InnerHit() - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder.InnerHit
-
- innerHits() - Method in class org.elasticsearch.percolator.PercolateContext
-
- innerHits() - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.BaseInnerHits
-
- innerHits() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- innerHits() - Method in class org.elasticsearch.search.internal.SearchContext
-
- innerHitsBuilder() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
- InnerHitsBuilder - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsBuilder() - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder
-
- InnerHitsBuilder.InnerHit - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsContext - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsContext() - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsContext
-
- InnerHitsContext(Map<String, InnerHitsContext.BaseInnerHits>) - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsContext
-
- InnerHitsContext.BaseInnerHits - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsContext.NestedInnerHits - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsContext.ParentChildInnerHits - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsFetchSubPhase - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsFetchSubPhase(SortParseElement, FetchSourceParseElement, HighlighterParseElement, FieldDataFieldsParseElement, ScriptFieldsParseElement) - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsFetchSubPhase
-
- InnerHitsParseElement - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsParseElement(SortParseElement, FetchSourceParseElement, HighlighterParseElement, FieldDataFieldsParseElement, ScriptFieldsParseElement) - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsParseElement
-
- InnerHitsQueryParserHelper - Class in org.elasticsearch.index.query.support
-
- InnerHitsQueryParserHelper(SortParseElement, FetchSourceParseElement, HighlighterParseElement, ScriptFieldsParseElement, FieldDataFieldsParseElement) - Constructor for class org.elasticsearch.index.query.support.InnerHitsQueryParserHelper
-
- InnerHitsSubSearchContext - Class in org.elasticsearch.search.fetch.innerhits
-
- InnerHitsSubSearchContext(String, SubSearchContext) - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsSubSearchContext
-
- innerParse(XContentParser, SubPhaseContext, SearchContext) - Method in class org.elasticsearch.search.fetch.FetchSubPhaseParseElement
-
Implement the actual parsing here.
- innerParse(XContentParser, FieldDataFieldsContext, SearchContext) - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsParseElement
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
-
- innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
-
- InnerQuery(QueryParseContext, String...) - Constructor for class org.elasticsearch.index.query.support.XContentStructure.InnerQuery
-
- innerReadFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
-
- innerReadFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
-
- innerReadFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
-
- 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
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.QuerySourceBuilder
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.ElasticsearchException
-
Renders additional per exception information into the xcontent
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.index.query.QueryParsingException
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.RescoreBuilder.QueryRescorer
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.RescoreBuilder.Rescorer
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.search.SearchParseException
-
- 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.completion.CompletionSuggestionFuzzyBuilder
-
- 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.PhraseSuggestionBuilder.Laplace
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.LinearInterpolation
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.SmoothingModel
-
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.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.SuggestBuilder.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
-
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsPipelineAggregator
-
- 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.ExtendedStatsBucketPipelineAggregator
-
- innerWriteTo(StreamOutput, boolean) - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
-
- inOrder(boolean) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
- inPackage(Package) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches classes in the given package.
- input() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
-
- Input() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceParser.Input
-
- InputStream(InputStream) - Constructor for class org.elasticsearch.common.Base64.InputStream
-
- InputStream(InputStream, int) - Constructor for class org.elasticsearch.common.Base64.InputStream
-
- 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
-
- inRoot() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
-
- insert(String, T) - Method in class org.elasticsearch.common.path.PathTrie
-
- insert(String[], int, T) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
-
- insertElement(T[], T, int) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
- insertionOrder - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
-
- inspect() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
-
Inspects if the barrier is broken.
- 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 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.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.list.ListTasksAction
-
- 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.tasks.PendingClusterTasksAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateAction
-
- 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.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.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.admin.indices.warmer.delete.DeleteWarmerAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.bulk.BulkAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.count.CountAction
-
Deprecated.
- INSTANCE - Static variable in class org.elasticsearch.action.delete.DeleteAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.exists.ExistsAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.explain.ExplainAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.fieldstats.FieldStatsAction
-
- 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.indexedscripts.delete.DeleteIndexedScriptAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.percolate.MultiPercolateAction
-
- INSTANCE - Static variable in class org.elasticsearch.action.percolate.PercolateAction
-
- 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.suggest.SuggestAction
-
- 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(T) - Constructor for class org.elasticsearch.common.inject.internal.InternalFactory.Instance
-
- INSTANCE - Static variable in class org.elasticsearch.common.transport.DummyTransportAddress
-
- INSTANCE - Static variable in class org.elasticsearch.monitor.os.DummyOsInfo
-
- INSTANCE - Static variable in class org.elasticsearch.plugins.DummyPluginInfo
-
- INSTANCE - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
-
- INSTANCE - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
-
- INSTANCE - Static variable in class org.elasticsearch.search.rescore.QueryRescorer
-
- instance() - Static method in class org.elasticsearch.tasks.LoggingTaskListener
-
Get the instance of LoggingActionListener cast appropriately.
- 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(Injector, Key<T>, Object, InternalFactory<? extends T>, Set<InjectionPoint>, T) - Constructor for class org.elasticsearch.common.inject.internal.InstanceBindingImpl
-
- InstanceBindingImpl(Object, Key<T>, Scoping, Set<InjectionPoint>, T) - Constructor for class org.elasticsearch.common.inject.internal.InstanceBindingImpl
-
- InstanceMap(String, Class<K>, Class<V>, Class<?>...) - Constructor for class org.elasticsearch.common.util.ExtensionPoint.InstanceMap
-
- InstanceShardOperationRequest<T extends InstanceShardOperationRequest> - 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.
- INT_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.BigArrays
-
- IntArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of integer values.
- INTEGER - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- Integer() - Constructor for class org.elasticsearch.common.collect.HppcMaps.Object.Integer
-
- INTEGER_GTE_2 - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- integerField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- IntegerFieldMapper - Class in org.elasticsearch.index.mapper.core
-
- IntegerFieldMapper(String, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper
-
- IntegerFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
-
- IntegerFieldMapper.CustomIntegerNumericField - Class in org.elasticsearch.index.mapper.core
-
- IntegerFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
-
- IntegerFieldMapper.IntegerFieldType - Class in org.elasticsearch.index.mapper.core
-
- IntegerFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
-
- IntegerFieldType() - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- IntegerFieldType(IntegerFieldMapper.IntegerFieldType) - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- INTERNAL_CLUSTER_INFO_TIMEOUT - Static variable in class org.elasticsearch.cluster.InternalClusterInfoService
-
- INTERNAL_CLUSTER_INFO_UPDATE_INTERVAL - Static variable in class org.elasticsearch.cluster.InternalClusterInfoService
-
- internalActionLongTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- internalActionTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- internalAddListener(ActionListener<T>) - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
-
- InternalAggregation - Class in org.elasticsearch.search.aggregations
-
- InternalAggregation() - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation
-
Constructs an un initialized addAggregation (used for serialization)
- InternalAggregation(String, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation
-
Constructs an get with a given name.
- InternalAggregation.CommonFields - Class in org.elasticsearch.search.aggregations
-
Common xcontent fields that are shared among addAggregation
- InternalAggregation.ReduceContext - Class in org.elasticsearch.search.aggregations
-
- InternalAggregation.Type - Class in org.elasticsearch.search.aggregations
-
The aggregation type that holds all the string types that are associated with an aggregation:
name - used as the parser type
stream - used as the stream type
- InternalAggregations - Class in org.elasticsearch.search.aggregations
-
- InternalAggregations(List<InternalAggregation>) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregations
-
Constructs a new addAggregation.
- InternalAvg - Class in org.elasticsearch.search.aggregations.metrics.avg
-
- InternalAvg(String, double, long, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
-
- InternalBucket() - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation.InternalBucket
-
- InternalBucketMetricValue - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics
-
- InternalBucketMetricValue() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
-
- InternalBucketMetricValue(String, String[], double, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
-
- internalBuilder(SearchSourceBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source builder to be used with this request.
- internalBuilder() - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Returns the internal search source builder used to construct the request.
- InternalCardinality - Class in org.elasticsearch.search.aggregations.metrics.cardinality
-
- InternalChildren - Class in org.elasticsearch.search.aggregations.bucket.children
-
- InternalChildren() - Constructor for class org.elasticsearch.search.aggregations.bucket.children.InternalChildren
-
- InternalChildren(String, long, InternalAggregations, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.children.InternalChildren
-
- InternalClusterInfoService - Class in org.elasticsearch.cluster
-
InternalClusterInfoService provides the ClusterInfoService interface,
routinely updated on a timer.
- InternalClusterInfoService(Settings, NodeSettingsService, TransportNodesStatsAction, TransportIndicesStatsAction, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.cluster.InternalClusterInfoService
-
- InternalClusterInfoService.SubmitReschedulingClusterInfoUpdatedJob - Class in org.elasticsearch.cluster
-
- InternalClusterService - Class in org.elasticsearch.cluster.service
-
- InternalClusterService(Settings, DiscoveryService, OperationRouting, TransportService, NodeSettingsService, ThreadPool, ClusterName, DiscoveryNodeService, Version) - Constructor for class org.elasticsearch.cluster.service.InternalClusterService
-
- 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
-
- InternalDateRange - Class in org.elasticsearch.search.aggregations.bucket.range.date
-
- InternalDateRange.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range.date
-
- InternalDateRange.Factory - Class in org.elasticsearch.search.aggregations.bucket.range.date
-
- internalDebug(String) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalDebug(String, Throwable) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalDebug(String) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalDebug(String, Throwable) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalDebug(String) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalDebug(String, Throwable) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalDebug(String) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- internalDebug(String, Throwable) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- InternalDerivative - Class in org.elasticsearch.search.aggregations.pipeline.derivative
-
- InternalDerivative(String, double, double, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
-
- internalDispatchRequest(HttpRequest, HttpChannel) - Method in class org.elasticsearch.http.HttpServer
-
- InternalEngine - Class in org.elasticsearch.index.engine
-
- InternalEngine(EngineConfig, boolean) - Constructor for class org.elasticsearch.index.engine.InternalEngine
-
- InternalEngineFactory - Class in org.elasticsearch.index.engine
-
- InternalEngineFactory() - Constructor for class org.elasticsearch.index.engine.InternalEngineFactory
-
- internalError(String) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalError(String, Throwable) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalError(String) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalError(String, Throwable) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalError(String) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalError(String, Throwable) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalError(String) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- internalError(String, Throwable) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- InternalExtendedStats - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
-
- InternalExtendedStats() - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
-
- InternalExtendedStats(String, long, double, double, double, double, double, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
-
- InternalExtendedStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended
-
- 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
-
- InternalFilters - Class in org.elasticsearch.search.aggregations.bucket.filters
-
- InternalFilters() - Constructor for class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- InternalFilters(String, List<InternalFilters.Bucket>, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- InternalFilters.Bucket - Class in org.elasticsearch.search.aggregations.bucket.filters
-
- internalFrequency(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
-
- InternalGeoBounds - Class in org.elasticsearch.search.aggregations.metrics.geobounds
-
- InternalGeoCentroid - Class in org.elasticsearch.search.aggregations.metrics.geocentroid
-
- InternalGeoCentroid() - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- InternalGeoCentroid(String, GeoPoint, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- InternalGeoDistance - Class in org.elasticsearch.search.aggregations.bucket.range.geodistance
-
- InternalGeoDistance(String, List<InternalGeoDistance.Bucket>, ValueFormatter, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
-
- InternalGeoDistance.Factory - Class in org.elasticsearch.search.aggregations.bucket.range.geodistance
-
- 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(String, int, Collection<InternalGeoHashGrid.Bucket>, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
-
- 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.
- InternalHDRPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
-
- InternalHDRPercentileRanks(String, double[], DoubleHistogram, boolean, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
-
- 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, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
-
- InternalHDRPercentiles.Iter - Class in org.elasticsearch.search.aggregations.metrics.percentiles.hdr
-
- internalHighlightFields() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- InternalHistogram<B extends InternalHistogram.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
TODO should be renamed to InternalNumericHistogram (see comment on
Histogram
)?
- InternalHistogram.Bucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
- InternalHistogram.Factory<B extends InternalHistogram.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
- internalHits() - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- InternalIndicesLifecycle - Class in org.elasticsearch.indices
-
InternalIndicesLifecycle handles invoking each listener for the Index.
- InternalIndicesLifecycle(Settings) - Constructor for class org.elasticsearch.indices.InternalIndicesLifecycle
-
- internalInfo(String) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalInfo(String, Throwable) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalInfo(String) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalInfo(String, Throwable) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalInfo(String) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalInfo(String, Throwable) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalInfo(String) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- internalInfo(String, Throwable) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- InternalIPv4Range - Class in org.elasticsearch.search.aggregations.bucket.range.ipv4
-
- InternalIPv4Range() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
-
- InternalIPv4Range(String, List<InternalIPv4Range.Bucket>, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
-
- InternalIPv4Range.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range.ipv4
-
- InternalIPv4Range.Factory - Class in org.elasticsearch.search.aggregations.bucket.range.ipv4
-
- InternalLineStringBuilder(MultiLineStringBuilder) - Constructor for class org.elasticsearch.common.geo.builders.MultiLineStringBuilder.InternalLineStringBuilder
-
- internalMap() - Method in class org.elasticsearch.common.settings.Settings.Builder
-
- InternalMax - Class in org.elasticsearch.search.aggregations.metrics.max
-
- InternalMax(String, double, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.InternalMax
-
- InternalMetricsAggregation - Class in org.elasticsearch.search.aggregations.metrics
-
- InternalMetricsAggregation() - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMetricsAggregation
-
- InternalMetricsAggregation(String, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMetricsAggregation
-
- InternalMin - Class in org.elasticsearch.search.aggregations.metrics.min
-
- InternalMin(String, double, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.InternalMin
-
- InternalMissing - Class in org.elasticsearch.search.aggregations.bucket.missing
-
- InternalMultiBucketAggregation<A extends InternalMultiBucketAggregation,B extends InternalMultiBucketAggregation.InternalBucket> - Class in org.elasticsearch.search.aggregations
-
- InternalMultiBucketAggregation() - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
- InternalMultiBucketAggregation(String, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
- InternalMultiBucketAggregation.InternalBucket - Class in org.elasticsearch.search.aggregations
-
- InternalNested - Class in org.elasticsearch.search.aggregations.bucket.nested
-
- InternalNested() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
-
- InternalNested(String, long, InternalAggregations, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
-
- InternalNestedIdentity(String, int, InternalSearchHit.InternalNestedIdentity) - Constructor for class org.elasticsearch.search.internal.InternalSearchHit.InternalNestedIdentity
-
- InternalNumericMetricsAggregation - Class in org.elasticsearch.search.aggregations.metrics
-
- InternalNumericMetricsAggregation.MultiValue - Class in org.elasticsearch.search.aggregations.metrics
-
- InternalNumericMetricsAggregation.SingleValue - Class in org.elasticsearch.search.aggregations.metrics
-
- InternalParseContext(Settings, DocumentMapperParser, DocumentMapper, ContentPath) - Constructor for class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- InternalPercentile - Class in org.elasticsearch.search.aggregations.metrics.percentiles
-
- InternalPercentile(double, double) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentile
-
- InternalPercentilesBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
-
- InternalPercentilesBucket() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- InternalPercentilesBucket(String, double[], double[], ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- InternalPercentilesBucket.Iter - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
-
- InternalProfileCollector - Class in org.elasticsearch.search.profile
-
This class wraps a Lucene Collector and times the execution of:
- setScorer()
- collect()
- doSetNextReader()
- needsScores()
InternalProfiler facilitates the linking of the the Collector graph
- InternalProfileCollector(Collector, String, List<InternalProfileCollector>) - Constructor for class org.elasticsearch.search.profile.InternalProfileCollector
-
- InternalProfileShardResults - Class in org.elasticsearch.search.profile
-
A container class to hold all the profile results across all shards.
- InternalProfileShardResults(Map<String, List<ProfileShardResult>>) - Constructor for class org.elasticsearch.search.profile.InternalProfileShardResults
-
- InternalProfileShardResults(StreamInput) - Constructor for class org.elasticsearch.search.profile.InternalProfileShardResults
-
- InternalRange<B extends InternalRange.Bucket,R extends InternalRange<B,R>> - Class in org.elasticsearch.search.aggregations.bucket.range
-
- InternalRange() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- InternalRange(String, List<B>, ValueFormatter, boolean, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- 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
-
- InternalReverseNested() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
-
- InternalReverseNested(String, long, InternalAggregations, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
-
- InternalSampler - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
- 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
-
- 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
-
- InternalSearchHit - Class in org.elasticsearch.search.internal
-
- InternalSearchHit(int, String, Text, Map<String, SearchHitField>) - Constructor for class org.elasticsearch.search.internal.InternalSearchHit
-
- InternalSearchHit(int, String, Text, InternalSearchHit.InternalNestedIdentity, Map<String, SearchHitField>) - Constructor for class org.elasticsearch.search.internal.InternalSearchHit
-
- InternalSearchHit.Fields - Class in org.elasticsearch.search.internal
-
- InternalSearchHit.InternalNestedIdentity - Class in org.elasticsearch.search.internal
-
- InternalSearchHit.InternalNestedIdentity.Fields - Class in org.elasticsearch.search.internal
-
- InternalSearchHitField - Class in org.elasticsearch.search.internal
-
- InternalSearchHitField(String, List<Object>) - Constructor for class org.elasticsearch.search.internal.InternalSearchHitField
-
- InternalSearchHits - Class in org.elasticsearch.search.internal
-
- InternalSearchHits(InternalSearchHit[], long, float) - Constructor for class org.elasticsearch.search.internal.InternalSearchHits
-
- InternalSearchHits.StreamContext - Class in org.elasticsearch.search.internal
-
- InternalSearchHits.StreamContext.ShardTargetType - Enum in org.elasticsearch.search.internal
-
- InternalSearchResponse - Class in org.elasticsearch.search.internal
-
- InternalSearchResponse(InternalSearchHits, InternalAggregations, Suggest, InternalProfileShardResults, boolean, Boolean) - Constructor for class org.elasticsearch.search.internal.InternalSearchResponse
-
- InternalSettingsPreparer - Class in org.elasticsearch.node.internal
-
- InternalSettingsPreparer() - Constructor for class org.elasticsearch.node.internal.InternalSettingsPreparer
-
- InternalSignificantTerms<A extends InternalSignificantTerms,B extends InternalSignificantTerms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- InternalSignificantTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
- InternalSignificantTerms(long, long, String, int, long, SignificanceHeuristic, List<? extends InternalSignificantTerms.Bucket>, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
- InternalSignificantTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- InternalSimpleValue - Class in org.elasticsearch.search.aggregations.pipeline
-
- InternalSimpleValue() - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
- InternalSimpleValue(String, double, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
- InternalSingleBucketAggregation - Class in org.elasticsearch.search.aggregations.bucket
-
A base class for all the single bucket aggregations.
- InternalSingleBucketAggregation() - Constructor for class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
- InternalSingleBucketAggregation(String, long, InternalAggregations, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Creates a single bucket aggregation.
- internalSourceRef() - Method in class org.elasticsearch.index.get.GetResult
-
Internal source representation, might be compressed....
- internalSourceRef() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
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() - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- InternalStats(String, long, double, double, double, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- InternalStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
-
- InternalStatsBucket(String, long, double, double, double, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
-
- InternalSum - Class in org.elasticsearch.search.aggregations.metrics.sum
-
- InternalTDigestPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
-
- InternalTDigestPercentileRanks(String, double[], TDigestState, boolean, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
-
- 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, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
-
- InternalTDigestPercentiles.Iter - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
-
- InternalTerms<A extends InternalTerms,B extends InternalTerms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.terms
-
- InternalTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- InternalTerms(String, Terms.Order, int, int, long, List<? extends InternalTerms.Bucket>, boolean, long, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- InternalTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
-
- InternalTopHits - Class in org.elasticsearch.search.aggregations.metrics.tophits
-
- InternalTopHits(String, int, int, TopDocs, InternalSearchHits, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
-
- internalTrace(String) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalTrace(String, Throwable) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalTrace(String) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalTrace(String, Throwable) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalTrace(String) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalTrace(String, Throwable) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalTrace(String) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- internalTrace(String, Throwable) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- InternalValueCount - Class in org.elasticsearch.search.aggregations.metrics.valuecount
-
- InternalValueCount(String, long, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
-
- internalWarn(String) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalWarn(String, Throwable) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- internalWarn(String) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalWarn(String, Throwable) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- internalWarn(String) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalWarn(String, Throwable) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- internalWarn(String) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- internalWarn(String, Throwable) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.children.ChildrenBuilder
-
- 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.filters.FiltersAggregationBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.MetricsAggregationBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativeBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffBuilder
-
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
-
- interruptTask() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Subclasses can override this method to implement interruption of the
future's computation.
- intersection(ObjectLookupContainer<T>, ObjectLookupContainer<T>) - Static method in class org.elasticsearch.common.collect.HppcMaps
-
- intersection(double) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
-
Set the intersection of this line segment to the given position
- 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_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.
- interval(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
-
- interval() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
-
- Interval() - Constructor for class org.elasticsearch.common.rounding.Rounding.Interval
-
- Interval(long) - Constructor for class org.elasticsearch.common.rounding.Rounding.Interval
-
Creates a new interval rounding.
- interval(TimeValue) - Method in class org.elasticsearch.monitor.jvm.HotThreads
-
- interval(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
-
Set the interval in milliseconds.
- interval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
-
Set the interval.
- interval(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramBuilder
-
Sets the interval for the histogram.
- intField(FieldInfo, int) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
-
- intPage(boolean) - Method in class org.elasticsearch.cache.recycler.PageCacheRecycler
-
- intToBytes(int) - Static method in class org.elasticsearch.common.Numbers
-
Converts an int to a byte array.
- intValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- intValue(boolean) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- intValue(boolean) - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- intValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- 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(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
-
- InvalidAliasNameException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
-
- InvalidIndexNameException - Exception in org.elasticsearch.indices
-
- InvalidIndexNameException(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
-
- InvalidIndexNameException(StreamInput) - 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(SnapshotId, String) - Constructor for exception org.elasticsearch.snapshots.InvalidSnapshotNameException
-
- InvalidSnapshotNameException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.InvalidSnapshotNameException
-
- InvalidTypeNameException - Exception in org.elasticsearch.indices
-
- InvalidTypeNameException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidTypeNameException
-
- InvalidTypeNameException(String) - Constructor for exception org.elasticsearch.indices.InvalidTypeNameException
-
- invoke(Object, Method, Object[]) - Method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider2
-
When a factory method is invoked, we create a child injector that binds all parameters, then
use that to get an instance of the return type.
- ipField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- IpFieldMapper - Class in org.elasticsearch.index.mapper.ip
-
- IpFieldMapper(String, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper
-
- IpFieldMapper.Builder - Class in org.elasticsearch.index.mapper.ip
-
- IpFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.ip
-
- IpFieldMapper.IpFieldType - Class in org.elasticsearch.index.mapper.ip
-
- IpFieldMapper.NumericIpAnalyzer - Class in org.elasticsearch.index.mapper.ip
-
- IpFieldMapper.NumericIpTokenizer - Class in org.elasticsearch.index.mapper.ip
-
- IpFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.ip
-
- IpFieldType() - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- IpFieldType(IpFieldMapper.IpFieldType) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- ipRange(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
- IpRangeParser - Class in org.elasticsearch.search.aggregations.bucket.range.ipv4
-
- IpRangeParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ipv4.IpRangeParser
-
- ipToLong(String) - Static method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
-
- IPv4 - Static variable in class org.elasticsearch.search.aggregations.support.format.ValueFormat
-
- IPv4 - Static variable in interface org.elasticsearch.search.aggregations.support.format.ValueFormatter
-
- IPv4 - Static variable in interface org.elasticsearch.search.aggregations.support.format.ValueParser
-
- IPv4Formatter() - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormatter.IPv4Formatter
-
- IPv4RangeBuilder - Class in org.elasticsearch.search.aggregations.bucket.range.ipv4
-
Builder for the IPv4Range
aggregation.
- IPv4RangeBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
-
Sole constructor.
- IrishAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
Provider for IrishAnalyzer
- IrishAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.IrishAnalyzerProvider
-
- isA(ValueType) - Method in enum org.elasticsearch.search.aggregations.support.ValueType
-
- isAccessibleDirectory(Path, ESLogger) - 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
- 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(List<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
- isAllNodes(String...) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
- 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
- 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
- isAnyOriginSupported() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Determines whether a wildcard origin, '*', is supported.
- isArray(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
- isArtificial() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
-
- 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.
- isAutoThrottle() - Method in class org.elasticsearch.index.shard.MergeSchedulerConfig
-
Returns true
iff auto throttle is enabled.
- isBeta() - Method in class org.elasticsearch.Version
-
- isBoolean(char[], int, int) - Static method in class org.elasticsearch.common.Booleans
-
returns true if the a sequence of chars is one of "true","false","on","off","yes","no","0","1"
- isBooleanValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- isBooleanValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
returns true if the current value is boolean in nature.
- 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
-
- isBroken() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
-
Queries if this barrier is in a broken state.
- isBrowser(String) - Static method in class org.elasticsearch.rest.support.RestUtils
-
- 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.tasks.CancellableTask
-
- isCharacterTokenStream(TokenStream) - Static method in class org.elasticsearch.index.analysis.Analysis
-
Check whether the provided token stream is able to provide character
terms.
- isChecksum(String) - Static method in class org.elasticsearch.index.store.Store
-
- isClientNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
- isCloseConnectionException(Throwable) - Static method in class org.elasticsearch.common.transport.NetworkExceptionHelper
-
- isClosed() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- isClosed() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- isClosed() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- isClosed - Variable in class org.elasticsearch.index.engine.Engine
-
- isClosed() - Method in class org.elasticsearch.index.translog.TranslogReader
-
- isClosed() - Method in class org.elasticsearch.node.Node
-
Returns true if the node is closed.
- isCommitted() - Method in class org.elasticsearch.index.engine.Segment
-
- isComplete() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- isCompound() - Method in class org.elasticsearch.index.engine.Segment
-
- isCompoundOnFlush() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns true
iff flushed segments should be written as compound file system.
- isCompress() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
Returns true if metadata files should be compressed
- 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
-
Returns true if metadata and snapshot files should be compressed
- isCompress(byte) - Static method in class org.elasticsearch.transport.support.TransportStatus
-
- isCompressed(BytesReference) - Method in interface org.elasticsearch.common.compress.Compressor
-
- isCompressed(ChannelBuffer) - Method in interface org.elasticsearch.common.compress.Compressor
-
- isCompressed(IndexInput) - Method in interface org.elasticsearch.common.compress.Compressor
-
- isCompressed(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
- isCompressed(IndexInput) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
- isCompressed(BytesReference) - Method in class org.elasticsearch.common.compress.deflate.DeflateCompressor
-
- isCompressed(ChannelBuffer) - Method in class org.elasticsearch.common.compress.deflate.DeflateCompressor
-
- isCompressed(IndexInput) - Method in class org.elasticsearch.common.compress.deflate.DeflateCompressor
-
- isCompressed(BytesReference) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
-
Deprecated.
- isCompressed(ChannelBuffer) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
-
Deprecated.
- isCompressed(IndexInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
-
Deprecated.
- isConcrete(Class<?>) - Static method in class org.elasticsearch.common.Classes
-
- isConflictException(Throwable) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- 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.
- isConstantMatchAllQuery(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
- isConstructing() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
-
- isContextEmpty() - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- isContextEmpty() - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- isContextEmpty() - Method in interface org.elasticsearch.common.HasContext
-
Checks if the context is empty.
- isContextEmpty() - Method in class org.elasticsearch.percolator.PercolateContext
-
- 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 of CorruptIndexException
,
IndexFormatTooOldException
, or IndexFormatTooNewException
otherwise false.
- isCorsSupportEnabled() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Determines if support for CORS is enabled.
- isCountedDown() - Method in class org.elasticsearch.common.util.concurrent.CountDown
-
Returns true
iff the count-down has reached zero.
- isCreate() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Iff true
the engine should create a new lucene index when opening the engine.
- isCreated() - Method in class org.elasticsearch.action.index.IndexResponse
-
Returns true if the document was created, false if updated.
- isCreated() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
-
Returns true if the document was created, false if updated.
- isCreated() - Method in class org.elasticsearch.action.update.UpdateResponse
-
Returns true if document was created due to an UPSERT operation
- isCredentialsAllowed() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Determines if cookies are supported for CORS requests.
- isCurrent(Translog.TranslogGeneration) - Method in class org.elasticsearch.index.translog.Translog
-
Returns true
iff the given generation is the current gbeneration 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.
- isDataOnlyNode(ClusterState) - Static method in class org.elasticsearch.gateway.GatewayMetaState
-
- isDebugEnabled() - Method in interface org.elasticsearch.common.logging.ESLogger
-
Returns true
if a DEBUG level message is logged.
- isDebugEnabled() - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- isDebugEnabled() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- isDebugEnabled() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- isDebugEnabled() - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
-
- isDeleted() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
-
- isDeleteOnExit() - Method in class org.elasticsearch.common.PidFile
-
Returns true
iff the process id file is deleted on system exit.
- isDeprecatedSetting(String) - Method in class org.elasticsearch.index.query.QueryParseContext
-
Return whether the setting is deprecated.
- isDone() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
- isDynamicOrLoggingSetting(String) - Method in class org.elasticsearch.cluster.settings.DynamicSettings
-
- 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.percolate.PercolateShardResponse
-
- isEmpty() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
-
- 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.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.builders.ShapeBuilder.CoordinateNode
-
- isEmpty(DocIdSet) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Is it an empty DocIdSet
?
- 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 enum org.elasticsearch.common.util.CollectionUtils
-
Checks if the given array contains any elements.
- isEmpty() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- isEmpty() - Method in class org.elasticsearch.common.util.MinimalMap
-
- isEmpty() - Method in class org.elasticsearch.index.mapper.FieldMappers
-
- 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() - Method in class org.elasticsearch.search.rescore.RescoreBuilder
-
- isEnabled() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- isEnabled(String) - Method in class org.elasticsearch.common.lucene.LoggerInfoStream
-
- isEnabled() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.FieldNamesFieldType
-
- isEnabled() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- isEnableGcDeletes() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns true
iff delete garbage collection in the engine should be enabled.
- isError(byte) - Static method in class org.elasticsearch.transport.support.TransportStatus
-
- isErrorEnabled() - Method in interface org.elasticsearch.common.logging.ESLogger
-
Returns true
if an ERROR level message is logged.
- isErrorEnabled() - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- isErrorEnabled() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- isErrorEnabled() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- isErrorEnabled() - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
-
- 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.indexedscripts.get.GetIndexedScriptResponse
-
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 exists.
- 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
- isExplicitFalse(String) - Static method in class org.elasticsearch.common.Booleans
-
Returns true
iff the value is either of the following:
false, 0, off, no
otherwise false
- isExplicitlyScoped() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns true if this scope was explicitly applied.
- isExplicitTrue(String) - Static method in class org.elasticsearch.common.Booleans
-
Returns true
iff the value is either of the following:
true, 1, on, yes
otherwise false
- 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.percolate.MultiPercolateResponse.Item
-
- isFailure() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
-
Is it a failed search?
- isFilter() - Method in class org.elasticsearch.index.query.QueryParseContext
-
Return whether we are currently parsing a filter or a query.
- isFiltered() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
-
- 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
-
- isFlushOnClose() - Method in class org.elasticsearch.index.shard.IndexShard
-
- 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.delete.DeleteResponse
-
Returns true if a doc was found to delete.
- isFound() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
-
Returns true if a doc was found to delete.
- isFreed() - Method in class org.elasticsearch.search.action.SearchServiceTransportAction.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
-
- isFuzzy() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- isFuzzyTranspositions() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- isFuzzyTranspositions() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
- isFuzzyUnicodeAware() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- isGenerated() - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
-
- isGenerated() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Fields might not be available before indexing, for example _all, token_count,...
- isGenerated() - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
-
- isGenerated() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- isGeoHashEnabled() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- isGeoHashPrefixEnabled() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- isGeoPoint() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
-
- isGlobalStateEquals(MetaData, MetaData) - Static method in class org.elasticsearch.cluster.metadata.MetaData
-
- isHeldByCurrentThread() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
-
- 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.postingshighlight.Snippet
-
- isIgnoredEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns true
iff any unassigned shards are marked as temporarily ignored.
- isIncludeInParent() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Nested
-
- isIncludeInRoot() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Nested
-
- isIncludeRelocations() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
- isIndexUsingShadowReplicas(Settings) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Returns true
iff the given settings indicate that the index associated
with these settings uses shadow replicas.
- 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
- isInfoEnabled() - Method in interface org.elasticsearch.common.logging.ESLogger
-
Returns true
if an INFO level message is logged.
- isInfoEnabled() - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- isInfoEnabled() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- isInfoEnabled() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- isInfoEnabled() - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
-
- isIngestNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Returns a boolean that tells whether this an ingest node or not
- isInnerClass(Class<?>) - Static method in class org.elasticsearch.common.Classes
-
- isIsolated() - Method in class org.elasticsearch.plugins.PluginInfo
-
- isJvm() - Method in class org.elasticsearch.plugins.PluginInfo
-
- isKnown(DiscoveryNode) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- 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
-
- isLast() - Method in class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
-
- isLatLonEnabled() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- 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.
- 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.index.get.GetField
-
- isMetadataField(String) - Static method in class org.elasticsearch.index.mapper.MapperService
-
- isMetadataField() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- isMetadataField() - Method in interface org.elasticsearch.search.SearchHitField
-
- 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.
- isMultiValued(SortedNumericDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns whether the provided values *might* be multi-valued.
- isMultiValued(SortedNumericDoubleValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns whether the provided values *might* be multi-valued.
- isMultiValued(SortedBinaryDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns whether the provided values *might* be multi-valued.
- isMultiValued(MultiGeoPointValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns whether the provided values *might* be multi-valued.
- isMultiValued() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns true
iff this builder contains a document ID that is associated with more than one ordinal.
- isNativesAvailable() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns true if we successfully loaded native libraries.
- isNegativeQuery(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
- isNested() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Nested
-
- 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
-
- isNotifyOnMergeFailure() - Method in class org.elasticsearch.index.shard.MergeSchedulerConfig
-
Returns true
iff we fail the engine on a merge failure.
- 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
-
- isNullOriginAllowed() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Web browsers may set the 'Origin' request header to 'null' if a resource is loaded
from the local file system.
- isNumeric() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.NumberFieldType
-
- isNumeric() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- isNumeric() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
-
- isObject(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
- isOnSharedFilesystem(Settings) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Returns true
iff the given settings indicate that the index
associated with these settings allocates it's shards on a shared
filesystem.
- isOOM(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
Returns true
iff the given throwable is and OutOfMemoryException, otherwise false
- 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 this Translog
is still open.
- isOptimizeAutoGenerateId() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns true
iff documents with auto-generated IDs are optimized if possible.
- isOptional() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns true if this injection point shall be skipped if the injector cannot resolve bindings
for all required dependencies.
- isOriginAllowed(String) - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Returns whether the input origin is allowed by this configuration.
- isParent(String) - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- isPrimaryActive() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
-
- isProcessed() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
-
- 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
-
- isRC() - Method in class org.elasticsearch.Version
-
- isReadOverrideException(Throwable) - 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.
- 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).
- isRegexBased() - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude
-
- isRegistered(Class<? extends Throwable>) - Static method in exception org.elasticsearch.ElasticsearchException
-
Retruns true
iff the given class is a registered for an exception to be read.
- 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
-
- isRelocationTargetOf(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if the routing is the relocation target of the given routing
- isRemoved() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodeIterator
-
- 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.support.TransportStatus
-
- isReservedChar(char) - Static method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- isRetainedAtRuntime(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Returns true if the given annotation is retained at runtime.
- isRunning() - Method in class org.elasticsearch.common.StopWatch
-
Return whether the stop watch is currently running.
- isSame(StoreFileMetaData) - Method in class org.elasticsearch.index.shard.CommitPoint.FileInfo
-
- isSame(StoreFileMetaData) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Checks if a file in a store is the same file
- 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.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.
- isSameShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if this routing has the same shardId 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.
- isScopeAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
- isSearch() - Method in class org.elasticsearch.index.engine.Segment
-
- isSeccompInstalled() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns true if secure computing mode is enabled (supported systems only)
- isSet(CommonStatsFlags.Flag) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- isSet() - Method in class org.elasticsearch.tasks.TaskId
-
- isShardNotAvailableException(Throwable) - Static method in class org.elasticsearch.action.support.TransportActions
-
- isShortCircuit() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Determines whether a CORS request should be rejected if it's invalid before being
further processing.
- isSimpleMatchPattern(String) - Static method in class org.elasticsearch.common.regex.Regex
-
Is the str a simple match pattern.
- isSingle() - Method in class org.elasticsearch.common.cli.CliToolConfig
-
- isSite() - Method in class org.elasticsearch.plugins.PluginInfo
-
- isSortable() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- isSortable() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- 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.
- isSourceEmpty() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- isSourceEmpty() - Method in interface org.elasticsearch.search.SearchHit
-
Is the source empty (not available) or not.
- isStopAtNonOption() - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd
-
- isStoringPayloads() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- isStrict() - Method in class org.elasticsearch.common.ParseFieldMatcher
-
Should deprecated settings be rejected?
- isSubAction() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
-
- isSubAction() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
-
- 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.cluster.ClusterStateTaskExecutor.TaskResult
-
- isSyncOnEachOperation() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns true
iff each low level operation shoudl be fsynced
- isSynthetic() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
-
- isTempBlobName(String) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
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.indexing.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 timedout
- isTokenChar(int) - Method in class org.elasticsearch.index.analysis.CharMatcher.ByUnicodeCategory
-
- isTokenChar(int) - Method in interface org.elasticsearch.index.analysis.CharMatcher
-
Returns true if, and only if, the provided character matches this character class.
- isTraceEnabled() - Method in interface org.elasticsearch.common.logging.ESLogger
-
Returns true
if a TRACE level message is logged.
- isTraceEnabled() - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- isTraceEnabled() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- isTraceEnabled() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- isTransportThread(Thread) - Static method in enum org.elasticsearch.transport.Transports
-
Utility method to detect whether a thread is a network thread.
- isUnicodeAware() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
- 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.
- isValue() - Method in enum org.elasticsearch.common.xcontent.XContentParser.Token
-
- 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) - Method in enum org.elasticsearch.index.VersionType
-
Checks whether the current version conflicts with the expected version, based on the current version type.
- isWarnEnabled() - Method in interface org.elasticsearch.common.logging.ESLogger
-
Returns true
if a WARN level message is logged.
- isWarnEnabled() - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- isWarnEnabled() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- isWarnEnabled() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- isWarnEnabled() - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
-
- isWildcard() - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
-
- isWithin(double, double) - Method in interface org.elasticsearch.common.geo.GeoDistance.DistanceBoundingCheck
-
- isWithin(double, double) - Method in class org.elasticsearch.common.geo.GeoDistance.Meridian180DistanceBoundingCheck
-
- isWithin(double, double) - Method in class org.elasticsearch.common.geo.GeoDistance.SimpleDistanceBoundingCheck
-
- 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
-
- isWritable(Path) - Static method in class org.elasticsearch.env.Environment
-
Returns true if the path is writable.
- ItalianAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- ItalianAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ItalianAnalyzerProvider
-
- Item() - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
-
- Item(String, String, String) - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
-
Constructs a single get item.
- Item(Integer, PercolateShardResponse) - Constructor for class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response.Item
-
- Item(Integer, Throwable) - Constructor for class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response.Item
-
- Item(SearchResponse, Throwable) - Constructor for class org.elasticsearch.action.search.MultiSearchResponse.Item
-
- Item() - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.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.
- items() - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse
-
- items() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Request
-
- items() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response
-
- 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
-
- 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[], double[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket.Iter
-
- iterableAsArrayList(Iterable<? extends E>) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- iterate(PortsRange.PortCallback) - Method in class org.elasticsearch.common.transport.PortsRange
-
- iterator() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
-
Iterator over the repositories data
- iterator() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
- iterator() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
-
- 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
-
- 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.indexedscripts.get.GetIndexedScriptResponse
-
- iterator() - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse
-
- iterator() - Method in class org.elasticsearch.action.percolate.PercolateResponse
-
- iterator() - Method in class org.elasticsearch.action.search.MultiSearchResponse
-
- iterator() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
- 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.routing.GroupShardsIterator
-
- iterator() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
- iterator() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodeIterator
-
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodesIterator
-
- 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.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.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.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
-
Deprecated.
- iterator() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredTerms
-
Deprecated.
- iterator() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommits
-
- iterator() - Method in class org.elasticsearch.index.get.GetField
-
- 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.FieldMapper
-
- iterator() - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
-
- iterator() - Method in class org.elasticsearch.index.mapper.FieldMappers
-
- iterator() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- iterator() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- iterator() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
- iterator() - Method in class org.elasticsearch.index.search.child.ConstantScorer
-
- iterator() - Method in class org.elasticsearch.index.shard.CommitPoints
-
- 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.bucket.significant.InternalSignificantTerms
-
- iterator() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- 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.tdigest.InternalTDigestPercentileRanks
-
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
-
- iterator() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- iterator() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- iterator() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- iterator() - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- iterator() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
-
- 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
-
- PackedArrayEstimator(CircuitBreaker, IndexNumericFieldData.NumericType, String) - Constructor for class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData.PackedArrayEstimator
-
- PackedArrayIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
Stores numeric data into bit-packed arrays for better memory efficiency.
- PackedArrayIndexFieldData(Index, Settings, MappedFieldType.Names, FieldDataType, IndexFieldDataCache, IndexNumericFieldData.NumericType, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData
-
- PackedArrayIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
-
- PackedArrayIndexFieldData.PackedArrayEstimator - Class in org.elasticsearch.index.fielddata.plain
-
Estimator that wraps numeric field data loading in a
RamAccountingTermsEnum, adjusting the breaker after data has been
loaded
- pad(Table.Cell, int, RestRequest, UTF8StreamWriter) - Static method in class org.elasticsearch.rest.action.support.RestTable
-
- pad(boolean) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
-
- padStart(String, int, char) - Static method in class org.elasticsearch.common.Strings
-
- PAGE_SIZE_IN_BYTES - Static variable in class org.elasticsearch.common.util.BigArrays
-
Page size in bytes: 16KB
- PageCacheRecycler - Class in org.elasticsearch.cache.recycler
-
A recycler of fixed-size pages.
- PageCacheRecycler(Settings, ThreadPool) - Constructor for class org.elasticsearch.cache.recycler.PageCacheRecycler
-
- pageCacheRecycler() - Method in class org.elasticsearch.percolator.PercolateContext
-
- pageCacheRecycler() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
- pageCacheRecycler() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- pageCacheRecycler() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- pageCacheRecycler() - Method in class org.elasticsearch.search.internal.SearchContext
-
- PageCacheRecycler.Type - Enum in org.elasticsearch.cache.recycler
-
- 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(Index, Settings, MappedFieldType.Names, FieldDataType, IndexFieldDataCache, CircuitBreakerService) - 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(BigArrays, ByteArray, int) - Constructor for class org.elasticsearch.common.bytes.PagedBytesReference
-
- PagedBytesReference(BigArrays, ByteArray, int, int) - Constructor for class org.elasticsearch.common.bytes.PagedBytesReference
-
- PARAGRAPH_SEPARATOR - Static variable in class org.elasticsearch.search.highlight.HighlightUtils
-
- param(String) - Method in class org.elasticsearch.common.xcontent.ToXContent.DelegatingMapParams
-
- param(String, String) - Method in class org.elasticsearch.common.xcontent.ToXContent.DelegatingMapParams
-
- param(String) - Method in class org.elasticsearch.common.xcontent.ToXContent.MapParams
-
- param(String, String) - Method in class org.elasticsearch.common.xcontent.ToXContent.MapParams
-
- param(String) - Method in interface org.elasticsearch.common.xcontent.ToXContent.Params
-
- param(String, String) - Method in interface org.elasticsearch.common.xcontent.ToXContent.Params
-
- param(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
- param(String, String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
- param(String) - Method in class org.elasticsearch.rest.RestRequest
-
- param(String, Object) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
- paramAsBoolean(String, boolean) - Method in class org.elasticsearch.common.xcontent.ToXContent.DelegatingMapParams
-
- paramAsBoolean(String, Boolean) - Method in class org.elasticsearch.common.xcontent.ToXContent.DelegatingMapParams
-
- paramAsBoolean(String, boolean) - Method in class org.elasticsearch.common.xcontent.ToXContent.MapParams
-
- paramAsBoolean(String, Boolean) - Method in class org.elasticsearch.common.xcontent.ToXContent.MapParams
-
- paramAsBoolean(String, boolean) - Method in interface org.elasticsearch.common.xcontent.ToXContent.Params
-
- paramAsBoolean(String, Boolean) - Method in interface org.elasticsearch.common.xcontent.ToXContent.Params
-
- 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
-
- params() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
- params() - Method in class org.elasticsearch.rest.RestRequest
-
- PARAMS - Static variable in interface org.elasticsearch.script.Script.ScriptField
-
- params(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
-
Set parameters that will be available in the init, map
and combine phases.
- PARAMS_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- PARAMS_FIELD - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptParser
-
- PARAMS_FIELD - Static variable in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorParser
-
- 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() - Method in class org.elasticsearch.action.index.IndexRequest
-
- 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 and also implicitely sets the routing if not already set.
- parent() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- PARENT - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
- parent() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- parent(String) - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- parent() - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- parent() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- parent(String) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- parent() - Method in class org.elasticsearch.index.translog.Translog.Create
-
- parent() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- parent - Variable in class org.elasticsearch.index.translog.Translog.Source
-
- parent() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Return the parent aggregator.
- parent - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
-
- parent() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- parent - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
-
- parent() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
- parent() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
-
- ParentChild(ParentChildIndexFieldData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
-
- ParentChildAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- ParentChildAtomicFieldData(ImmutableOpenMap<String, AtomicOrdinalsFieldData>) - Constructor for class org.elasticsearch.index.fielddata.plain.ParentChildAtomicFieldData
-
- ParentChildEstimator(CircuitBreaker, TermsEnum) - Constructor for class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.ParentChildEstimator
-
- ParentChildIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
ParentChildIndexFieldData is responsible for loading the id cache mapping
needed for has_child and has_parent queries into memory.
- ParentChildIndexFieldData(Index, Settings, MappedFieldType.Names, FieldDataType, IndexFieldDataCache, MapperService, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
-
- ParentChildIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
-
- ParentChildIndexFieldData.GlobalFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- ParentChildIndexFieldData.ParentChildEstimator - Class in org.elasticsearch.index.fielddata.plain
-
Estimator that wraps parent/child id field data by wrapping the data
in a RamAccountingTermsEnum.
- ParentChildInnerHits(SearchContext, ParsedQuery, Map<String, InnerHitsContext.BaseInnerHits>, MapperService, DocumentMapper) - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.ParentChildInnerHits
-
- ParentCollector(IndexParentChildFieldData, SearchContext, String) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- ParentConstantScoreQuery - Class in org.elasticsearch.index.search.child
-
- ParentConstantScoreQuery(ParentChildIndexFieldData, Query, String, Filter) - Constructor for class org.elasticsearch.index.search.child.ParentConstantScoreQuery
-
Deprecated.
- parentFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- ParentFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
- ParentFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- ParentFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- ParentFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- parentFilter() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
-
- parentFilter - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- parentFilter - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- parentFilter - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
-
Deprecated.
- parentIdxs - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- ParentQuery - Class in org.elasticsearch.index.search.child
-
- ParentQuery(ParentChildIndexFieldData, Query, String, Filter) - Constructor for class org.elasticsearch.index.search.child.ParentQuery
-
Deprecated.
- ParentScoreCollector(IndexParentChildFieldData, SearchContext, String) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCollector
-
Deprecated.
- ParentScoreCountCollector(IndexParentChildFieldData, SearchContext, String) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCountCollector
-
Deprecated.
- ParentToChildrenAggregator - Class in org.elasticsearch.search.aggregations.bucket.children
-
- ParentToChildrenAggregator(String, AggregatorFactories, AggregationContext, Aggregator, String, Query, Query, ValuesSource.Bytes.ParentChild, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator
-
- ParentToChildrenAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.children
-
- parentType - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- parentType - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- ParentWeight(Query, Weight, Filter, long, ChildrenQuery.ParentCollector, int, int) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
-
Deprecated.
- parse(String) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- parse(String) - Static method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Comparison
-
- parse(String) - Static method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Property
-
- parse(String) - Static method in enum org.elasticsearch.cache.recycler.PageCacheRecycler.Type
-
- parse(XContentParser, MappingMetaData.ParseContext) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
- 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, String[]) - Method in class org.elasticsearch.common.cli.CliTool
-
- parse(CliToolConfig.Cmd, String[]) - Method in class org.elasticsearch.common.cli.CliTool
-
- parse(String, CommandLine) - Method in class org.elasticsearch.common.cli.CliTool
-
- parse(XContentParser) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parse(XContentParser, GeoShapeFieldMapper) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
Parse the geometry specified by the source document and return a ShapeBuilder instance used to
build the actual geometry
- parse(XContentParser) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- parse(XContentParser, GeoShapeFieldMapper) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- parse(String, Callable<Long>) - Method in class org.elasticsearch.common.joda.DateMathParser
-
- parse(String, Callable<Long>, boolean, DateTimeZone) - Method in class org.elasticsearch.common.joda.DateMathParser
-
- 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, DistanceUnit) - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Parses a given distance and converts it to this unit.
- parse(XContentParser) - Static method in class org.elasticsearch.common.unit.Fuzziness
-
- parse(String) - Static method in class org.elasticsearch.common.util.LocaleUtils
-
Parse the string describing a locale into a
Locale
object
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.core.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 }
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper.TypeParser
-
- parse(String, String, String, BytesReference) - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- parse(SourceToParse) - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- parse(String, CompressedXContent) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
-
- parse(String, CompressedXContent, String) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
-
- parse(FieldMapper, ParseContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Parse using the provided
ParseContext
and return a mapping
update if dynamic mappings modified the mappings, or
null
if
mappings were not modified.
- parse(ParseContext, GeoPoint, String) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.TypeParser
-
- parse(ParseContext, GeoPoint, String) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.TypeParser
-
- parse(GeoPointFieldMapperLegacy.Builder, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy
-
- parse(ParseContext, GeoPoint, String) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper.TypeParser
-
- parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.TypeParser
-
- parse(String, MappedFieldType.Loading) - Static method in enum org.elasticsearch.index.mapper.MappedFieldType.Loading
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in interface org.elasticsearch.index.mapper.Mapper.TypeParser
-
- parse(String, CompressedXContent, boolean) - Method in class org.elasticsearch.index.mapper.MapperService
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in interface org.elasticsearch.index.mapper.MetadataFieldMapper.TypeParser
-
- parse(String, Map<String, Object>) - Static method in class org.elasticsearch.index.mapper.object.DynamicTemplate
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
-
- parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.TypeParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.AndQueryParser
-
Deprecated.
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.BoolQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.BoostingQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.CommonTermsQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.ConstantScoreQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.DisMaxQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.ExistsQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FilteredQueryParser
-
Deprecated.
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FQueryFilterParser
-
Deprecated.
- parse(QueryParseContext, XContentParser) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionParser
-
Parses bodies of the kind
- parse(QueryParseContext, XContentParser) - Method in class org.elasticsearch.index.query.functionscore.factor.FactorParser
-
Deprecated.
- parse(QueryParseContext, XContentParser) - Method in class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryParser
-
- parse(QueryParseContext, XContentParser) - Method in class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionParser
-
- parse(QueryParseContext, XContentParser) - Method in interface org.elasticsearch.index.query.functionscore.ScoreFunctionParser
-
- parse(QueryParseContext, XContentParser) - Method in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FuzzyQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoDistanceQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeohashCellQuery.Parser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoPolygonQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoShapeQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.HasChildQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.HasParentQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.IdsQueryParser
-
- parse(QueryBuilder) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parse(byte[]) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parse(byte[], int, int) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parse(BytesReference) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parse(QueryParseContext, BytesReference) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parse(String) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parse(XContentParser) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parse(QueryParseContext, XContentParser) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.IndicesQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.LimitQueryParser
-
Deprecated.
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MatchAllQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MatchQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MissingQueryParser
-
- parse(XContentParser, ParseFieldMatcher, MoreLikeThisQueryBuilder.Item) - Static method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Parses and returns the given item.
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryParser
-
- parse(String, ParseFieldMatcher) - Static method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MultiMatchQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.NestedQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.NotQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.OrQueryParser
-
Deprecated.
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.PrefixQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.QueryFilterParser
-
Deprecated.
- parse(QueryParseContext) - Method in interface org.elasticsearch.index.query.QueryParser
-
Parses the into a query from the current parser location.
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.QueryStringQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.RangeQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.RegexpQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.ScriptQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SimpleQueryStringParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanContainingQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanFirstQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanMultiTermQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanNearQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanNotQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanOrQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanTermQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanWithinQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.support.InnerHitsQueryParserHelper
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TemplateQueryParser
-
Parses the template query replacing template parameters with provided
values.
- parse(XContentParser, ParseFieldMatcher, String...) - Static method in class org.elasticsearch.index.query.TemplateQueryParser
-
- parse(String, XContentParser, ParseFieldMatcher, String...) - Static method in class org.elasticsearch.index.query.TemplateQueryParser
-
- parse(XContentParser, ParseFieldMatcher) - Static method in class org.elasticsearch.index.query.TemplateQueryParser
-
- parse(XContentParser, Map<String, ScriptService.ScriptType>, ParseFieldMatcher) - Static method in class org.elasticsearch.index.query.TemplateQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TermQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TermsQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TypeQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.WildcardQueryParser
-
- parse(QueryParseContext) - Method in class org.elasticsearch.index.query.WrapperQueryParser
-
- parse(MatchQuery.Type, String, Object) - Method in class org.elasticsearch.index.search.MatchQuery
-
- parse(MultiMatchQueryBuilder.Type, Map<String, Float>, Object, String) - Method in class org.elasticsearch.index.search.MultiMatchQuery
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.index.search.stats.StatsGroupsParseElement
-
- parse(String, CommandLine) - Method in class org.elasticsearch.plugins.PluginManagerCliParser
-
- parse(XContentParser, ParseFieldMatcher) - Method in class org.elasticsearch.script.AbstractScriptParser
-
- parse(Map<String, Object>, boolean, ParseFieldMatcher) - Method in class org.elasticsearch.script.AbstractScriptParser
-
- parse(Map<String, Object>, boolean, ParseFieldMatcher) - Static method in class org.elasticsearch.script.Script
-
- parse(XContentParser, ParseFieldMatcher) - Static method in class org.elasticsearch.script.Script
-
- parse(Map<String, Object>, boolean, ParseFieldMatcher) - Static method in class org.elasticsearch.script.Template
-
- parse(XContentParser, ParseFieldMatcher) - Static method in class org.elasticsearch.script.Template
-
- parse(XContentParser, Map<String, ScriptService.ScriptType>, ParseFieldMatcher) - Static method in class org.elasticsearch.script.Template
-
Deprecated.
- parse(XContentParser, Map<String, ScriptService.ScriptType>, String, ParseFieldMatcher) - Static method in class org.elasticsearch.script.Template
-
Deprecated.
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.AggregationBinaryParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.AggregationParseElement
-
- parse(String, XContentParser, SearchContext) - 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, ParseFieldMatcher) - Static method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.children.ChildrenParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IpRangeParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerParser
-
- parse(XContentParser, ParseFieldMatcher, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDParser
-
- parse(XContentParser, ParseFieldMatcher, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore.JLHScoreParser
-
- parse(XContentParser, ParseFieldMatcher, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYParser
-
- parse(XContentParser, ParseFieldMatcher, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore.PercentageScoreParser
-
- parse(XContentParser, ParseFieldMatcher, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicParser
-
- parse(XContentParser, ParseFieldMatcher, SearchContext) - Method in interface org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParser
-
- parse(String, XContentParser, SearchContext, ValuesSourceParser, IncludeExclude.Parser) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.NumericValuesSourceMetricsAggregatorParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountParser
-
- parse(SearchContext, String, XContentLocation) - Static method in enum org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Parse a string GapPolicy into the byte enum
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.BucketMetricsParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativeParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorParser
-
- parse(Map<String, Object>, String, int, ParseFieldMatcher) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel.SingleExpModelParser
-
- parse(Map<String, Object>, String, int, ParseFieldMatcher) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel.DoubleExpModelParser
-
- parse(Map<String, Object>, String, int, ParseFieldMatcher) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelParser
-
- parse(String, ParseFieldMatcher) - Static method in enum org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.SeasonalityType
-
Parse a string SeasonalityType into the byte enum
- parse(Map<String, Object>, String, int, ParseFieldMatcher) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel.LinearModelParser
-
- parse(Map<String, Object>, String, int, ParseFieldMatcher) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel.AbstractModelParser
-
Parse a settings hash that is specific to this model
- parse(Map<String, Object>, String, int, ParseFieldMatcher) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel.SimpleModelParser
-
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgParser
-
- parse(String, XContentParser, SearchContext) - Method in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
-
Returns the pipeline aggregator factory with which this parser is
associated.
- parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffParser
-
- parse(String) - Static method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.explain.ExplainParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.FetchSubPhaseParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.FieldsParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.source.FetchSourceParseElement
-
- parse(XContentParser) - Method in class org.elasticsearch.search.fetch.source.FetchSourceParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.version.VersionParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.highlight.HighlighterParseElement
-
- parse(XContentParser, IndexQueryParserService) - Method in class org.elasticsearch.search.highlight.HighlighterParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.profile.ProfileParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.FilterBinaryParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.FromParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.IndicesBoostParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.MinScoreParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.PostFilterParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.QueryBinaryParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.QueryParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.SizeParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.TerminateAfterParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.TimeoutParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.rescore.QueryRescorer
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.rescore.RescoreParseElement
-
- parse(XContentParser, SearchContext) - Method in interface org.elasticsearch.search.rescore.Rescorer
-
- parse(XContentParser, SearchContext) - Method in interface org.elasticsearch.search.SearchParseElement
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.sort.GeoDistanceSortParser
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.sort.ScriptSortParser
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.sort.SortParseElement
-
- parse(XContentParser, SearchContext) - Method in interface org.elasticsearch.search.sort.SortParser
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.sort.TrackScoresParseElement
-
- parse(XContentParser, MapperService, IndexQueryParserService, HasContextAndHeaders) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestParser
-
- parse(XContentParser, MapperService, IndexQueryParserService, HasContextAndHeaders) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestParser
-
- parse(XContentParser, MapperService, IndexQueryParserService, HasContextAndHeaders) - Method in interface org.elasticsearch.search.suggest.SuggestContextParser
-
- parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.suggest.SuggestParseElement
-
- parse(XContentParser, MapperService, IndexQueryParserService, HasContextAndHeaders) - Method in class org.elasticsearch.search.suggest.term.TermSuggestParser
-
- PARSE_STRICT - Static variable in class org.elasticsearch.index.query.IndexQueryParserService
-
- parseAfterEffect(Settings) - Method in class org.elasticsearch.index.similarity.DFRSimilarityProvider
-
Parses the given Settings and creates the appropriate AfterEffect
- parseAggregators(XContentParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.AggregatorParsers
-
Parses the aggregation request recursively generating aggregator factories in turn.
- parseAnalysisVersion(Settings, Settings, ESLogger) - Static method in class org.elasticsearch.index.analysis.Analysis
-
- parseArticles(Environment, Settings) - Static method in class org.elasticsearch.index.analysis.Analysis
-
- parseBasicModel(Settings) - Method in class org.elasticsearch.index.similarity.DFRSimilarityProvider
-
Parses the given Settings and creates the appropriate BasicModel
- parseBoolean(char[], int, int, boolean) - Static method in class org.elasticsearch.common.Booleans
-
Returns false
if text is in false, 0, off, no; else, true
- parseBoolean(String, Boolean) - Static method in class org.elasticsearch.common.Booleans
-
- parseBoolean(String, boolean) - Static method in class org.elasticsearch.common.Booleans
-
Returns true
iff the value is neither of the following:
false, 0, off, no
otherwise false
- parseBooleanExact(String) - Static method in class org.elasticsearch.common.Booleans
-
- 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
- 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.
- parseCircle(ShapeBuilder.CoordinateNode, DistanceUnit.Distance) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parseClassPath() - Static method in class org.elasticsearch.bootstrap.JarHell
-
Parses the classpath into an array of URLs
- parseCommonInnerHitOptions(XContentParser, XContentParser.Token, String, SubSearchContext, SortParseElement, FetchSourceParseElement, HighlighterParseElement, ScriptFieldsParseElement, FieldDataFieldsParseElement) - Static method in class org.elasticsearch.index.query.support.InnerHitsQueryParserHelper
-
- parseCommonWords(Environment, Settings, CharArraySet, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
-
- parseConfig(Map<String, Object>, boolean, ParseFieldMatcher) - Method in class org.elasticsearch.script.ScriptParameterParser
-
- ParseContext(boolean, boolean, boolean) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
- ParseContext - Class in org.elasticsearch.index.mapper
-
- ParseContext() - Constructor for class org.elasticsearch.index.mapper.ParseContext
-
- parseContext - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- parseContext - Variable in class org.elasticsearch.index.search.MatchQuery
-
- parseContext(ParseContext, XContentParser) - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- parseContext(ParseContext, XContentParser) - Method in class org.elasticsearch.search.suggest.context.ContextMapping
-
- parseContext(ParseContext, XContentParser) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- 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.core.TypeParsers
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Parse the field value and populate fields
.
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
-
- parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
-
- parseCreateFieldForString(ParseContext, String, float) - Static method in class org.elasticsearch.index.mapper.core.StringFieldMapper
-
Parse a field as though it were a string.
- parseDateTimeFormatter(Object) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
- parsedDoc() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- ParsedDocument - Class in org.elasticsearch.index.mapper
-
The result of parsing a document.
- ParsedDocument(Field, Field, String, String, String, long, long, List<ParseContext.Document>, BytesReference, Mapping) - Constructor for class org.elasticsearch.index.mapper.ParsedDocument
-
- parseDirectSpellcheckerSettings(XContentParser, String, DirectSpellcheckerSettings, ParseFieldMatcher) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- parseDistance(String) - Static method in class org.elasticsearch.common.unit.DistanceUnit.Distance
-
- parseDistribution(Settings) - Method in class org.elasticsearch.index.similarity.IBSimilarityProvider
-
Parses the given Settings and creates the appropriate Distribution
- parsedMatchAllQuery() - Static method in class org.elasticsearch.index.query.ParsedQuery
-
- parseDocuments(XContentParser, List<MultiGetRequest.Item>, String, String, String[], FetchSourceContext, String, boolean) - Static method in class org.elasticsearch.action.get.MultiGetRequest
-
- parseDocuments(XContentParser, List<MultiGetRequest.Item>) - Static method in class org.elasticsearch.action.get.MultiGetRequest
-
- parseDouble(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.Boolean
-
- parseDouble(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.DateMath
-
- parseDouble(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.DateTime
-
- parseDouble(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.IPv4
-
- parseDouble(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.Number.Pattern
-
- parseDouble(String, SearchContext) - Method in interface org.elasticsearch.search.aggregations.support.format.ValueParser
-
- parseDouble(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.Raw
-
- 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
- parseDoubleValue(Object) - Static method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
Converts an object value into a double
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.percolator.PercolateContext
-
- parsedPostFilter() - Method in class org.elasticsearch.percolator.PercolateContext
-
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- parsedPostFilter() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- parsedPostFilter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.SearchContext
-
- parsedPostFilter() - Method in class org.elasticsearch.search.internal.SearchContext
-
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- ParsedQuery - Class in org.elasticsearch.index.query
-
The result of parsing a query.
- ParsedQuery(Query, ImmutableMap<String, Query>) - Constructor for class org.elasticsearch.index.query.ParsedQuery
-
- ParsedQuery(Query, ParsedQuery) - Constructor for class org.elasticsearch.index.query.ParsedQuery
-
- ParsedQuery(Query) - Constructor for class org.elasticsearch.index.query.ParsedQuery
-
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.percolator.PercolateContext
-
- parsedQuery() - Method in class org.elasticsearch.percolator.PercolateContext
-
- parsedQuery() - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.BaseInnerHits
-
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- parsedQuery() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- parsedQuery() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.SearchContext
-
- parsedQuery() - Method in class org.elasticsearch.search.internal.SearchContext
-
- parseElement() - Method in class org.elasticsearch.search.suggest.SuggestPhase
-
- parseElements() - Method in class org.elasticsearch.search.aggregations.AggregationPhase
-
- parseElements() - Method in class org.elasticsearch.search.dfs.DfsPhase
-
- parseElements() - Method in class org.elasticsearch.search.fetch.explain.ExplainFetchSubPhase
-
- parseElements() - Method in class org.elasticsearch.search.fetch.FetchPhase
-
- parseElements() - Method in interface org.elasticsearch.search.fetch.FetchSubPhase
-
- parseElements() - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsFetchSubPhase
-
- parseElements() - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsFetchSubPhase
-
- parseElements() - Method in class org.elasticsearch.search.fetch.matchedqueries.MatchedQueriesFetchSubPhase
-
- parseElements() - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsFetchSubPhase
-
- parseElements() - Method in class org.elasticsearch.search.fetch.source.FetchSourceSubPhase
-
- parseElements() - Method in class org.elasticsearch.search.fetch.version.VersionFetchSubPhase
-
- parseElements() - Method in class org.elasticsearch.search.highlight.HighlightPhase
-
- parseElements() - Method in class org.elasticsearch.search.query.QueryPhase
-
- parseElements() - Method in class org.elasticsearch.search.rescore.RescorePhase
-
- parseElements() - Method in interface org.elasticsearch.search.SearchPhase
-
- parseElements() - Method in class org.elasticsearch.search.suggest.SuggestPhase
-
- parseEnvelope(ShapeBuilder.CoordinateNode, ShapeBuilder.Orientation) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parseExternalValue(Class<T>) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Try to parse an externalValue if any
- ParseField - Class in org.elasticsearch.common
-
Holds a field that can be found in a request while parsing and its different variants, which may be deprecated.
- ParseField(String, String...) - Constructor for class org.elasticsearch.common.ParseField
-
- parseField(FieldMapper.Builder, String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
Parse common field attributes such as doc_values
or store
.
- parseField() - Method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
- parseField() - Method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
- parseFieldMatcher - Variable in class org.elasticsearch.action.support.TransportAction
-
- ParseFieldMatcher - Class in org.elasticsearch.common
-
Matcher to use in combination with
ParseField
while parsing requests.
- ParseFieldMatcher(Settings) - Constructor for class org.elasticsearch.common.ParseFieldMatcher
-
- ParseFieldMatcher(boolean) - Constructor for class org.elasticsearch.common.ParseFieldMatcher
-
- parseFieldMatcher() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
-
- parseFieldMatcher() - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parseFieldMatcher(ParseFieldMatcher) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- parseFieldMatcher() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- parseFieldMatcher - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
-
- parseFieldMatcher - Variable in class org.elasticsearch.rest.BaseRestHandler
-
- parseFieldMatcher - Variable in class org.elasticsearch.search.internal.SearchContext
-
- parseFieldMatcher() - Method in class org.elasticsearch.search.internal.SearchContext
-
- parseFields(XContentParser, IndexQueryParserService) - Method in class org.elasticsearch.search.highlight.HighlighterParseElement
-
- parseFromLatLon(String) - Static method in class org.elasticsearch.common.geo.GeoPoint
-
- parseFromRestRequest(RestRequest) - Static method in class org.elasticsearch.search.fetch.source.FetchSourceContext
-
- parseGeometries(XContentParser, GeoShapeFieldMapper) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
Parse the geometries array of a GeometryCollection
- parseGeoPoint(XContentParser) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
- parseGeoPoint(XContentParser, GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
- parseGeoPoint(String, GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
- parseGroup(MatchQuery.Type, String, Float, Object, String) - Method in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
-
- parseIdFromFileName(Path) - Static method in class org.elasticsearch.index.translog.Translog
-
Extracts the translog generation from a file name.
- parseIds(XContentParser, List<MultiGetRequest.Item>, String, String, String[], FetchSourceContext, String) - Static method in class org.elasticsearch.action.get.MultiGetRequest
-
- parseIds(XContentParser, List<MultiGetRequest.Item>) - Static method in class org.elasticsearch.action.get.MultiGetRequest
-
- parseIndex(String, String, FieldMapper.Builder) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
- parseInlineScript(XContentParser) - Method in class org.elasticsearch.script.AbstractScriptParser
-
- parseInnerFilter(XContentParser) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
Parses an inner filter, returning null if the filter should be ignored.
- parseInnerFilter() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- parseInnerFilter(String) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- parseInnerQuery(XContentParser) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parseInnerQuery(QueryParseContext) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
- parseInnerQuery() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- 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(XContentParser, MapperService, IndexQueryParserService, String, int, HasContextAndHeaders) - Method in class org.elasticsearch.search.suggest.SuggestParseElement
-
- parseInto(DateTimeParserBucket, String, int) - Method in class org.elasticsearch.common.joda.Joda.EpochTimeParser
-
- parseLambda(Settings) - Method in class org.elasticsearch.index.similarity.IBSimilarityProvider
-
Parses the given Settings and creates the appropriate Lambda
- parseLinearRing(ShapeBuilder.CoordinateNode, boolean) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parseLineString(ShapeBuilder.CoordinateNode) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parseLong(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.Boolean
-
- parseLong(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.DateMath
-
- parseLong(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.DateTime
-
- parseLong(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.IPv4
-
- parseLong(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.Number.Pattern
-
- parseLong(String, SearchContext) - Method in interface org.elasticsearch.search.aggregations.support.format.ValueParser
-
- parseLong(String, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.format.ValueParser.Raw
-
- parseLongValue(Object) - Static method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
-
Converts an object value into a long
- parseMultiField(FieldMapper.Builder, String, Mapper.TypeParser.ParserContext, String, Object) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
- parseMultiLine(ShapeBuilder.CoordinateNode) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parseMultiPoint(ShapeBuilder.CoordinateNode) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parseMultiPolygon(ShapeBuilder.CoordinateNode, ShapeBuilder.Orientation, boolean) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parseNested(String, Map<String, Object>, ObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
-
- parseNoCFSRatio(String) - Static method in class org.elasticsearch.index.shard.MergePolicyConfig
-
- parseNormalization(Settings) - Method in class org.elasticsearch.index.similarity.AbstractSimilarityProvider
-
Parses the given Settings and creates the appropriate Normalization
- parseNumberField(NumberFieldMapper.Builder, String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
- parseObjectOrDocumentTypeProperties(String, Object, Mapper.TypeParser.ParserContext, ObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
-
- parseObjectProperties(String, String, Object, Mapper.TypeParser.ParserContext, ObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
-
- parseParams(ToXContent.Params) - Method in class org.elasticsearch.script.ScriptParameterParser
-
- parsePathType(String, String) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
- parsePayload(BytesRef, PayloadProcessor.SuggestPayload) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionLookupProvider
-
- parsePoint(ShapeBuilder.CoordinateNode) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parsePolygon(ShapeBuilder.CoordinateNode, ShapeBuilder.Orientation, boolean) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- parseProperties(ObjectMapper.Builder, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
-
- parseQueries(Map<String, ContextMapping>, XContentParser) - Static method in class org.elasticsearch.search.suggest.context.ContextMapping.ContextQuery
-
- parseQuery(BytesReference) - Method in class org.elasticsearch.index.query.IndexQueryParserService
-
Selectively parses a query from a top level query or query_binary json field from the specified source.
- parseQuery(String, XContentParser) - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- parseQuery(String, XContentParser) - Method in class org.elasticsearch.search.suggest.context.ContextMapping
-
Parse a query according to the context.
- parseQuery(String, XContentParser) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- parseQuerySource(RestRequest) - Static method in class org.elasticsearch.rest.action.support.RestActions
-
- parser() - Method in class org.elasticsearch.common.joda.FormatDateTimeFormatter
-
- parser() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- parser() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- parser() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- Parser() - Constructor for class org.elasticsearch.index.query.GeohashCellQuery.Parser
-
- parser(XContentParser) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- parser() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- parser(String) - Method in class org.elasticsearch.search.aggregations.AggregatorParsers
-
Returns the parser that is registered under the given aggregation type.
- Parser() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude.Parser
-
- parser() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormat
-
- parser() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- 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, AnalysisService, SimilarityLookupService, MapperService, Map<String, Mapper.TypeParser>, Version, ParseFieldMatcher) - 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.
- parseRewriteMethod(ParseFieldMatcher, String) - Static method in class org.elasticsearch.index.query.support.QueryParsers
-
- parseRewriteMethod(ParseFieldMatcher, String, MultiTermQuery.RewriteMethod) - Static method in class org.elasticsearch.index.query.support.QueryParsers
-
- parseSearchRequest(SearchRequest, RestRequest, ParseFieldMatcher, BytesReference) - Static method in class org.elasticsearch.rest.action.search.RestSearchAction
-
- parseSearchSource(RestRequest) - Static method in class org.elasticsearch.rest.action.search.RestSearchAction
-
- parseSinglePointOrList(XContentParser) - Static method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- parseSingleRescoreContext(XContentParser, SearchContext) - Method in class org.elasticsearch.search.rescore.RescoreParseElement
-
- parseSizeValue(String) - Static method in class org.elasticsearch.common.unit.SizeValue
-
- parseSizeValue(String, SizeValue) - Static method in class org.elasticsearch.common.unit.SizeValue
-
- parseSmoothingModel(XContentParser, PhraseSuggestionContext, String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestParser
-
- parseSpecial(String, XContentParser, SearchContext, XContentParser.Token, String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParametersParser
-
- parseSpecial(String, XContentParser, SearchContext, XContentParser.Token, String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- parseSpecial(String, XContentParser, SearchContext, XContentParser.Token, String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsParametersParser
-
- parseStemExclusion(Settings, CharArraySet) - Static method in class org.elasticsearch.index.analysis.Analysis
-
- parseStopWords(Environment, Settings, CharArraySet) - Static method in class org.elasticsearch.index.analysis.Analysis
-
- parseStopWords(Environment, Settings, CharArraySet, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
-
- parseStore(String, String) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
- parseString(String, boolean) - Static method in enum org.elasticsearch.cluster.ClusterState.Metric
-
- parseString(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
- parseStringTimestamp(String, FormatDateTimeFormatter, Version) - Static method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
-
- parseStringValue(String, PropertyPlaceholder.PlaceholderResolver, Set<String>) - Method in class org.elasticsearch.common.property.PropertyPlaceholder
-
- parseStringValue(String) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- parseSuggestContext(XContentParser, MapperService, String, SuggestionSearchContext.SuggestionContext, ParseFieldMatcher) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- parseTermVector(String, String, FieldMapper.Builder) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
- parseTextField(FieldMapper.Builder, String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
-
Parse text field attributes.
- parseTimeValue(String, TimeValue, String) - Static method in class org.elasticsearch.common.unit.TimeValue
-
- parseToMilliseconds(Object, boolean, DateTimeZone, DateMathParser) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- 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, ESLogger) - Static method in class org.elasticsearch.common.lucene.Lucene
-
- parseVersion(RestRequest) - Static method in class org.elasticsearch.rest.action.support.RestActions
-
- parseVersion(RestRequest, long) - Static method in class org.elasticsearch.rest.action.support.RestActions
-
- parseVersionLenient(String, Version) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Parses the version string lenient and returns the the default value if the given string is null or emtpy
- parseWords(Environment, Settings, String, CharArraySet, Map<String, Set<?>>, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
-
- parsingStillNeeded() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Is parsing still needed?
- 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(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() - 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(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() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns true if incomplete indices will be restored
- partial(boolean) - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Set to true if partial snapshot should be allowed
- 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
- path() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Id
-
- path() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
-
- path() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
-
- path() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
- path - Variable in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
-
- path() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
-
- path() - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
-
- path - Variable in class org.elasticsearch.common.blobstore.url.URLBlobContainer
-
- path() - Method in class org.elasticsearch.common.blobstore.url.URLBlobStore
-
Returns base URL
- path - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
-
- path(String) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Builder
-
- PATH - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
-
- path() - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
-
- path(String) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Builder
-
- PATH - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
-
- path() - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- path(String) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
-
- PATH - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
-
- path() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- 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 - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- path() - Method in class org.elasticsearch.index.translog.TranslogReader
-
- 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() - 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.MultiBucketsAggregation.Bucket.SubAggregationComparator
-
- path(String) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedBuilder
-
Set the path to use for this nested aggregation.
- path(String) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedBuilder
-
Set the path to use for this nested aggregation.
- PATH_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Defaults
-
- PATH_TYPE - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Defaults
-
- pathAsText(String) - Method in class org.elasticsearch.index.mapper.ContentPath
-
- PathElement(String, String, String) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
-
- pathElements() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Id
-
- pathElements() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
-
- pathElements() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
-
- PathHierarchyTokenizerFactory - Class in org.elasticsearch.index.analysis
-
- PathHierarchyTokenizerFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PathHierarchyTokenizerFactory
-
- pathsForPermissionsCheck(Settings, Environment) - Method in class org.elasticsearch.common.cli.CheckFileCommand
-
Returns the array of paths, that should be checked if the permissions, user or groups have changed
before and after execution of the command
- PathTrie<T> - Class in org.elasticsearch.common.path
-
- PathTrie(PathTrie.Decoder) - Constructor for class org.elasticsearch.common.path.PathTrie
-
- PathTrie(char, String, PathTrie.Decoder) - Constructor for class org.elasticsearch.common.path.PathTrie
-
- PathTrie.Decoder - Interface in org.elasticsearch.common.path
-
- PathTrie.TrieNode<T> - Class in org.elasticsearch.common.path
-
- pathType() - Method in class org.elasticsearch.index.mapper.ContentPath
-
- pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.ContentPath
-
- pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
-
- pathType - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- pathType - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper
-
- pathType - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
-
- pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
-
- pathType() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- PathUtils - Class in org.elasticsearch.common.io
-
Utilities for creating a Path from names,
or accessing the default FileSystem.
- pattern() - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormat.Patternable
-
- Pattern(String) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Number.Pattern
-
- Pattern(String) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueParser.Number.Pattern
-
- Patternable(String, ValueFormatter, ValueParser) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormat.Patternable
-
- PatternAnalyzer - Class in org.elasticsearch.index.analysis
-
Simple regex-based analyzer based on PatternTokenizer + lowercase + stopwords
- PatternAnalyzer(Pattern, boolean, CharArraySet) - Constructor for class org.elasticsearch.index.analysis.PatternAnalyzer
-
- PatternAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- PatternAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternAnalyzerProvider
-
- PatternCaptureGroupTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- PatternCaptureGroupTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternCaptureGroupTokenFilterFactory
-
- PatternCaptureGroupTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternCaptureGroupTokenFilterFactory
-
- PatternReplaceCharFilterFactory - Class in org.elasticsearch.index.analysis
-
- PatternReplaceCharFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternReplaceCharFilterFactory
-
- PatternReplaceTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- PatternReplaceTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternReplaceTokenFilterFactory
-
- PatternTokenizerFactory - Class in org.elasticsearch.index.analysis
-
- PatternTokenizerFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternTokenizerFactory
-
- payload - Variable in class org.elasticsearch.search.lookup.TermPosition
-
- PAYLOAD_SEP - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
- payloadAsFloat(float) - Method in class org.elasticsearch.search.lookup.TermPosition
-
- payloadAsInt(int) - Method in class org.elasticsearch.search.lookup.TermPosition
-
- payloadAsString() - Method in class org.elasticsearch.search.lookup.TermPosition
-
- 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(boolean) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Builder
-
- PAYLOADS - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- pb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- pbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- peek() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- Pending(Object, Priority, long, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
-
- 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, ActionListener<PendingClusterTasksResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a list of the pending cluster tasks, that are scheduled to be executed.
- pendingClusterTasks(PendingClusterTasksRequest) - 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
-
- pendingJoinRequests - Variable in class org.elasticsearch.discovery.zen.NodeJoinController
-
- 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 interface org.elasticsearch.cluster.ClusterService
-
Returns the tasks that are pending.
- pendingTasks() - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- PER_FIELD_ANALYZER - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item.Field
-
- percent(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
-
- 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
-
- PERCENTAGE - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- percentageField(XContentBuilderString, XContentBuilderString, double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- PercentageScore - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- PercentageScore.PercentageScoreBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- PercentageScore.PercentageScoreParser - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- PercentageScoreBuilder() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore.PercentageScoreBuilder
-
- PercentageScoreParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore.PercentageScoreParser
-
- percentAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
-
- 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 - Interface in org.elasticsearch.search.aggregations.metrics.percentiles
-
- 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.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
-
- 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.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- percentileRanks(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
- PercentileRanks - Interface in org.elasticsearch.search.aggregations.metrics.percentiles
-
An aggregation that computes approximate percentiles given values.
- PercentileRanksBuilder - Class in org.elasticsearch.search.aggregations.metrics.percentiles
-
- PercentileRanksBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksBuilder
-
Sole constructor.
- PercentileRanksParser - Class in org.elasticsearch.search.aggregations.metrics.percentiles
-
- PercentileRanksParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksParser
-
- percentiles(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Percentiles
aggregation with the given name.
- percentiles(double...) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksBuilder
-
Set the values to compute percentiles from.
- Percentiles - Interface in org.elasticsearch.search.aggregations.metrics.percentiles
-
An aggregation that computes approximate percentiles.
- percentiles(double...) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesBuilder
-
Set the percentiles to compute.
- PercentilesBucket - Interface in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
-
- percentilesBucket(String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
-
- PercentilesBucketBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
-
- PercentilesBucketBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketBuilder
-
- PercentilesBucketParser - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
-
- PercentilesBucketParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketParser
-
- PercentilesBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
-
- PercentilesBucketPipelineAggregator(String, double[], String[], BucketHelpers.GapPolicy, ValueFormatter, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
-
- PercentilesBucketPipelineAggregator.Factory - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile
-
- PercentilesBuilder - Class in org.elasticsearch.search.aggregations.metrics.percentiles
-
- PercentilesBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesBuilder
-
Sole constructor.
- PercentilesMethod - Enum in org.elasticsearch.search.aggregations.metrics.percentiles
-
An enum representing the methods for calculating percentiles
- PercentilesParser - Class in org.elasticsearch.search.aggregations.metrics.percentiles
-
- PercentilesParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesParser
-
- percents(Double[]) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketBuilder
-
- PERCENTS - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketParser
-
- PERCENTS_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesParser
-
- percolate - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- percolate(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- percolate() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- percolate(PercolateRequest) - Method in interface org.elasticsearch.client.Client
-
Percolates a request returning the matches documents.
- percolate(PercolateRequest, ActionListener<PercolateResponse>) - Method in interface org.elasticsearch.client.Client
-
Percolates a request returning the matches documents.
- percolate(PercolateRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
- percolate(PercolateRequest, ActionListener<PercolateResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
- percolate(PercolateShardRequest) - Method in class org.elasticsearch.percolator.PercolatorService
-
- PERCOLATE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- PercolateAction - Class in org.elasticsearch.action.percolate
-
- PercolateContext - Class in org.elasticsearch.percolator
-
- PercolateContext(PercolateShardRequest, SearchShardTarget, IndexShard, IndexService, PageCacheRecycler, BigArrays, ScriptService, Query, ParseFieldMatcher) - Constructor for class org.elasticsearch.percolator.PercolateContext
-
- PercolateException - Exception in org.elasticsearch.percolator
-
Exception during percolating document(s) at runtime.
- PercolateException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.percolator.PercolateException
-
- PercolateException(StreamInput) - Constructor for exception org.elasticsearch.percolator.PercolateException
-
- percolateQueries() - Method in class org.elasticsearch.index.percolator.PercolatorQueriesRegistry
-
- percolateQueries() - Method in class org.elasticsearch.percolator.PercolateContext
-
- percolateQuery() - Method in class org.elasticsearch.percolator.PercolateContext
-
- percolateQuery(Query) - Method in class org.elasticsearch.percolator.PercolateContext
-
- percolateRegistry() - Method in class org.elasticsearch.index.shard.IndexShard
-
- PercolateRequest - Class in org.elasticsearch.action.percolate
-
A request to execute a percolate operation.
- PercolateRequest() - Constructor for class org.elasticsearch.action.percolate.PercolateRequest
-
Constructor only for internal usage.
- PercolateRequestBuilder - Class in org.elasticsearch.action.percolate
-
A builder the easy to use of defining a percolate request.
- PercolateRequestBuilder(ElasticsearchClient, PercolateAction) - Constructor for class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- PercolateResponse - Class in org.elasticsearch.action.percolate
-
Encapsulates the response of a percolator request.
- PercolateResponse.Match - Class in org.elasticsearch.action.percolate
-
Represents a query that has matched with the document that was percolated.
- PercolateShardRequest - Class in org.elasticsearch.action.percolate
-
- PercolateShardRequest() - Constructor for class org.elasticsearch.action.percolate.PercolateShardRequest
-
- PercolateShardResponse - Class in org.elasticsearch.action.percolate
-
- PercolateShardResponse(BytesRef[], List<Map<String, HighlightField>>, long, float[], PercolateContext, ShardId) - Constructor for class org.elasticsearch.action.percolate.PercolateShardResponse
-
- PercolateShardResponse(BytesRef[], long, float[], PercolateContext, ShardId) - Constructor for class org.elasticsearch.action.percolate.PercolateShardResponse
-
- PercolateShardResponse(BytesRef[], List<Map<String, HighlightField>>, long, PercolateContext, ShardId) - Constructor for class org.elasticsearch.action.percolate.PercolateShardResponse
-
- PercolateShardResponse(long, PercolateContext, ShardId) - Constructor for class org.elasticsearch.action.percolate.PercolateShardResponse
-
- PercolateShardResponse(PercolateContext, ShardId) - Constructor for class org.elasticsearch.action.percolate.PercolateShardResponse
-
- PercolateSourceBuilder - Class in org.elasticsearch.action.percolate
-
Builder to create the percolate request body.
- PercolateSourceBuilder() - Constructor for class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
- PercolateSourceBuilder.DocBuilder - Class in org.elasticsearch.action.percolate
-
A builder for defining the document to be percolated in various ways.
- PercolateStats - Class in org.elasticsearch.index.percolator.stats
-
Exposes percolator related statistics.
- PercolateStats() - Constructor for class org.elasticsearch.index.percolator.stats.PercolateStats
-
Noop constructor for serialazation purposes.
- PercolatorException - Exception in org.elasticsearch.index.percolator
-
Exception during indexing a percolator query.
- PercolatorException(Index, String, Throwable) - Constructor for exception org.elasticsearch.index.percolator.PercolatorException
-
- PercolatorException(StreamInput) - Constructor for exception org.elasticsearch.index.percolator.PercolatorException
-
- PercolatorModule - Class in org.elasticsearch.percolator
-
- PercolatorModule() - Constructor for class org.elasticsearch.percolator.PercolatorModule
-
- PercolatorQueriesRegistry - Class in org.elasticsearch.index.percolator
-
- PercolatorQueriesRegistry(ShardId, Settings, IndexQueryParserService, ShardIndexingService, IndicesLifecycle, MapperService, IndexFieldDataService, ShardPercolateService) - Constructor for class org.elasticsearch.index.percolator.PercolatorQueriesRegistry
-
- PercolatorService - Class in org.elasticsearch.percolator
-
- PercolatorService(Settings, IndexNameExpressionResolver, IndicesService, PageCacheRecycler, BigArrays, HighlightPhase, ClusterService, AggregationPhase, ScriptService, MappingUpdatedAction) - Constructor for class org.elasticsearch.percolator.PercolatorService
-
- PercolatorService.ReduceResult - Class in org.elasticsearch.percolator
-
- percolatorTypeId() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
-
- percolatorTypeId - Variable in class org.elasticsearch.percolator.PercolateContext
-
- perFieldAnalyzer() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the overridden analyzers at each field.
- perFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Override the analyzer used at each field when generating term vectors.
- perFieldAnalyzer() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- 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
-
- PerFieldMappingPostingFormatCodec(Lucene50StoredFieldsFormat.Mode, MapperService, ESLogger) - Constructor for class org.elasticsearch.index.codec.PerFieldMappingPostingFormatCodec
-
- performBatchRecovery(Iterable<Translog.Operation>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Applies all operations in the iterable to the current engine and returns the number of operations applied.
- performOperation(ShardIterator, ShardRouting, int) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
-
- performRecoveryOperation(Engine, Translog.Operation, boolean) - Method in class org.elasticsearch.index.shard.TranslogRecoveryPerformer
-
Performs a single recovery operation.
- performRecoveryRestart() - Method in class org.elasticsearch.index.shard.IndexShard
-
called if recovery has to be restarted after network error / delay **
- performReroute(String) - Method in class org.elasticsearch.cluster.routing.RoutingService
-
- performStateRecovery(Gateway.GatewayStateRecoveredListener) - Method in class org.elasticsearch.gateway.Gateway
-
- performTranslogRecovery(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
After the store has been recovered, we need to start the engine in order to apply operations
- period(int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel.HoltWintersModelBuilder
-
- PersianAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- PersianAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PersianAnalyzerProvider
-
- PersianNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
-
- PersianNormalizationFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PersianNormalizationFilterFactory
-
- persistentSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
- persistentSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the persistent settings to be updated.
- persistentSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the persistent settings to be updated.
- persistentSettings(String) - 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() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- persistentSettings(Settings) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- persistentSettings() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- peta() - Method in class org.elasticsearch.common.unit.SizeValue
-
- petaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
-
- phase() - Method in exception org.elasticsearch.index.engine.RecoveryEngineException
-
- phase1(SnapshotIndexCommit, Translog.View) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
Perform phase1 of the recovery operations.
- phase2(Translog.Snapshot) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
Perform phase2 of the recovery process
- phraseLimit(Integer) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
Sets the maximum number of phrases the fvh will consider.
- phraseLimit(Integer) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
Sets the maximum number of phrases the fvh will consider if the field doesn't also define phraseLimit.
- phraseLimit() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- phraseSlop() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- phraseSlop(int) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- phraseSlop(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Sets the default slop for phrases.
- phraseSlop - Variable in class org.elasticsearch.index.search.MatchQuery
-
- PhraseSuggester - Class in org.elasticsearch.search.suggest.phrase
-
- PhraseSuggester(ScriptService) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggester
-
- PhraseSuggestion - Class in org.elasticsearch.search.suggest.phrase
-
- PhraseSuggestion() - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
-
- PhraseSuggestion(String, int) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
-
- phraseSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a phrase suggestion lookup query with the provided name
- 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.CandidateGenerator - Class in org.elasticsearch.search.suggest.phrase
-
- PhraseSuggestionBuilder.DirectCandidateGenerator - Class in org.elasticsearch.search.suggest.phrase
-
- PhraseSuggestionBuilder.Laplace - Class in org.elasticsearch.search.suggest.phrase
-
- PhraseSuggestionBuilder.LinearInterpolation - Class in org.elasticsearch.search.suggest.phrase
-
Linear interpolation smoothing model.
- PhraseSuggestionBuilder.SmoothingModel - Class in org.elasticsearch.search.suggest.phrase
-
- PhraseSuggestionBuilder.StupidBackoff - Class in org.elasticsearch.search.suggest.phrase
-
- PhraseSuggestParser - Class in org.elasticsearch.search.suggest.phrase
-
- PhraseSuggestParser(PhraseSuggester) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestParser
-
- physicalName() - Method in class org.elasticsearch.index.shard.CommitPoint.FileInfo
-
- physicalName() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns original file name
- pick(SortedNumericDocValues, long, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pick(SortedNumericDocValues, long, DocIdSetIterator, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pick(SortedNumericDoubleValues, double, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pick(SortedNumericDoubleValues, double, DocIdSetIterator, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pick(SortedBinaryDocValues, BytesRef, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pick(BinaryDocValues, BytesRefBuilder, DocIdSetIterator, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pick(RandomAccessOrds, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pick(SortedDocValues, DocIdSetIterator, int, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pick(MultiValueMode.UnsortedNumericDoubleValues, double, int) - Method in enum org.elasticsearch.search.MultiValueMode
-
- pickShardPath(ShardId) - Method in class org.elasticsearch.common.util.MultiDataPathUpgrader
-
Picks a target ShardPath to allocate and upgrade the given shard to.
- pid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
The process id.
- 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() - Method in class org.elasticsearch.env.Environment
-
The PID file location (can be null if no PID file is configured)
- ping(ZenPing.PingListener, TimeValue) - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
-
- ping(ZenPing.PingListener, TimeValue) - Method in interface org.elasticsearch.discovery.zen.ping.ZenPing
-
- ping(ZenPing.PingListener, TimeValue) - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
-
- PING_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
-
- PING_DATA_SIZE - Static variable in class org.elasticsearch.transport.netty.NettyHeader
-
The magic number (must be lower than 0) for a ping message.
- PING_SCHEDULE - Static variable in class org.elasticsearch.transport.netty.NettyTransport
-
- pingAndWait(TimeValue) - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
-
- pingAndWait(TimeValue) - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
-
- PingCollection() - Constructor for class org.elasticsearch.discovery.zen.ping.ZenPing.PingCollection
-
- PingContextProvider - Interface in org.elasticsearch.discovery.zen.ping
-
- pingHeader() - Static method in class org.elasticsearch.transport.netty.NettyHeader
-
A ping header is same as regular header, just with -1 for the size of the message.
- pingInterval - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- PingRequest() - Constructor for class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.PingRequest
-
- PingResponse(DiscoveryNode, DiscoveryNode, ClusterName, boolean) - Constructor for class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
-
- pingRetryCount - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- pingRetryTimeout - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- pipelineAggregator(String) - Method in class org.elasticsearch.search.aggregations.AggregatorParsers
-
Returns the parser that is registered under the given pipeline aggregator
type.
- PipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
-
- PipelineAggregator() - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
- PipelineAggregator(String, String[], Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
- PipelineAggregator.Parser - Interface in org.elasticsearch.search.aggregations.pipeline
-
Parses the pipeline aggregation request and creates the appropriate
pipeline aggregator factory for it.
- PipelineAggregatorBuilder<B extends PipelineAggregatorBuilder<B>> - Class in org.elasticsearch.search.aggregations.pipeline
-
A base class for all pipeline aggregator builders.
- PipelineAggregatorBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilder
-
Sole constructor, typically used by sub-classes.
- PipelineAggregatorBuilders - Class in org.elasticsearch.search.aggregations.pipeline
-
- PipelineAggregatorFactory - Class in org.elasticsearch.search.aggregations.pipeline
-
- PipelineAggregatorFactory(String, String, String[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorFactory
-
Constructs a new pipeline aggregator factory.
- pipelineAggregators() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
-
- 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
-
- PipelineAggregatorStreams - Class in org.elasticsearch.search.aggregations.pipeline
-
A registry for all the dedicated streams in the aggregation module.
- PipelineAggregatorStreams() - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorStreams
-
- PipelineAggregatorStreams.Stream - Interface in org.elasticsearch.search.aggregations.pipeline
-
A stream that knows how to read an aggregation from the input.
- pipelining - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- pipeliningMaxEvents - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- 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.highlight
-
- PlainHighlighter() - Constructor for class org.elasticsearch.search.highlight.PlainHighlighter
-
- PlainListenableActionFuture<T> - Class in org.elasticsearch.action.support
-
- PlainListenableActionFuture(ThreadPool) - 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 given
shardId
.
- PlainShardsIterator - Class in org.elasticsearch.cluster.routing
-
- 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
-
- PlaneFixedSourceDistance(double, double, DistanceUnit) - Constructor for class org.elasticsearch.common.geo.GeoDistance.PlaneFixedSourceDistance
-
- Plugin - Class in org.elasticsearch.plugins
-
An extension point allowing to plug in custom functionality.
- Plugin() - Constructor for class org.elasticsearch.plugins.Plugin
-
- Plugin(String, String) - Constructor for class org.elasticsearch.script.ScriptContext.Plugin
-
Creates a new custom scripts based operation exposed via plugin.
- PluginInfo - Class in org.elasticsearch.plugins
-
- PluginInfo() - Constructor for class org.elasticsearch.plugins.PluginInfo
-
- PluginManager - Class in org.elasticsearch.plugins
-
- PluginManager(Environment, URL, PluginManager.OutputMode, TimeValue) - Constructor for class org.elasticsearch.plugins.PluginManager
-
- PluginManager.OutputMode - Enum in org.elasticsearch.plugins
-
- PluginManagerCliParser - Class in org.elasticsearch.plugins
-
- PluginManagerCliParser() - Constructor for class org.elasticsearch.plugins.PluginManagerCliParser
-
- PluginManagerCliParser(Terminal) - Constructor for class org.elasticsearch.plugins.PluginManagerCliParser
-
- plugins(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should information about plugins be returned
- plugins() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
- PluginsAndModules - Class in org.elasticsearch.action.admin.cluster.node.info
-
Information about plugins and modules
- PluginsAndModules() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
-
- pluginsFile() - Method in class org.elasticsearch.env.Environment
-
- PluginsModule - Class in org.elasticsearch.plugins
-
- PluginsModule(PluginsService) - Constructor for class org.elasticsearch.plugins.PluginsModule
-
- PluginsService - Class in org.elasticsearch.plugins
-
- PluginsService(Settings, Path, Path, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.plugins.PluginsService
-
Constructs a new PluginService
- plusSkippedClasses(Class...) - Method in class org.elasticsearch.common.inject.internal.SourceProvider
-
Returns a new instance that also skips moreClassesToSkip
.
- point(double, double) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- point(Coordinate) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
Add a point to the shell of the polygon
- point(PointBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- point(double, double) - Method in class org.elasticsearch.common.geo.builders.PointCollection
-
Add a new point to the collection
- point(Coordinate) - Method in class org.elasticsearch.common.geo.builders.PointCollection
-
Add a new point to the collection
- point(double, double) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
- point(double, double) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- point(GeoPoint) - Method in class org.elasticsearch.index.query.GeohashCellQuery.Builder
-
- point(double, double) - Method in class org.elasticsearch.index.query.GeohashCellQuery.Builder
-
- point(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
Set the point to calculate distances from using a
lat,lon
notation or geohash.
- point(GeoPoint) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
-
Set the point to calculate distances from.
- point(double, double) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The point to create the range distance facets from.
- PointBuilder - Class in org.elasticsearch.common.geo.builders
-
- PointBuilder() - Constructor for class org.elasticsearch.common.geo.builders.PointBuilder
-
- PointCollection<E extends PointCollection<E>> - Class in org.elasticsearch.common.geo.builders
-
- PointCollection() - Constructor for class org.elasticsearch.common.geo.builders.PointCollection
-
- PointCollection(ArrayList<Coordinate>) - Constructor for class org.elasticsearch.common.geo.builders.PointCollection
-
- points(Coordinate...) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
Add a array of points to the shell of the polygon
- points - Variable in class org.elasticsearch.common.geo.builders.PointCollection
-
- points(Coordinate...) - Method in class org.elasticsearch.common.geo.builders.PointCollection
-
Add a array of points to the collection
- points(Collection<? extends Coordinate>) - Method in class org.elasticsearch.common.geo.builders.PointCollection
-
Add a collection of points to the collection
- POINTS - Static variable in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
- POINTS - Static variable in class org.elasticsearch.index.query.GeoPolygonQueryParser
-
- points() - Method in class org.elasticsearch.index.search.geo.GeoPolygonQuery
-
- 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.geo.GeoShapeFieldMapper.Defaults
-
- pointsOnly() - Method in class org.elasticsearch.common.geo.XShapeCollection
-
- pointsOnly() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- policy(BackoffPolicy) - Method in class org.elasticsearch.action.bulk.Retry
-
- poll() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- poll(long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- pollLastQuery() - Method in class org.elasticsearch.search.profile.Profiler
-
Removes the last (e.g.
- polygon(GeometryFactory, Coordinate[][]) - Static method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- polygon(BasePolygonBuilder<?>) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- polygon(BasePolygonBuilder<?>) - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
- polygon() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
- polygon(ShapeBuilder.Orientation) - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
- PolygonBuilder - Class in org.elasticsearch.common.geo.builders
-
- PolygonBuilder() - Constructor for class org.elasticsearch.common.geo.builders.PolygonBuilder
-
- PolygonBuilder(ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.PolygonBuilder
-
- PolygonBuilder(ArrayList<Coordinate>, ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.PolygonBuilder
-
- polygons - Variable in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
- port - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- PorterStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- PorterStemTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PorterStemTokenFilterFactory
-
- 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
-
- PortugueseAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- PortugueseAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PortugueseAnalyzerProvider
-
- pos - Variable in class org.elasticsearch.common.io.FastCharArrayReader
-
The current buffer position.
- posIncAttr - Variable in class org.elasticsearch.search.suggest.SuggestUtils.TokenConsumer
-
- position(Coordinate, Coordinate, double) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
-
- 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 - Variable in class org.elasticsearch.search.lookup.TermPosition
-
- POSITION_INCREMENT_GAP - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
-
Post 2.0 default for position_increment_gap.
- POSITION_INCREMENT_GAP_PRE_2_0 - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
-
- positionIncrementGap - Variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
-
The distance between tokens from different values in the same field.
- positionIncrementGap(int) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
-
- positionIncrementGap(Version) - Static method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
-
The default position_increment_gap for a particular version of Elasticsearch.
- PositionIterator - Class in org.elasticsearch.search.lookup
-
- PositionIterator(IndexFieldTerm) - Constructor for class org.elasticsearch.search.lookup.PositionIterator
-
- positions(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the positions for each term if stored or skip.
- positions() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- positive(QueryBuilder) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
- POSITIVE_BYTES_SIZE - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- POSITIVE_INTEGER - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- post(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
-
- 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.bucket.BestBucketsDeferringCollector
-
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.BestDocsDeferringCollector
-
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
-
- postCollection() - Method in class org.elasticsearch.search.aggregations.BucketCollector
-
Post-collection callback.
- postCreate(Engine.Create) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after create index operation occurred.
- postCreate(Engine.Create, Throwable) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after create index operation occurred with exception.
- postCreate(Engine.Create) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- postCreate(Engine.Create, Throwable) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- postCreateUnderLock(Engine.Create) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after the indexing occurs, under a locking scheme to maintain
concurrent updates to the same doc.
- postCreateUnderLock(Engine.Create) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- postDelete(Engine.Delete) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after the delete operation occurred.
- postDelete(Engine.Delete, Throwable) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after the delete operation occurred with exception.
- postDelete(Engine.Delete) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- postDelete(Engine.Delete, Throwable) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- postDeleteUnderLock(Engine.Delete) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after the delete occurs, under a locking scheme to maintain
concurrent updates to the same doc.
- postDeleteUnderLock(Engine.Delete) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- 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(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- postFilter(byte[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- postFilter(byte[], int, int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- postFilter(BytesReference) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- postFilter(XContentBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Constructs a new search source builder with a query from a builder.
- postFilter(Map) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Constructs a new search source builder with a query from a map.
- postFilter(DirectCandidateGenerator.Candidate, CharsRefBuilder, BytesRefBuilder, List<DirectCandidateGenerator.Candidate>) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
-
- postFilter(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
Sets a filter (analyzer) that is applied to each of the generated tokens
before they are passed to the actual phrase scorer.
- PostFilterParseElement - Class in org.elasticsearch.search.query
-
- PostFilterParseElement() - Constructor for class org.elasticsearch.search.query.PostFilterParseElement
-
- postIndex(Engine.Index) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after the indexing operation occurred.
- postIndex(Engine.Index, Throwable) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after the indexing operation occurred with exception.
- postIndex(Engine.Index) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- postIndex(Engine.Index, Throwable) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- postIndexUnderLock(Engine.Index) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called after the indexing occurs, under a locking scheme to maintain
concurrent updates to the same doc.
- postIndexUnderLock(Engine.Index) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- postings(PostingsEnum, int) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
-
- postingsFormat(PostingsFormat) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- PostingsHighlighter - Class in org.elasticsearch.search.highlight
-
- PostingsHighlighter() - Constructor for class org.elasticsearch.search.highlight.PostingsHighlighter
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
-
- postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
-
- postPercolate(long) - Method in class org.elasticsearch.index.percolator.stats.ShardPercolateService
-
- postProcess(MapperService) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
-
- postProcess(DocumentMapper) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
-
- postProcess(MappedFieldType) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
-
- postRecovery(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
- postSuggest(long) - Method in class org.elasticsearch.index.suggest.stats.ShardSuggestMetric
-
Called after suggest
- postTags(String...) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
Explicitly set the post tags for this field that will be used for highlighting.
- postTags(String...) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
Explicitly set the post tags that will be used for highlighting.
- postTags() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- pow(Short, Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- pow(Integer, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- pow(Float, Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- pow(Long, Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- pow(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- pre(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
-
- PRE_20_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
-
- 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, AnalyzerScope, Analyzer) - Constructor for class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
-
- PreBuiltAnalyzers - Enum in org.elasticsearch.indices.analysis
-
- PreBuiltCacheFactory - Class in org.elasticsearch.indices.analysis
-
- PreBuiltCacheFactory.PreBuiltCache<T> - Interface in org.elasticsearch.indices.analysis
-
- PreBuiltCharFilterFactoryFactory - Class in org.elasticsearch.index.analysis
-
- PreBuiltCharFilterFactoryFactory(CharFilterFactory) - Constructor for class org.elasticsearch.index.analysis.PreBuiltCharFilterFactoryFactory
-
- PreBuiltCharFilters - Enum in org.elasticsearch.indices.analysis
-
- PreBuiltSimilarityProvider - Class in org.elasticsearch.index.similarity
-
- PreBuiltSimilarityProvider(String, Similarity) - Constructor for class org.elasticsearch.index.similarity.PreBuiltSimilarityProvider
-
- PreBuiltSimilarityProvider.Factory - Class in org.elasticsearch.index.similarity
-
- PreBuiltTokenFilterFactoryFactory - Class in org.elasticsearch.index.analysis
-
- PreBuiltTokenFilterFactoryFactory(TokenFilterFactory) - Constructor for class org.elasticsearch.index.analysis.PreBuiltTokenFilterFactoryFactory
-
- PreBuiltTokenFilters - Enum in org.elasticsearch.indices.analysis
-
- PreBuiltTokenizerFactoryFactory - Class in org.elasticsearch.index.analysis
-
- PreBuiltTokenizerFactoryFactory(TokenizerFactory) - Constructor for class org.elasticsearch.index.analysis.PreBuiltTokenizerFactoryFactory
-
- PreBuiltTokenizers - Enum in org.elasticsearch.indices.analysis
-
- precision() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapperLegacy.Encoding
-
- precision(int) - Method in class org.elasticsearch.index.query.GeohashCellQuery.Builder
-
- precision(String) - Method in class org.elasticsearch.index.query.GeohashCellQuery.Builder
-
- PRECISION - Static variable in class org.elasticsearch.index.query.GeohashCellQuery
-
- precision(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridBuilder
-
Set the geohash precision to use for this aggregation.
- precision() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
-
- precision(String) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
-
Set the precision use o make suggestions
- precision(double, DistanceUnit) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
-
Set the precision use o make suggestions
- precision(double) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
-
Set the precision use o make suggestions
- precision(int) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
-
Set the precision use o make suggestions
- PRECISION_STEP_16_BIT - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
-
- PRECISION_STEP_32_BIT - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
-
- PRECISION_STEP_64_BIT - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
-
- PRECISION_STEP_8_BIT - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
-
- 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.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- precisionStep(int) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
-
- precisionStep - Variable in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- precisionStep(int) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.Builder
-
- precisionThreshold(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityBuilder
-
Set a precision threshold.
- preCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.BestDocsDeferringCollector
-
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
-
- preCollection() - Method in class org.elasticsearch.search.aggregations.BucketCollector
-
Pre collection callback.
- 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
-
- preCreate(Engine.Create) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called before the indexing occurs.
- preCreate(Engine.Create) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- preDelete(Engine.Delete) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called before the delete occurs.
- preDelete(Engine.Delete) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- predict(Collection<T>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModel
-
Predicts the next `n` values in the series.
- predict(int) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgBuilder
-
Sets the number of predictions that should be returned.
- PREDICT - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgParser
-
- preferAttributesActiveInitializingShardsIt(String[], DiscoveryNodes) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
- preferAttributesActiveInitializingShardsIt(String[], DiscoveryNodes, int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
- preference(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
Sets the preference to execute the search.
- preference() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
- preference(String) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
- preference() - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
- preference(String) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
Routing preference for executing the search on shards
- preference() - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
- preference() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- 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() - Method in class org.elasticsearch.action.get.GetRequest
-
- preference(String) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
Sets the preference to execute the search.
- preference() - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- preference(String) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
Sets the preference to execute the search.
- preference() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
- preference() - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- preference(String) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
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() - Method in class org.elasticsearch.action.search.SearchRequest
-
- preference(String) - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
- preference() - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
- preference() - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyRequest
-
- preference(String) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
-
Sets the preference to execute the search.
- preference() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
-
- preference - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- preference() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- 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(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
- PREFERRED_ENCODING - Static variable in class org.elasticsearch.common.Base64
-
Preferred encoding.
- preferredName() - Method in enum org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
-
- preFilter(BytesRef, CharsRefBuilder, BytesRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
-
- preFilter(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
Sets a filter (analyzer) that is applied to each of the tokens passed to this candidate generator.
- PREFIX - Static variable in class org.elasticsearch.client.support.Headers
-
- PREFIX_LENGTH - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
-
- PrefixAnalyzer - Class in org.apache.lucene.analysis
-
This Analyzer
wraps another analyzer and adds a set of prefixes to the
underlying TokenStream.
- PrefixAnalyzer(Analyzer, char, CharSequence) - Constructor for class org.apache.lucene.analysis.PrefixAnalyzer
-
- PrefixAnalyzer(Analyzer, char, Iterable<? extends CharSequence>) - Constructor for class org.apache.lucene.analysis.PrefixAnalyzer
-
- PrefixAnalyzer.PrefixTokenFilter - Class in org.apache.lucene.analysis
-
- prefixLength(int) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
-
- prefixLength(int) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
- prefixLength(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
- prefixLength() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- prefixLength(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- prefixLength(int) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
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(String, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- prefixQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing terms with a specified prefix.
- 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.
- PrefixQueryParser - Class in org.elasticsearch.index.query
-
- PrefixQueryParser() - Constructor for class org.elasticsearch.index.query.PrefixQueryParser
-
- PrefixTokenFilter(TokenStream, char, Iterable<? extends CharSequence>) - Constructor for class org.apache.lucene.analysis.PrefixAnalyzer.PrefixTokenFilter
-
- preflightResponseHeader(CharSequence, Object...) - Method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
Returns HTTP response headers that should be added to a CORS preflight response.
- preflightResponseHeader(CharSequence, Iterable<T>) - Method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
Returns HTTP response headers that should be added to a CORS preflight response.
- preflightResponseHeader(CharSequence, Callable<T>) - Method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
Returns HTTP response headers that should be added to a CORS preflight response.
- preflightResponseHeaders() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
Returns HTTP response headers that should be added to a CORS preflight response.
- preIndex(Engine.Index) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
-
Called before the indexing occurs.
- preIndex(Engine.Index) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- prepare(UpdateRequest, IndexShard) - 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(UpdateRequest, GetResult) - 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_TRANSLOG - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.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.
- prepareAnalyze(String, String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- prepareAnalyze(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text.
- prepareAnalyze() - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text/texts.
- prepareBackground(AggregationContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
-
Creates the TermsEnum (if not already created) and must be called before any calls to getBackgroundFrequency
- prepareBulk() - Method in interface org.elasticsearch.client.Client
-
Executes a bulk of index / delete operations.
- prepareBulk() - 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
-
- prepareCommit() - Method in class org.elasticsearch.index.translog.Translog
-
- prepareCount(String...) - Method in interface org.elasticsearch.client.Client
-
- prepareCount(String...) - Method in class org.elasticsearch.client.support.AbstractClient
-
- prepareCreate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Creates an index using an explicit request allowing to specify the settings of the index.
- prepareCreateOnPrimary(SourceToParse, long, VersionType, boolean, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
- prepareCreateOnReplica(SourceToParse, long, VersionType, boolean, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
- 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(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...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index based on the index name.
- prepareDelete() - Method in class org.elasticsearch.client.support.AbstractClient
-
- prepareDelete(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
-
- prepareDeleteIndexedScript() - Method in interface org.elasticsearch.client.Client
-
Delete an indexed script
- prepareDeleteIndexedScript(String, String) - Method in interface org.elasticsearch.client.Client
-
Delete an indexed script
- prepareDeleteIndexedScript() - Method in class org.elasticsearch.client.support.AbstractClient
-
Delete an indexed script
- prepareDeleteIndexedScript(String, String) - Method in class org.elasticsearch.client.support.AbstractClient
-
Delete an indexed script
- prepareDeleteOnPrimary(String, String, long, VersionType) - Method in class org.elasticsearch.index.shard.IndexShard
-
- prepareDeleteOnReplica(String, String, long, VersionType) - Method in class org.elasticsearch.index.shard.IndexShard
-
- prepareDeleteRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Unregisters a repository.
- prepareDeleteSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete snapshot.
- prepareDeleteTemplate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index template.
- prepareDeleteWarmer() - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index warmer.
- prepareEnvironment(Settings, Terminal) - Static method in class org.elasticsearch.node.internal.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.Client
-
- prepareExists(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices exists.
- prepareExists(String...) - Method in class org.elasticsearch.client.support.AbstractClient
-
- 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
-
- prepareFieldStats() - Method in interface org.elasticsearch.client.Client
-
- prepareFieldStats() - 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 mergee 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
- prepareGet() - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type and id.
- 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() - Method in class org.elasticsearch.client.support.AbstractClient
-
- 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.
- prepareGetIndexedScript() - Method in interface org.elasticsearch.client.Client
-
Get an indexed script
- prepareGetIndexedScript(String, String) - Method in interface org.elasticsearch.client.Client
-
Get the indexed script
- prepareGetIndexedScript() - Method in class org.elasticsearch.client.support.AbstractClient
-
- prepareGetIndexedScript(String, String) - Method in class org.elasticsearch.client.support.AbstractClient
-
- prepareGetMappings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- 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.
- prepareGetTemplates(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Gets an index template (optional).
- prepareGetWarmers(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Returns a new builder to fetch index warmer metadata for the given indices.
- 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(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 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 class org.elasticsearch.client.support.AbstractClient
-
- prepareIndex(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
-
- prepareIndexOnPrimary(SourceToParse, long, VersionType, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
- prepareIndexOnReplica(SourceToParse, long, VersionType, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
- prepareIndexOperationOnPrimary(BulkShardRequest, IndexRequest, IndexShard) - Static method in class org.elasticsearch.action.index.TransportIndexAction
-
Utility method to create either an index or a create operation depending
on the
IndexRequest.OpType
of the request.
- 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
-
- prepareMultiPercolate() - Method in interface org.elasticsearch.client.Client
-
Performs multiple percolate requests.
- prepareMultiPercolate() - 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.
- 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.
- preparePercolate() - Method in interface org.elasticsearch.client.Client
-
Percolates a request returning the matches documents.
- preparePercolate() - Method in class org.elasticsearch.client.support.AbstractClient
-
- preparePutIndexedScript() - Method in interface org.elasticsearch.client.Client
-
Put an indexed script
- preparePutIndexedScript(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Put the indexed script
- preparePutIndexedScript() - Method in class org.elasticsearch.client.support.AbstractClient
-
Put an indexed script
- preparePutIndexedScript(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
-
Put the indexed script
- preparePutMapping(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- preparePutRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Registers a snapshot repository.
- preparePutTemplate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- preparePutWarmer(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index search warmer to be applies when applicable.
- 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).
- prepareRenderSearchTemplate() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Return the rendered search request for a given search template.
- prepareReroute() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Update settings in the cluster.
- prepareRestoreSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restores a snapshot.
- 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.BestDocsDeferringCollector
-
- prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
- prepareSettings(Settings) - Static method in class org.elasticsearch.node.internal.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.
- prepareSnapshotStatus(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- prepareSnapshotStatus() - 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.
- prepareSuggest(String...) - Method in interface org.elasticsearch.client.Client
-
Suggestions matching a specific phrase.
- prepareSuggest(String...) - Method in class org.elasticsearch.client.support.AbstractClient
-
- prepareSyncedFlush(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly sync flush one or more indices (write sync id to shards for faster recovery).
- prepareTargetForTranslog(Translog.View) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
- prepareTermVector() - Method in interface org.elasticsearch.client.Client
-
Deprecated.
- prepareTermVector(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Deprecated.
- prepareTermVector() - Method in class org.elasticsearch.client.support.AbstractClient
-
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(String, String, String) - 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 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(String, String, String) - 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 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.internal.AllFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
-
- preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
-
- prePercolate() - Method in class org.elasticsearch.index.percolator.stats.ShardPercolateService
-
- preProcess() - Method in class org.elasticsearch.percolator.PercolateContext
-
- 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() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
Should be called before executing the main query and after all other parameters have been set.
- preProcess() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- preProcess() - Method in class org.elasticsearch.search.internal.SearchContext
-
Should be called before executing the main query and after all other parameters have been set.
- preProcess() - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- preProcess(SearchContext) - Method in class org.elasticsearch.search.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.core.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.core.CompletionFieldMapper.Fields
-
- preservePositionIncrements(boolean) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Builder
-
- preserveSeparators(boolean) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Builder
-
- PreShardSyncedFlushRequest() - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
-
- PreShardSyncedFlushRequest(ShardId) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
-
- preSuggest() - Method in class org.elasticsearch.index.suggest.stats.ShardSuggestMetric
-
Called before suggest
- preTags(String...) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
Explicitly set the pre tags for this field that will be used for highlighting.
- preTags(String...) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
Explicitly set the pre tags that will be used for highlighting.
- preTags() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- prettyPrint() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
-
- prettyPrint() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
- prettyPrint() - Method in class org.elasticsearch.cluster.ClusterState
-
- prettyPrint() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
- prettyPrint() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
- prettyPrint() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
- prettyPrint() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- prettyPrint() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- prettyPrint() - Method in class org.elasticsearch.common.StopWatch
-
Return a string with a table describing all tasks performed.
- prettyPrint() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- 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.
- primary() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- primary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns true
iff this shard is a primary.
- primary - Variable in class org.elasticsearch.index.shard.ShardStateMetaData
-
- primaryActiveInitializingShardIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
- 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
-
- primaryShard() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
- PrimaryShardAllocator - Class in org.elasticsearch.gateway
-
The primary shard allocator allocates primary shard that were not created as
a result of an API to a node that held them last to be recovered.
- PrimaryShardAllocator(Settings) - 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
-
- print(CliToolConfig, Terminal) - Method in class org.elasticsearch.common.cli.HelpPrinter
-
- print(String, CliToolConfig.Cmd, Terminal) - Method in class org.elasticsearch.common.cli.HelpPrinter
-
- print(String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
-
- print(Terminal.Verbosity, String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
-
- printer() - Method in class org.elasticsearch.common.joda.FormatDateTimeFormatter
-
- printError(String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
-
- printError(Throwable) - Method in class org.elasticsearch.common.cli.Terminal
-
- println() - Method in class org.elasticsearch.common.cli.Terminal
-
- println(String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
-
- println(Terminal.Verbosity) - Method in class org.elasticsearch.common.cli.Terminal
-
- println(Terminal.Verbosity, String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
-
- printStackTrace(Throwable) - Method in class org.elasticsearch.common.cli.Terminal
-
- printTo(StringBuffer, long, Chronology, int, DateTimeZone, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
- printTo(Writer, long, Chronology, int, DateTimeZone, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
- printTo(StringBuffer, ReadablePartial, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
- printTo(Writer, ReadablePartial, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
- printUsage(Terminal) - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd
-
- printUsage(Terminal) - Method in class org.elasticsearch.common.cli.CliToolConfig
-
- printWarn(String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
-
- 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() - Method in class org.elasticsearch.cluster.BasicClusterStateTaskConfig
-
- 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 - Class in org.elasticsearch.common
-
- priority() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedCallable
-
- priority - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
-
- priority() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
-
- 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
-
- 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, ActionRequest, ActionListener) - Method in interface org.elasticsearch.action.support.ActionFilterChain
-
Continue processing the request.
- proceed(String, ActionResponse, ActionListener) - Method in interface org.elasticsearch.action.support.ActionFilterChain
-
Continue processing the response.
- process() - 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.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.stats.NodesStatsRequest
-
Should the node Process be returned.
- process(MetaData, MappingMetaData, boolean, String) - Method in class org.elasticsearch.action.index.IndexRequest
-
- process(RestRequest, RestChannel, RestFilterChain) - Method in class org.elasticsearch.rest.RestFilter
-
Process the rest request.
- process(ValueParser, SearchContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
-
- processAfterWrite(boolean, IndexShard, Translog.Location) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- processAllocation(RoutingAllocation) - Method in class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
-
Process any changes needed to the allocation based on this fetch result.
- processAnalyzer(String, Class<? extends AnalyzerProvider>) - Method in class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.AnalyzersBindings
-
- processAnalyzers(AnalysisModule.AnalysisBinderProcessor.AnalyzersBindings) - Method in class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
-
- processAsyncFetch(ShardId, T[], FailedNodeException[]) - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
Called by the response handler of the async action to fetch data.
- processCharFilter(String, Class<? extends CharFilterFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.CharFiltersBindings
-
- processCharFilters(AnalysisModule.AnalysisBinderProcessor.CharFiltersBindings) - Method in class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
-
- ProcessClusterEventTimeoutException - Exception in org.elasticsearch.cluster.metadata
-
- ProcessClusterEventTimeoutException(TimeValue, String) - Constructor for exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
-
- ProcessClusterEventTimeoutException(StreamInput) - 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.
- processedFiles(int, long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Sets processed files stats
- processedFiles() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Number of processed files
- processedSize() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Size of processed files
- 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(ObjectMapper.Builder, String, Object) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.TypeParser
-
- ProcessInfo - Class in org.elasticsearch.monitor.process
-
- ProcessInfo(long, boolean) - Constructor for class org.elasticsearch.monitor.process.ProcessInfo
-
- processInfo() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
- processMessageReceived(Request, TransportChannel) - Method in class org.elasticsearch.transport.RequestHandlerRegistry
-
- processModule(Module) - Method in interface org.elasticsearch.common.inject.PreProcessModule
-
- processModule(Module) - Method in class org.elasticsearch.plugins.PluginsService
-
- processModules(Iterable<Module>) - Method in class org.elasticsearch.plugins.PluginsService
-
- PROCESSORS - Static variable in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Settings key to manually set the number of available processors.
- processPendingDeletes(Index, Settings, TimeValue) - Method in class org.elasticsearch.indices.IndicesService
-
Processes all pending deletes for the given index.
- ProcessProbe - Class in org.elasticsearch.monitor.process
-
- processResponse(Response) - Method in class org.elasticsearch.rest.action.support.RestActionListener
-
- processResponse(Response) - Method in class org.elasticsearch.rest.action.support.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, ProcessProbe) - Constructor for class org.elasticsearch.monitor.process.ProcessService
-
- processSettings(Settings) - Static method in class org.elasticsearch.tribe.TribeService
-
- ProcessStats() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
-
- processStats() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
- ProcessStats - Class in org.elasticsearch.monitor.process
-
- 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
-
- processTokenFilter(String, Class<? extends TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.TokenFiltersBindings
-
- processTokenFilters(AnalysisModule.AnalysisBinderProcessor.TokenFiltersBindings) - Method in class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
-
- processTokenizer(String, Class<? extends TokenizerFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.TokenizersBindings
-
- processTokenizers(AnalysisModule.AnalysisBinderProcessor.TokenizersBindings) - Method in class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
-
- profile(boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should the query be profiled.
- profile() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Return whether to profile query execution, or null
if
unspecified.
- profile() - Method in class org.elasticsearch.search.internal.InternalSearchResponse
-
Returns the profile results for this search response (including all shards).
- profileAddresses() - Method in class org.elasticsearch.transport.TransportInfo
-
- profileBoundAddresses() - Method in class org.elasticsearch.transport.local.LocalTransport
-
- profileBoundAddresses - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- profileBoundAddresses() - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- profileBoundAddresses() - Method in interface org.elasticsearch.transport.Transport
-
Further profile bound addresses
- ProfileBreakdown - Class in org.elasticsearch.search.profile
-
A record of timings for the various operations that may happen during query execution.
- ProfileBreakdown() - Constructor for class org.elasticsearch.search.profile.ProfileBreakdown
-
Sole constructor.
- ProfileBreakdown.TimingType - Enum in org.elasticsearch.search.profile
-
Enumeration of all supported timing types.
- profileName - Variable in class org.elasticsearch.transport.netty.MessageChannelHandler
-
- ProfileParseElement - Class in org.elasticsearch.search.profile
-
- ProfileParseElement() - Constructor for class org.elasticsearch.search.profile.ProfileParseElement
-
- Profiler - Class in org.elasticsearch.search.profile
-
This class acts as a thread-local storage for profiling a query.
- Profiler() - Constructor for class org.elasticsearch.search.profile.Profiler
-
- profileResults() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns the profiled results for this search, or potentially null if result was empty
- profileResults(List<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 several
Profiler
s that makes management easier.
- Profilers(ContextIndexSearcher) - Constructor for class org.elasticsearch.search.profile.Profilers
-
Sole constructor.
- ProfileShardResult - Class in org.elasticsearch.search.profile
-
A container class to hold the profile results for a single shard in the request.
- ProfileShardResult(List<ProfileResult>, long, CollectorResult) - Constructor for class org.elasticsearch.search.profile.ProfileShardResult
-
- ProfileShardResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.ProfileShardResult
-
- ProfileWeight - Class in org.elasticsearch.search.profile
-
Weight wrapper that will compute how much time it takes to build the
Scorer
and then return a Scorer
that is wrapped in
order to compute timings as well.
- ProfileWeight(Query, Weight, ProfileBreakdown) - Constructor for class org.elasticsearch.search.profile.ProfileWeight
-
- PropertiesSettingsLoader - Class in org.elasticsearch.common.settings.loader
-
Settings loader that loads (parses) the settings in a properties format.
- PropertiesSettingsLoader() - Constructor for class org.elasticsearch.common.settings.loader.PropertiesSettingsLoader
-
- PROPERTY_SUPPORT_STAGING_URLS - Static variable in class org.elasticsearch.plugins.PluginManager
-
- PropertyPlaceholder - Class in org.elasticsearch.common.property
-
Utility class for working with Strings that have placeholder values in them.
- PropertyPlaceholder(String, String) - Constructor for class org.elasticsearch.common.property.PropertyPlaceholder
-
Creates a new PropertyPlaceholderHelper
that uses the supplied prefix and suffix.
- PropertyPlaceholder(String, String, boolean) - Constructor for class org.elasticsearch.common.property.PropertyPlaceholder
-
Creates a new PropertyPlaceholderHelper
that uses the supplied prefix and suffix.
- PropertyPlaceholder.PlaceholderResolver - Interface in org.elasticsearch.common.property
-
Strategy interface used to resolve replacement values for placeholders contained in Strings.
- PROTO - Static variable in class org.elasticsearch.cluster.block.ClusterBlocks
-
- PROTO - Static variable in class org.elasticsearch.cluster.ClusterState
-
- PROTO - Static variable in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- PROTO - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- PROTO - Static variable in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- PROTO - Static variable in class org.elasticsearch.cluster.metadata.MappingMetaData
-
- PROTO - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- PROTO - Static variable in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
- PROTO - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodes
-
- PROTO - Static variable in class org.elasticsearch.cluster.RestoreInProgress
-
- PROTO - Static variable in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
- PROTO - Static variable in class org.elasticsearch.cluster.routing.RoutingTable
-
- PROTO - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress
-
- PROTO - Static variable in class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- PROTO - Static variable in class org.elasticsearch.common.transport.LocalTransportAddress
-
- PROTO - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
- PROTO - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
- PROTO - Static variable in class org.elasticsearch.search.warmer.IndexWarmersMetaData
-
- PROTO - Static variable in class org.elasticsearch.snapshots.Snapshot
-
- PROTOTYPE - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
- PROTOTYPE - Static variable in class org.elasticsearch.action.support.replication.ReplicationTask.Status
-
- PrototypeReader(T) - Constructor for class org.elasticsearch.cluster.DiffableUtils.PrototypeReader
-
- 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(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Provider<? extends T>, Set<InjectionPoint>) - Constructor for class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
-
- ProviderInstanceBindingImpl(Object, Key<T>, Scoping, Set<InjectionPoint>, Provider<? extends T>) - 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 type
elementType
.
- 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, Throwable) - Constructor for exception org.elasticsearch.common.inject.ProvisionException
-
- ProvisionException(String) - Constructor for exception org.elasticsearch.common.inject.ProvisionException
-
- 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, 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.DiscoveryService
-
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.local.LocalDiscovery
-
- publish(ClusterChangedEvent, Discovery.AckListener) - Method in class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
-
- publish(ClusterChangedEvent, Discovery.AckListener) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- PUBLISH_DIFF_ENABLE - Static variable in class org.elasticsearch.discovery.DiscoverySettings
-
- PUBLISH_TIMEOUT - Static variable in class org.elasticsearch.discovery.DiscoverySettings
-
- publishAddress() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
-
- PublishClusterStateAction - Class in org.elasticsearch.discovery.zen.publish
-
- PublishClusterStateAction(Settings, TransportService, DiscoveryNodesProvider, PublishClusterStateAction.NewClusterStateListener, DiscoverySettings) - Constructor for class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
-
- PublishClusterStateAction.NewClusterStateListener - Interface in org.elasticsearch.discovery.zen.publish
-
- PublishClusterStateAction.NewClusterStateListener.NewStateProcessed - Interface in org.elasticsearch.discovery.zen.publish
-
- publishHosts - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- 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.Builder) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- put(IndexTemplateMetaData) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- put(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
-
- put(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- put(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- put(K, V) - Method in class org.elasticsearch.common.collect.MapBuilder
-
- put(Object...) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Puts tuples of key value pairs of settings.
- put(String, String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a setting with the provided setting key and value.
- put(String, Class) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a setting with the provided setting key and class as value.
- 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, int) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the int value.
- put(String, Version) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
- 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, float) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the float 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, 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, String, String[], String[]) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting group.
- put(Settings) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets all the provided settings.
- put(Map<String, String>) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets all the provided settings.
- put(Properties) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets all the provided settings.
- put(BytesRef) - Method in class org.elasticsearch.common.util.BloomFilter
-
- put(long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- 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(E) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- 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(K, V) - Method in class org.elasticsearch.common.util.MinimalMap
-
- 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(Object, Object) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
-
- put(Object, Object) - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
-
- put(Object, Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- putAlias(AliasMetaData) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- putAlias(AliasMetaData.Builder) - 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.IndexTemplateMetaData.Builder
-
- putAll(Map<Integer, VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
Puts all the entries in the map to the builder.
- putAll(IntObjectAssociativeContainer<? extends VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- putAll(Iterable<? extends IntObjectCursor<? extends VType>>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- putAll(Map<KType, VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
Puts all the entries in the map to the builder.
- putAll(ObjectObjectAssociativeContainer<? extends KType, ? extends VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- putAll(Iterable<? extends ObjectObjectCursor<? extends KType, ? extends VType>>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- putAll(Map<K, V>) - Method in class org.elasticsearch.common.collect.MapBuilder
-
- putAll(Map<? extends Long, ? extends T>) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.common.util.MinimalMap
-
- putAll(Map) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
-
- putAll(Map) - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
-
- putAll(Map) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- putAllInContext(ObjectObjectAssociativeContainer<Object, Object>) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- putAllInContext(ObjectObjectAssociativeContainer<Object, Object>) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- putAllInContext(ObjectObjectAssociativeContainer<Object, Object>) - Method in interface org.elasticsearch.common.HasContext
-
Attaches the given values to the context
- putAllInContext(ObjectObjectAssociativeContainer<Object, Object>) - Method in class org.elasticsearch.percolator.PercolateContext
-
- putArray(String, String...) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and an array of values.
- putAttribute(String, String) - Method in class org.elasticsearch.node.service.NodeService
-
- putContext(SearchContext) - Method in class org.elasticsearch.search.SearchService
-
- putCustom(String, ClusterState.Custom) - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- putCustom(String, IndexMetaData.Custom) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- putCustom(String, IndexMetaData.Custom) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- putCustom(String, MetaData.Custom) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- putHeader(String, Object) - Method in class org.elasticsearch.action.ActionRequestBuilder
-
- putHeader(String, Object) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- putHeader(String, V) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- putHeader(String, V) - Method in interface org.elasticsearch.common.HasHeaders
-
- putHeader(String, V) - Method in class org.elasticsearch.percolator.PercolateContext
-
- putIfAbsent(long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- putIfAbsent(Long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- putIfAbsent(long, T) - Method in interface org.elasticsearch.common.util.concurrent.ConcurrentMapLong
-
- putInContext(Object, Object) - Method in class org.elasticsearch.common.ContextAndHeaderHolder
-
- putInContext(Object, Object) - Method in class org.elasticsearch.common.DelegatingHasContextAndHeaders
-
- putInContext(Object, Object) - Method in interface org.elasticsearch.common.HasContext
-
Attaches the given value to the context.
- putInContext(Object, Object) - Method in class org.elasticsearch.percolator.PercolateContext
-
- putIndexedScript(PutIndexedScriptRequest, ActionListener<PutIndexedScriptResponse>) - Method in interface org.elasticsearch.client.Client
-
Put an indexed script
- putIndexedScript(PutIndexedScriptRequest) - Method in interface org.elasticsearch.client.Client
-
Put an indexed script
- putIndexedScript(PutIndexedScriptRequest, ActionListener<PutIndexedScriptResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
Put an indexed script
- putIndexedScript(PutIndexedScriptRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
Put an indexed script
- PutIndexedScriptAction - Class in org.elasticsearch.action.indexedscripts.put
-
- PutIndexedScriptRequest - Class in org.elasticsearch.action.indexedscripts.put
-
Index request to index a script to the script index and make it available at search time.
- PutIndexedScriptRequest() - Constructor for class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- PutIndexedScriptRequest(String) - Constructor for class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Constructs a new index request against the specific index and type.
- PutIndexedScriptRequest(String, String) - Constructor for class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Constructs a new index request against the index, type, id and using the source.
- PutIndexedScriptRequestBuilder - Class in org.elasticsearch.action.indexedscripts.put
-
An index document action request builder.
- PutIndexedScriptRequestBuilder(ElasticsearchClient, PutIndexedScriptAction) - Constructor for class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
- PutIndexedScriptResponse - Class in org.elasticsearch.action.indexedscripts.put
-
A response of an index operation,
- PutIndexedScriptResponse() - Constructor for class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
-
- PutIndexedScriptResponse(String, String, long, boolean) - Constructor for class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
-
- 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
-
- PutIndexTemplateResponse - Class in org.elasticsearch.action.admin.indices.template.put
-
A response for a put index template action.
- putMapper(Mapper) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- putMapping(PutMappingRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- putMapping(PutMappingRequest, ActionListener<PutMappingResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- putMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- putMapping(MappingMetaData) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- putMapping(String, CompressedXContent) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.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(PutMappingClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
-
- 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
- PutMappingRequest - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Puts mapping definition registered under a specific type into one or more indices.
- PutMappingRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
- PutMappingRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Constructs a new put mapping request against one or more indices.
- putMappingRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Create a create 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
-
- PutMappingResponse - Class in org.elasticsearch.action.admin.indices.mapping.put
-
The response of put mapping operation.
- putProperties(String, Properties) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Puts all the properties with keys starting with the provided prefix.
- putProperties(String, Properties, String[]) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Puts all the properties with keys starting with the provided prefix.
- putRepository(PutRepositoryRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Registers a snapshot repository.
- putRepository(PutRepositoryRequest, ActionListener<PutRepositoryResponse>) - 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 - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Register repository request.
- PutRepositoryRequest() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
- PutRepositoryRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Constructs a new put repository request with the provided name.
- putRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Registers snapshot repository
- 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
- PutRepositoryResponse - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Register repository response
- PutRequest(String, String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
-
- PutResponse(boolean, IndexTemplateMetaData) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutResponse
-
- putScriptToIndex(PutIndexedScriptRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.script.ScriptService
-
- putTemplate(PutIndexTemplateRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- putTemplate(PutIndexTemplateRequest, ActionListener<PutIndexTemplateResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- putTemplate(MetaDataIndexTemplateService.PutRequest, MetaDataIndexTemplateService.PutListener) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService
-
- putWarmer(PutWarmerRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index search warmer to be applies when applicable.
- putWarmer(PutWarmerRequest, ActionListener<PutWarmerResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index search warmer to be applies when applicable.
- PutWarmerAction - Class in org.elasticsearch.action.admin.indices.warmer.put
-
Action for the admin/warmers/put API.
- PutWarmerRequest - Class in org.elasticsearch.action.admin.indices.warmer.put
-
A request that associates a
SearchRequest
with a name in the cluster that is
in-turn used to warm up indices before they are available for search.
- PutWarmerRequest() - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
- PutWarmerRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
Constructs a new warmer.
- PutWarmerRequestBuilder - Class in org.elasticsearch.action.admin.indices.warmer.put
-
- PutWarmerRequestBuilder(ElasticsearchClient, PutWarmerAction, String) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
-
- PutWarmerRequestBuilder(ElasticsearchClient, PutWarmerAction) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
-
- PutWarmerResponse - Class in org.elasticsearch.action.admin.indices.warmer.put
-
An acknowledged response of put warmer operation.
- 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
- 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
- raiseNodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- raiseNodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
-
- raiseNodeDisconnected(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- raiseNodeDisconnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
-
- RamAccountingTermsEnum - Class in org.elasticsearch.index.fielddata
-
TermsEnum
that takes a MemoryCircuitBreaker, 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.io.stream.BytesStreamOutput
-
Returns the number of bytes used by the underlying
ByteArray
- ramBytesUsed() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
-
Deprecated.
- 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.GeoPointArrayAtomicFieldData.Single
-
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointArrayLegacyAtomicFieldData.Single
-
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
-
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildAtomicFieldData
-
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.GlobalFieldData
-
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVBytesAtomicFieldData
-
- ramBytesUsed() - Method in class org.elasticsearch.index.translog.Translog.Location
-
- ramBytesUsed() - Method in class org.elasticsearch.indices.cache.request.IndicesRequestCache.Key
-
- ramBytesUsed() - Method in class org.elasticsearch.indices.cache.request.IndicesRequestCache.Value
-
- ramTree - Variable in class org.elasticsearch.index.engine.Segment
-
- random() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- 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.Strings
-
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.Strings
-
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
- randomDouble() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- randomFloat() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- randomFunction(int) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- randomFunction(long) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- randomFunction(String) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- randomInt() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- randomInt(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- randomLong() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- randomLong(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- RandomScoreFunction - Class in org.elasticsearch.common.lucene.search.function
-
- RandomScoreFunction() - Constructor for class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
-
Default constructor.
- 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.random
-
A function that computes a random score for the matched documents
- RandomScoreFunctionBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionBuilder
-
- RandomScoreFunctionParser - Class in org.elasticsearch.index.query.functionscore.random
-
- RandomScoreFunctionParser() - Constructor for class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionParser
-
- range(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Range
aggregation with the given name.
- Range(String, Object, Object) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder.Range
-
- Range(String, Double, Double) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder.Range
-
Create a new range.
- Range - Interface in org.elasticsearch.search.aggregations.bucket.range
-
A range
aggregation.
- Range(String, double, String, double, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
-
- Range.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.range
-
A bucket associated with a specific range
- RangeAggregator - Class in org.elasticsearch.search.aggregations.bucket.range
-
- RangeAggregator(String, AggregatorFactories, ValuesSource.Numeric, ValueFormat, InternalRange.Factory, List<RangeAggregator.Range>, boolean, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
-
- RangeAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.range
-
- RangeAggregator.Range - Class in org.elasticsearch.search.aggregations.bucket.range
-
- RangeAggregator.Unmapped - Class in org.elasticsearch.search.aggregations.bucket.range
-
- RangeBuilder - Class in org.elasticsearch.search.aggregations.bucket.range
-
- RangeBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
-
Sole constructor.
- RangeParser - Class in org.elasticsearch.search.aggregations.bucket.range
-
- RangeParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeParser
-
- rangeQuery(Object, Object, boolean, boolean) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- rangeQuery(Object, Object, boolean, boolean, DateTimeZone, DateMathParser) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- rangeQuery(Object, Object, boolean, boolean) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.DoubleFieldType
-
- rangeQuery(Object, Object, boolean, boolean) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- rangeQuery(Object, Object, boolean, boolean) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.LongFieldType
-
- rangeQuery(Object, Object, boolean, boolean) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- rangeQuery(Object, Object, boolean, boolean) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- rangeQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents within an range of terms.
- 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.
- RangeQueryParser - Class in org.elasticsearch.index.query
-
- RangeQueryParser() - Constructor for class org.elasticsearch.index.query.RangeQueryParser
-
- ranges - Variable in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
-
- rate(TimeUnit) - Method in class org.elasticsearch.common.metrics.EWMA
-
Returns the rate in the given units of time.
- RateLimitedFSDirectory - Class in org.apache.lucene.store
-
- RateLimitedFSDirectory(Directory, StoreRateLimiting.Provider, StoreRateLimiting.Listener) - Constructor for class org.apache.lucene.store.RateLimitedFSDirectory
-
- rateLimiter() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- rateLimiting() - Method in interface org.apache.lucene.store.StoreRateLimiting.Provider
-
- rateLimiting() - Method in class org.elasticsearch.index.store.FsDirectoryService
-
- rateLimiting() - Method in class org.elasticsearch.index.store.IndexStore
-
Returns the rate limiting, either of the index is explicitly configured, or
the node level one (defaults to the node level one).
- rateLimiting() - Method in class org.elasticsearch.indices.store.IndicesStore
-
- 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
-
- rateUnit() - Method in class org.elasticsearch.common.metrics.MeterMetric
-
- 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 class org.elasticsearch.search.aggregations.support.format.ValueFormat
-
- RAW - Static variable in interface org.elasticsearch.search.aggregations.support.format.ValueFormatter
-
- Raw() - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Raw
-
- RAW - Static variable in interface org.elasticsearch.search.aggregations.support.format.ValueParser
-
- rawField(String, InputStream) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- rawField(String, BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- rawPath() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
- rawPath() - Method in class org.elasticsearch.rest.RestRequest
-
The non decoded, raw path provided.
- rawValue(BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- 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) - Static method in class org.elasticsearch.action.fieldstats.FieldStats
-
- read(byte) - Static method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Comparison
-
- read(byte) - Static method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Property
-
- read() - Method in class org.elasticsearch.common.Base64.InputStream
-
Reads enough of the input stream to convert
to/from Base64 and returns the next byte.
- read(byte[], int, int) - Method in class org.elasticsearch.common.Base64.InputStream
-
- read(byte[], int, int, boolean) - Method in class org.elasticsearch.common.compress.CompressedIndexInput
-
Deprecated.
- read() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
- read(byte[], int, int) - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
- read(byte[], int, int, boolean) - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
- read() - Method in class org.elasticsearch.common.io.FastCharArrayReader
-
Reads a single character.
- read(char[], int, int) - Method in class org.elasticsearch.common.io.FastCharArrayReader
-
Reads characters into a portion of an array.
- read() - Method in class org.elasticsearch.common.io.FastStringReader
-
Reads a single character.
- read(char[], int, int) - Method in class org.elasticsearch.common.io.FastStringReader
-
Reads characters into a portion of an array.
- read() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
-
- read(byte[], int, int) - 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(byte[]) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
-
- read(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
-
- read(StreamInput) - Method in interface org.elasticsearch.common.io.stream.StreamInputReader
-
- read(char[], int, int) - Method in class org.elasticsearch.common.lucene.all.AllEntries
-
- read(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
-
- read() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
-
- read(StreamInput) - Static method in class org.elasticsearch.common.rounding.Rounding.Streams
-
- read(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() - Method in class org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream
-
- read(byte[], int, int) - Method in class org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream
-
- read() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
- read(byte[], int, int) - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
- read() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
-
- read(BufferedChecksumStreamInput) - Method in class org.elasticsearch.index.translog.LegacyTranslogReader
-
Deprecated.
- read(Translog.Location) - Method in class org.elasticsearch.index.translog.Translog
-
Read the Operation object from the given location.
- read(Translog.Location) - Method in class org.elasticsearch.index.translog.TranslogReader
-
- read(BufferedChecksumStreamInput) - Method in class org.elasticsearch.index.translog.TranslogReader
-
- 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) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicStreams
-
- read(StreamInput) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
-
- read(StreamInput) - Static method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModelStreams
-
- read(StreamInput) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueFormatterStreams
-
- read() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- read(byte[], int, int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- READ_WRITE - Static variable in enum org.elasticsearch.cluster.block.ClusterBlockLevel
-
- readAcknowledged(StreamInput) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
-
Reads the timeout value
- readAggregatedDfs(StreamInput) - Static method in class org.elasticsearch.search.dfs.AggregatedDfs
-
- readAggregations(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- readAliasAction(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.AliasAction
-
- readAllLines(InputStream) - Static method in class org.elasticsearch.common.io.Streams
-
- readAllLines(InputStream, Callback<String>) - Static method in class org.elasticsearch.common.io.Streams
-
- readAllocationExplanation(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
-
- 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
-
- readBlob(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Creates a new InputStream for the given blob name
- readBlob(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
-
- readBlob(String) - Method in class org.elasticsearch.common.blobstore.support.AbstractLegacyBlobContainer
-
Deprecated.
- readBlob(String) - Method in class org.elasticsearch.common.blobstore.url.URLBlobContainer
-
- 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
-
- readBlob(BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.LegacyBlobStoreFormat
-
Reads and parses the blob with given name.
- readBoolean() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a boolean.
- 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.compress.CompressedIndexInput
-
Deprecated.
- readByte() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
- 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
-
- readByte() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- readByteArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.compress.CompressedIndexInput
-
Deprecated.
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
- 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.BufferingTranslogWriter
-
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.ImmutableTranslogReader
-
reads an operation at the given position into the given buffer.
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.TranslogReader
-
reads bytes at position into the given buffer, filling it.
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
- readBytes(byte[], int, int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- readBytesRef() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readBytesRef(int) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readBytesRef(int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- 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.
- readBytesReference(int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- readBytesSizeValue(StreamInput) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
-
- 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
-
- readClusterBlocks(StreamInput) - Static method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
-
- readClusterHealth(StreamInput) - Static method in class org.elasticsearch.cluster.health.ClusterStateHealth
-
- readClusterIndexHealth(StreamInput) - Static method in class org.elasticsearch.cluster.health.ClusterIndexHealth
-
- readClusterName(StreamInput) - Static method in class org.elasticsearch.cluster.ClusterName
-
- readCommitStatsFrom(StreamInput) - Static method in class org.elasticsearch.index.engine.CommitStats
-
- readCommonStats(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- readCommonStatsFlags(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- readCompletionStats(StreamInput) - Static method in class org.elasticsearch.search.suggest.completion.CompletionStats
-
- readCompressedString(StreamInput) - Static method in class org.elasticsearch.common.compress.CompressedXContent
-
- readCounts(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
-
- readCpu(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
-
- readDfsSearchResult(StreamInput) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- readDiffFrom(StreamInput) - Method in class org.elasticsearch.cluster.AbstractDiffable
-
- readDiffFrom(StreamableReader<T>, StreamInput) - Static method in class org.elasticsearch.cluster.AbstractDiffable
-
- readDiffFrom(StreamInput) - Method in class org.elasticsearch.cluster.ClusterState
-
- readDiffFrom(StreamInput) - Method in interface org.elasticsearch.cluster.Diffable
-
Reads the
Diff
from StreamInput
- readDiffFrom(StreamInput, String) - Method in interface org.elasticsearch.cluster.DiffableUtils.KeyedReader
-
reads an object that respresents differences between two objects with the type T from the stream input
- readDiffFrom(StreamInput, String) - Method in class org.elasticsearch.cluster.DiffableUtils.PrototypeReader
-
- readDiffFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- readDiffFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- readDiffFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- readDistanceUnit(StreamInput) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
-
- readDocStats(StreamInput) - Static method in class org.elasticsearch.index.shard.DocsStats
-
- 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
-
- reader() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
-
- reader() - Method in class org.elasticsearch.index.engine.Engine.Searcher
-
- reader() - Method in class org.elasticsearch.indices.IndicesWarmer.WarmerContext
-
- reader - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
-
- reader() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
-
- reader - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- 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.common.lucene.all.AllField
-
- readerValue() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
-
- readerValue() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
-
- readerVersion - Variable in class org.elasticsearch.indices.cache.request.IndicesRequestCache.Key
-
- 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.admin.indices.shards.IndicesShardStoresResponse.Failure
-
- 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
-
- readFieldDataStats(StreamInput) - Static method in class org.elasticsearch.index.fielddata.FieldDataStats
-
- 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
-
- readFile(StreamInput) - Static method in class org.elasticsearch.indices.recovery.RecoveryState.File
-
- 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.
- readFlushStats(StreamInput) - Static method in class org.elasticsearch.index.flush.FlushStats
-
- 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.ActionWriteResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- 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.NodesHotThreadsResponse
-
- 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.NodesInfoResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
-
- 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.stats.NodesStatsRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
-
- 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.cancel.CancelTasksRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
- 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.tasks.list.TaskInfo
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryResponse
-
- 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.put.PutRepositoryResponse
-
- 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.delete.DeleteSnapshotResponse
-
- 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.NodesSnapshotStatus
-
- 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.ClusterStatsIndices
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmVersion
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
-
- 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.tasks.PendingClusterTasksResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateResponse
-
- 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.AliasActions
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse
-
- 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.cache.clear.ClearIndicesCacheResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
-
- 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.delete.DeleteIndexResponse
-
- 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.mapping.put.PutMappingResponse
-
- 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.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.settings.put.UpdateSettingsResponse
-
- 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.stats.CommonStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- 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.delete.DeleteIndexTemplateResponse
-
- 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.template.put.PutIndexTemplateResponse
-
- 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.upgrade.post.UpgradeSettingsResponse
-
- 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.admin.indices.warmer.delete.DeleteWarmerRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
- 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.count.CountRequest
-
Deprecated.
- readFrom(StreamInput) - Method in class org.elasticsearch.action.count.CountResponse
-
Deprecated.
- readFrom(StreamInput) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.delete.DeleteResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
- readFrom(StreamInput) - Method in class org.elasticsearch.action.exists.ExistsResponse
-
Deprecated.
- readFrom(StreamInput) - Method in class org.elasticsearch.action.exists.ShardExistsRequest
-
- 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.fieldstats.FieldStats.Date
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Double
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Float
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Long
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Text
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStatsResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStatsShardRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.fieldstats.FieldStatsShardResponse
-
- 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.index.IndexResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse.Item
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.PercolateResponse.Match
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.PercolateResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Request
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response
-
- 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.ShardSearchFailure
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.suggest.ShardSuggestRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.suggest.SuggestResponse
-
- 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.ChildTaskActionRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.ChildTaskRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
-
- 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.ReplicationRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
-
- 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.BaseTasksRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.TaskOperationFailure
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.dfs.ShardDfsOnlyRequest
-
- 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.NodeIndexDeletedAction.NodeIndexDeletedMessage
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction.NodeIndexStoreDeletedMessage
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardRoutingEntry
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.block.ClusterBlock
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.ClusterName
-
- readFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
-
- readFrom(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.cluster.ClusterState
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.ClusterState
-
- readFrom(StreamInput, String) - Method in interface org.elasticsearch.cluster.DiffableUtils.KeyedReader
-
reads an object of the type T from the stream input
- readFrom(StreamInput, String) - Method in class org.elasticsearch.cluster.DiffableUtils.PrototypeReader
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Reads a copy of an object with the same type form the stream input
The caller object remains unchanged.
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
-
Reads repository metadata from stream input
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.SnapshotId
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
- readFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
-
- readFrom(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.RestoreInProgress
-
Reads a copy of an object with the same type form the stream input
The caller object remains unchanged.
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Reads restore status from stream input
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand.Factory
-
- readFrom(StreamInput) - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand.Factory
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand.Factory
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand.Factory
-
- 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.Builder
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.RestoreSource
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- readFrom(StreamInput, String, int) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
- 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.cluster.SnapshotsInProgress
-
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
-
- readFrom(StreamInput) - Method in interface org.elasticsearch.common.io.stream.Streamable
-
- readFrom(StreamInput) - Method in interface org.elasticsearch.common.io.stream.StreamableReader
-
Reads a copy of an object with the same type form the stream input
The caller object remains unchanged.
- readFrom(StreamInput) - Static method in class org.elasticsearch.common.Priority
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.rounding.Rounding.FactorRounding
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.rounding.Rounding.Interval
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.rounding.Rounding.OffsetRounding
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.transport.BoundTransportAddress
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.transport.DummyTransportAddress
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.transport.LocalTransportAddress
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.unit.SizeValue
-
- readFrom(StreamInput) - Method in class org.elasticsearch.common.unit.TimeValue
-
serialization converts TimeValue internally to NANOSECONDS
- readFrom(StreamInput) - Static method in class org.elasticsearch.common.util.BloomFilter
-
- readFrom(StreamInput) - Static method in enum org.elasticsearch.common.xcontent.XContentType
-
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection.MasterPingRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.PingRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction.JoinRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction.LeaveRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction.ValidateJoinRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing.UnicastPingRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
-
- 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.NodesGatewayMetaState
-
- 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.NodesGatewayStartedShards
-
- readFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
-
- readFrom(StreamInput) - Method in class org.elasticsearch.http.HttpInfo
-
- readFrom(StreamInput) - Method in class org.elasticsearch.http.HttpStats
-
- 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.Engine.CommitId
-
- 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.GetField
-
- 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.Index
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.indexing.IndexingStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.merge.MergeStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- 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.search.stats.SearchStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.shard.DocsStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.shard.ShardId
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.store.StoreFileMetaData
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.store.StoreStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.suggest.stats.SuggestStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.translog.Translog.Create
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.translog.Translog.Delete
-
- readFrom(StreamInput) - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
-
Deprecated.
- readFrom(StreamInput) - Method in class org.elasticsearch.index.translog.Translog.Index
-
- 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.breaker.AllCircuitBreakerStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
-
- 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.RecoveryPrepareForTranslogOperationsRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.store.IndicesStore.ShardActiveRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
-
- 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) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.fs.FsInfo
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsInfo
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsStats.Mem
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsStats.Swap
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.process.ProcessInfo
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
-
- readFrom(StreamInput) - Method in class org.elasticsearch.monitor.process.ProcessStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.plugins.PluginInfo
-
- 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) - Method in class org.elasticsearch.script.Script
-
- readFrom(StreamInput) - Static method in enum org.elasticsearch.script.ScriptService.ScriptType
-
- readFrom(StreamInput) - Method in class org.elasticsearch.script.ScriptStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction.ScrollFreeContextRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction.SearchFreeContextRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction.SearchFreeContextResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.BucketStreamContext
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters.Bucket
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
-
- readFrom(StreamInput) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- readFrom(StreamInput, BigArrays) - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
-
- 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.aggregations.pipeline.PipelineAggregator
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.BooleanFormatter
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.GeoHash
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.IPv4Formatter
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Number.Pattern
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Raw
-
- 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.source.FetchSourceContext
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.highlight.HighlightField
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalSearchHit.InternalNestedIdentity
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- readFrom(StreamInput, InternalSearchHits.StreamContext) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- readFrom(StreamInput, InternalSearchHits.StreamContext) - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalSearchResponse
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.profile.CollectorResult
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.profile.InternalProfileShardResults
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.profile.ProfileShardResult
-
- 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.Scroll
-
- readFrom(StreamInput) - Method in class org.elasticsearch.search.SearchShardTarget
-
- 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.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.search.warmer.IndexWarmersMetaData
-
- readFrom(StreamInput) - Method in class org.elasticsearch.snapshots.RestoreInfo
- readFrom(StreamInput) - Method in class org.elasticsearch.snapshots.RestoreService.UpdateIndexShardRestoreStatusRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
- 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.tasks.TaskId
-
- readFrom(StreamInput) - Method in class org.elasticsearch.threadpool.ThreadPool.Info
-
- readFrom(StreamInput) - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
-
- readFrom(StreamInput) - Method in class org.elasticsearch.threadpool.ThreadPoolStats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.BytesTransportRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.TransportInfo
-
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.TransportMessage
-
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.TransportStats
-
- 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, byte[], int, 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 (and validates) plugin metadata descriptor file
- readFromStream(StreamInput) - Static method in class org.elasticsearch.plugins.PluginInfo
-
- readFromThin(StreamInput, String) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
-
- readFromThin(StreamInput) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
- readFromWithId(long, StreamInput) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- readFsInfo(StreamInput) - Static method in class org.elasticsearch.monitor.fs.FsInfo
-
- readFully(byte[]) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- 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
-
- 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
-
- readGarbageCollector(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
-
- readGarbageCollectors(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
-
- readGenericValue() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readGeoPoint() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readGetField(StreamInput) - Static method in class org.elasticsearch.index.get.GetField
-
- readGetResponse(StreamInput) - Static method in class org.elasticsearch.action.get.GetResponse
-
- readGetResult(StreamInput) - Static method in class org.elasticsearch.index.get.GetResult
-
- readGetStats(StreamInput) - Static method in class org.elasticsearch.index.get.GetStats
-
- readHeader(IndexInput) - Method in class org.elasticsearch.common.compress.CompressedIndexInput
-
Deprecated.
- readHeader(StreamInput) - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
- readHeader(IndexInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
-
Deprecated.
- readHeader(StreamInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedStreamInput
-
- readHighlightField(StreamInput) - Static method in class org.elasticsearch.search.highlight.HighlightField
-
- readHttpInfo(StreamInput) - Static method in class org.elasticsearch.http.HttpInfo
-
- readHttpStats(StreamInput) - Static method in class org.elasticsearch.http.HttpStats
-
- readImmutableMapDiff(StreamInput, DiffableUtils.KeyedReader<T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableMaps
- readImmutableMapDiff(StreamInput, T) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableMaps
- readImmutableOpenMapDiff(StreamInput, DiffableUtils.KeyedReader<T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenMaps
- readImmutableOpenMapDiff(StreamInput, T) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenMaps
- readIndexingStats(StreamInput) - Static method in class org.elasticsearch.index.indexing.IndexingStats
-
- readIndexName(StreamInput) - Static method in class org.elasticsearch.index.Index
-
- 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.action.admin.cluster.stats.ClusterStatsIndices
-
- readIndicesStats(StreamInput) - Static method in class org.elasticsearch.indices.NodeIndicesStats
-
- readInfoFrom(StreamInput) - Static method in class org.elasticsearch.monitor.fs.FsInfo.Path
-
- 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
-
- readInternalSearchResponse(StreamInput) - Static method in class org.elasticsearch.search.internal.InternalSearchResponse
-
- readIntLE(byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
-
Read an int in little-endian format.
- 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
-
- readJvmInfo(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmInfo
-
- readJvmStats(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
- readJvmStats(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats
-
- readJvmVersion(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmVersion
-
- readLastCommittedSegmentInfos(SearcherManager, Store) - Static method in class org.elasticsearch.index.engine.Engine
-
Read the last segments info from the commit pointed to by the searcher manager
- readLastCommittedSegmentsInfo() - Method in class org.elasticsearch.index.store.Store
-
Returns the last committed segments info for this store
- readList(StreamInputReader<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
-
- readLock - Variable in class org.elasticsearch.index.translog.TranslogWriter
-
- 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
-
- readMem(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
-
- readMem(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsStats.Mem
-
- readMem(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessStats.Mem
-
- readMemoryPool(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
-
- readMergeStats(StreamInput) - Static method in class org.elasticsearch.index.merge.MergeStats
-
- readMetadataSnapshot(Path, ESLogger) - 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.
- readNode(StreamInput) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
- 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.stats.ClusterStatsNodeResponse
-
- 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.stats.ClusterStatsNodes
-
- readOnly() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
- readOnly() - Method in interface org.elasticsearch.repositories.Repository
-
Returns true if the repository supports only read operations
- readOnly() - Method in class org.elasticsearch.repositories.uri.URLRepository
-
- readOperations(StreamInput) - Static method in class org.elasticsearch.index.translog.Translog
-
- readOptional(StreamInput) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueFormatterStreams
-
- readOptionalAggregations(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
-
- readOptionalAllCircuitBreakerStats(StreamInput) - Static method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
-
- readOptionalBoolean() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readOptionalCircuitBreakerStats(StreamInput) - Static method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
-
- readOptionalCommitStatsFrom(StreamInput) - Static method in class org.elasticsearch.index.engine.CommitStats
-
- readOptionalRestoreInfo(StreamInput) - Static method in class org.elasticsearch.snapshots.RestoreInfo
-
- readOptionalRestoreSource(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RestoreSource
-
- readOptionalSnapshotInfo(StreamInput) - Static method in class org.elasticsearch.snapshots.SnapshotInfo
-
Reads optional snapshot information from stream input
- readOptionalStreamable(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
-
- readOptionalText() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readOptionalVInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readOriginalIndices(StreamInput) - Static method in class org.elasticsearch.action.OriginalIndices
-
- readOsInfo(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsInfo
-
- readOsStats(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
-
- readOsStats(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsStats
-
- readOtherStatsFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
-
- readOtherStatsFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- readPercolateStats(StreamInput) - Static method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- readPerFieldAnalyzer(Map<String, Object>) - Static method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- readPingResponse(StreamInput) - Static method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
-
- readProcessInfo(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessInfo
-
- readProcessStats(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessStats
-
- readQueryCacheStats(StreamInput) - Static method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
- 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
-
- readRefreshStats(StreamInput) - Static method in class org.elasticsearch.index.refresh.RefreshStats
-
- 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
-
- readRestoreInfo(StreamInput) - Static method in class org.elasticsearch.snapshots.RestoreInfo
-
- readRestoreSource(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RestoreSource
-
- readResult(StreamInput) - Method in interface org.elasticsearch.search.aggregations.AggregationStreams.Stream
-
- readResult(StreamInput, BucketStreamContext) - Method in interface org.elasticsearch.search.aggregations.bucket.BucketStreams.Stream
-
- readResult(StreamInput) - Method in interface org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicStreams.Stream
-
- readResult(StreamInput) - Method in interface org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModelStreams.Stream
-
- readResult(StreamInput) - Method in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorStreams.Stream
-
- readScoreDoc(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
-
- readScript(StreamInput) - Static method in class org.elasticsearch.script.Script
-
- readScroll(StreamInput) - Static method in class org.elasticsearch.search.Scroll
-
- readSearchHit(StreamInput, InternalSearchHits.StreamContext) - Static method in class org.elasticsearch.search.internal.InternalSearchHit
-
- readSearchHitField(StreamInput) - Static method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- readSearchHits(StreamInput, InternalSearchHits.StreamContext) - Static method in class org.elasticsearch.search.internal.InternalSearchHits
-
- readSearchHits(StreamInput) - Static method in class org.elasticsearch.search.internal.InternalSearchHits
-
- readSearchShardsGroupResponse(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
-
- readSearchShardTarget(StreamInput) - Static method in class org.elasticsearch.search.SearchShardTarget
-
- readSearchStats(StreamInput) - Static method in class org.elasticsearch.index.search.stats.SearchStats
-
- readSecret(String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
-
- readSegment(StreamInput) - Static method in class org.elasticsearch.index.engine.Segment
-
- readSegmentInfos(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Reads the segments infos, failing if it fails to load
- 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
- readSegmentsStats(StreamInput) - Static method in class org.elasticsearch.index.engine.SegmentsStats
-
- readSettingsFromStream(StreamInput) - Static method in class org.elasticsearch.common.settings.Settings
-
- readShardId(StreamInput) - Static method in class org.elasticsearch.index.shard.ShardId
-
- readShardInfo(StreamInput) - Static method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- 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
- readShardRoutingEntry(StreamInput) - Static method in class org.elasticsearch.cluster.routing.ShardRouting
-
- readShardRoutingEntry(StreamInput, String, int) - Static method in class org.elasticsearch.cluster.routing.ShardRouting
-
- 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
-
- readShardSnapshotStatus(StreamInput) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
-
- readShardsSyncedFlushResult(StreamInput) - Static method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
-
- readShardStats(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
- 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(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Read a size under the assumption that a value of 0 means unlimited.
- readSizeValue(StreamInput) - Static method in class org.elasticsearch.common.unit.SizeValue
-
- readSnapshot(SnapshotId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Reads snapshot description from repository.
- readSnapshot(SnapshotId) - Method in interface org.elasticsearch.repositories.Repository
-
Reads snapshot description from repository.
- readSnapshotId(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.SnapshotId
-
Reads snapshot id from stream input
- readSnapshotInfo(StreamInput) - Static method in class org.elasticsearch.snapshots.SnapshotInfo
-
Reads snapshot information from stream input
- readSnapshotList() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Reads snapshot index file
- readSnapshotMetaData(SnapshotId, Snapshot, List<String>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns global metadata associate with the snapshot.
- readSnapshotMetaData(SnapshotId, Snapshot, List<String>) - Method in interface org.elasticsearch.repositories.Repository
-
Returns global metadata associate with the snapshot.
- readSnapshotShardFailure(StreamInput) - Static method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
Reads shard failure information from stream input
- 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
- readSortType(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.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
-
- readStats(StreamInput) - Static method in class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- readStats(StreamInput) - Static method in class org.elasticsearch.index.search.stats.SearchStats.Stats
-
- readStoreFileMetaData(StreamInput) - Static method in class org.elasticsearch.index.store.StoreFileMetaData
-
- readStoreFilesMetaData(StreamInput) - Static method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
-
- readStoreStats(StreamInput) - Static method in class org.elasticsearch.index.store.StoreStats
-
- readString() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readStringArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readSuggest(XContentBuilderString, StreamInput) - Static method in class org.elasticsearch.search.suggest.Suggest
-
- readSuggestStats(StreamInput) - Static method in class org.elasticsearch.index.suggest.stats.SuggestStats
-
- readSwap(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsStats.Swap
-
- 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
-
- readTaskStatus() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a Task.Status
from the current stream.
- readTemplate(StreamInput) - Static method in class org.elasticsearch.script.Template
-
- readTermStats(StreamInput, Term[]) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- readTermVectorsRequest(StreamInput) - Static method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- readText(String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
-
- readText() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readThreadPoolInfo(StreamInput) - Static method in class org.elasticsearch.threadpool.ThreadPoolInfo
-
- readThreadPoolStats(StreamInput) - Static method in class org.elasticsearch.threadpool.ThreadPoolStats
-
- readThreads(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
-
- readThrowable() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- readTimeout(StreamInput) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Reads the timeout value
- readTimeValue(StreamInput) - Static method in class org.elasticsearch.common.unit.TimeValue
-
- readTopDocs(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
-
- readTransportInfo(StreamInput) - Static method in class org.elasticsearch.transport.TransportInfo
-
- readTransportStats(StreamInput) - Static method in class org.elasticsearch.transport.TransportStats
-
- readURIParameters(TermVectorsRequest, RestRequest) - Static method in class org.elasticsearch.rest.action.termvectors.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
-
- readWarmerStats(StreamInput) - Static method in class org.elasticsearch.index.warmer.WarmerStats
-
- ready() - Method in class org.elasticsearch.common.io.FastCharArrayReader
-
Tells whether this stream is ready to be read.
- ready() - Method in class org.elasticsearch.common.io.FastStringReader
-
Tells whether this stream is ready to be read.
- ready() - Method in class org.elasticsearch.common.lucene.all.AllEntries
-
- readyBuffer() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
-
Deprecated.
- readyBuffer() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
Fill the uncompressed bytes buffer by reading the underlying inputStream.
- REAL_WORD_LIKELYHOOD - Static variable in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
-
- realtime() - Method in class org.elasticsearch.action.get.GetRequest
-
- realtime(Boolean) - Method in class org.elasticsearch.action.get.GetRequest
-
- realtime() - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- realtime(Boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- realtime() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
- 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() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return whether term vectors should be generated real-time (default to true).
- realtime(Boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Choose whether term vectors be generated real-time.
- realtime() - Method in class org.elasticsearch.index.engine.Engine.Get
-
- RealtimeRequest - Interface in org.elasticsearch.action
-
Indicates that a request can execute in realtime (reads from the translog).
- 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.
- realWordLikelyhood - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- reason() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- reason() - Method in class org.elasticsearch.action.search.ShardSearchFailure
-
The reason of the failure.
- reason() - Method in interface org.elasticsearch.action.ShardOperationFailedException
-
The reason of the failure.
- reason() - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
-
- reason() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Returns failure reason
- reason() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
-
- reason() - Method in class org.elasticsearch.snapshots.Snapshot
-
Returns reason for complete snapshot failure
- reason() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot failure reason
- reason() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
Returns reason for the failure
- REASON_AGGREGATION - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- REASON_AGGREGATION_GLOBAL - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- REASON_SEARCH_COUNT - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- REASON_SEARCH_MIN_SCORE - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- REASON_SEARCH_MULTI - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- REASON_SEARCH_POST_FILTER - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- REASON_SEARCH_TERMINATE_AFTER_COUNT - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- REASON_SEARCH_TIMEOUT - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- REASON_SEARCH_TOP_HITS - Static variable in class org.elasticsearch.search.profile.CollectorResult
-
- rebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
- rebalance(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Rebalancing number of shards on all nodes
- rebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
-
- RebalanceOnlyWhenActiveAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
Only allow rebalancing when all shards are active within the shard replication group.
- RebalanceOnlyWhenActiveAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.RebalanceOnlyWhenActiveAllocationDecider
-
- receiveBufferSizePredictorFactory - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- receiveBufferSizePredictorFactory - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- received(long) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- received(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
-
- receivePredictorMax - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- receivePredictorMin - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- 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
-
- recover(IndexShard, boolean, StoreRecoveryService.RecoveryListener) - Method in class org.elasticsearch.index.shard.StoreRecoveryService
-
Recovers the state of the shard from the gateway.
- 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(ShardId, int, ByteSizeValue, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
-
- RecoverFilesRecoveryException(StreamInput) - Constructor for exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
-
- recoverFromStore(ShardRouting, StoreRecoveryService.RecoveryListener) - Method in class org.elasticsearch.index.shard.IndexShard
-
- recoverFromTranslog(EngineConfig, Translog.TranslogGeneration) - Method in class org.elasticsearch.index.engine.InternalEngine
-
- 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(ESLogger, ThreadPool) - Constructor for class org.elasticsearch.indices.recovery.RecoveriesCollection
-
- RecoveriesCollection.StatusRef - Class in org.elasticsearch.indices.recovery
-
- recovering(String, RecoveryState.Type, DiscoveryNode) - Method in class org.elasticsearch.index.shard.IndexShard
-
Marks the shard as recovering based on a remote or local node, fails with exception is recovering is not allowed to be set.
- recovering(String, RecoveryState.Type, RestoreSource) - Method in class org.elasticsearch.index.shard.IndexShard
-
Marks the shard as recovering based on a restore, fails with exception is recovering is not allowed to be set.
- recoverToTarget() - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
performs the recovery from the local engine to the target
- recoverToTarget() - Method in class org.elasticsearch.indices.recovery.SharedFSRecoverySourceHandler
-
- recovery(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- recovery() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- 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(ShardId, int, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.RecoveryEngineException
-
- RecoveryEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.RecoveryEngineException
-
- RecoveryFailedException - Exception in org.elasticsearch.indices.recovery
-
- RecoveryFailedException(StartRecoveryRequest, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
-
- RecoveryFailedException(StartRecoveryRequest, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
-
- RecoveryFailedException(RecoveryState, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
-
- RecoveryFailedException(ShardId, DiscoveryNode, DiscoveryNode, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
-
- RecoveryFailedException(ShardId, DiscoveryNode, DiscoveryNode, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
-
- RecoveryFailedException(StreamInput) - 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
-
- recoveryFromSnapshot(Engine, Translog.Snapshot) - Method in class org.elasticsearch.index.shard.TranslogRecoveryPerformer
-
- 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.RecoveryPrepareForTranslogOperationsRequest
-
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
-
- recoveryId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
- RecoveryPrepareForTranslogOperationsRequest - Class in org.elasticsearch.indices.recovery
-
- RecoveryPrepareForTranslogOperationsRequest() - Constructor for class org.elasticsearch.indices.recovery.RecoveryPrepareForTranslogOperationsRequest
-
- 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() - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
-
- RecoveryResponse(int, int, int, boolean, Map<String, List<RecoveryState>>, List<ShardOperationFailedException>) - 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, NodeSettingsService) - Constructor for class org.elasticsearch.indices.recovery.RecoverySettings
-
- RecoverySource - 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.
- RecoverySource(Settings, TransportService, IndicesService, RecoverySettings, ClusterService) - Constructor for class org.elasticsearch.indices.recovery.RecoverySource
-
- RecoverySource.Actions - Class in org.elasticsearch.indices.recovery
-
- 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, StartRecoveryRequest, RecoverySettings, TransportService, ESLogger) - Constructor for class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
- recoveryState() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the current
RecoveryState
if this shard is recovering or has been recovering.
- RecoveryState - Class in org.elasticsearch.indices.recovery
-
Keeps track of state related to shard recovery.
- RecoveryState(ShardId, boolean, RecoveryState.Type, DiscoveryNode, DiscoveryNode) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState
-
- RecoveryState(ShardId, boolean, RecoveryState.Type, RestoreSource, DiscoveryNode) - 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.Type - Enum 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 - Class in org.elasticsearch.index.recovery
-
Recovery related statistics, starting at the shard level and allowing aggregation to
indices and node level
- RecoveryStats() - Constructor for class org.elasticsearch.index.recovery.RecoveryStats
-
- recoveryStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
returns stats about ongoing recoveries, both source and target
- RecoveryStatus - Class in org.elasticsearch.indices.recovery
-
- RecoveryStatus(IndexShard, DiscoveryNode, RecoveryTarget.RecoveryListener) - Constructor for class org.elasticsearch.indices.recovery.RecoveryStatus
-
- RecoveryTarget - Class in org.elasticsearch.indices.recovery
-
The recovery target handles recoveries of peer shards of the shard+node to recover to.
- RecoveryTarget(Settings, ThreadPool, TransportService, IndicesLifecycle, RecoverySettings, ClusterService) - Constructor for class org.elasticsearch.indices.recovery.RecoveryTarget
-
- RecoveryTarget.Actions - Class in org.elasticsearch.indices.recovery
-
- RecoveryTarget.RecoveryListener - Interface in org.elasticsearch.indices.recovery
-
- RecoveryTranslogOperationsRequest - Class in org.elasticsearch.indices.recovery
-
- RecoveryTranslogOperationsRequest() - Constructor for class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
-
- recoveryType() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
- 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(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
-
- recycler() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
-
- Recycler<T> - Interface in org.elasticsearch.common.recycler
-
A recycled object, note, implementations should support calling obtain and then recycle
on different threads.
- RECYCLER - Static variable in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction.Fields
-
- 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
-
- reduce(PercolateRequest, AtomicReferenceArray, PercolatorService) - Static method in class org.elasticsearch.action.percolate.TransportPercolateAction
-
- reduce(byte, List<PercolateShardResponse>, HasContextAndHeaders) - Method in class org.elasticsearch.percolator.PercolatorService
-
- reduce(List<? extends InternalSignificantTerms.Bucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
- reduce(List<? extends InternalTerms.Bucket>, 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 addAggregation to a single one and returns it.
- reduce(List<InternalAggregations>, InternalAggregation.ReduceContext) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Reduces the given lists of addAggregation.
- 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.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.having.BucketSelectorPipelineAggregator
-
- 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.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(Map<String, List<Suggest.Suggestion>>) - Static method in class org.elasticsearch.search.suggest.Suggest
-
- reduce(List<T>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
-
- reduce(List<Suggest.Suggestion<T>>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
Merges the result of another suggestion into this suggestion.
- REDUCE_PARAMS_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- REDUCE_SCRIPT - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- REDUCE_SCRIPT_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- ReduceContext(BigArrays, ScriptService, HasContextAndHeaders) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
- reducedAggregations() - Method in class org.elasticsearch.percolator.PercolatorService.ReduceResult
-
- 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
-
- ReduceResult(long, InternalAggregations) - Constructor for class org.elasticsearch.percolator.PercolatorService.ReduceResult
-
- reduceScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
-
Set the reduce script.
- 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
-
- 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.
- reference(String, String) - Static method in class org.elasticsearch.search.suggest.context.ContextBuilder
-
- reference(String, String, Iterable<? extends CharSequence>) - Static method in class org.elasticsearch.search.suggest.context.ContextBuilder
-
- refresh - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- refresh(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- refresh() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- refresh(boolean) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Should a refresh be executed post this bulk operation causing the operations to
be searchable.
- refresh() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- refresh(boolean) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Should a refresh be executed post this index operation causing the operation to
be searchable.
- refresh() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
- 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() - Method in class org.elasticsearch.action.get.GetRequest
-
- refresh() - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- refresh(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- refresh() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
- refresh(boolean) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
- refresh(boolean) - Method in class org.elasticsearch.action.index.IndexRequest
-
Should a refresh be executed post this index operation causing the operation to
be searchable.
- refresh() - Method in class org.elasticsearch.action.index.IndexRequest
-
- refresh(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Should a refresh be executed post this update operation causing the operation to
be searchable.
- refresh() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- 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() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
-
Refreshes the ClusterInfo in a blocking fashion
- refresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Returns a new instance to cache
- refresh(String) - Method in class org.elasticsearch.index.engine.Engine
-
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.ShadowEngine
-
- refresh(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
- REFRESH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- RefreshAction - Class in org.elasticsearch.action.admin.indices.refresh
-
- RefreshFailedEngineException - Exception in org.elasticsearch.index.engine
-
- RefreshFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.RefreshFailedEngineException
-
- RefreshFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.RefreshFailedEngineException
-
- refreshInterval() - Method in class org.elasticsearch.monitor.process.ProcessInfo
-
- 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
-
- RefreshRequest - Class in org.elasticsearch.action.admin.indices.refresh
-
A refresh request making all operations performed since the last refresh available for search.
- RefreshRequest() - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
-
- RefreshRequest(ActionRequest) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
-
Copy constructor that creates a new refresh request that is a copy of the one provided as an argument.
- RefreshRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
-
- refreshRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a refresh indices request.
- 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.
- refreshSettings(Settings) - Method in class org.elasticsearch.index.settings.IndexSettingsService
-
- RefreshStats - Class in org.elasticsearch.index.refresh
-
- RefreshStats() - Constructor for class org.elasticsearch.index.refresh.RefreshStats
-
- RefreshStats(long, long) - Constructor for class org.elasticsearch.index.refresh.RefreshStats
-
- refreshStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
- Regex - Class in org.elasticsearch.common.regex
-
- Regex() - Constructor for class org.elasticsearch.common.regex.Regex
-
- regex - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
-
- RegexpFlag - Enum in org.elasticsearch.index.query
-
Regular expression syntax flags.
- regexpQuery(String, int, int, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- 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 term query.
- RegexpQueryParser - Class in org.elasticsearch.index.query
-
- RegexpQueryParser() - Constructor for class org.elasticsearch.index.query.RegexpQueryParser
-
- 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(String, String, TransportRequest) - Method in class org.elasticsearch.tasks.TaskManager
-
Registers a task without parent task
- registerAction(GenericAction<Request, Response>, Class<? extends TransportAction<Request, Response>>, Class...) - Method in class org.elasticsearch.action.ActionModule
-
Registers an action.
- registerAggregatorParser(Class<? extends Aggregator.Parser>) - Method in class org.elasticsearch.search.SearchModule
-
Enabling extending the get module by adding a custom aggregation parser.
- registerAllocationDecider(Class<? extends AllocationDecider>) - Method in class org.elasticsearch.cluster.ClusterModule
-
- 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
-
- registerChildTask(Task, String) - Method in class org.elasticsearch.tasks.TaskManager
-
- registerClusterDynamicSetting(String, Validator) - Method in class org.elasticsearch.cluster.ClusterModule
-
- registerConnectionListener - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- registerExtension(String, Class<? extends T>) - Method in class org.elasticsearch.common.util.ExtensionPoint.ClassMap
-
Registers an extension class for a given key.
- registerExtension(Class<? extends T>) - Method in class org.elasticsearch.common.util.ExtensionPoint.ClassSet
-
Registers a new extension
- registerExtension(K, V) - Method in class org.elasticsearch.common.util.ExtensionPoint.InstanceMap
-
Registers a mapping from key
to value
- registerFactory(String, AllocationCommand.Factory) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Register a custom index meta data factory.
- registerFetchSubPhase(Class<? extends FetchSubPhase>) - Method in class org.elasticsearch.search.SearchModule
-
- registerFilter(Class<? extends ActionFilter>) - Method in class org.elasticsearch.action.ActionModule
-
- registerFilter(RestFilter) - Method in class org.elasticsearch.rest.RestController
-
Registers a pre processor to be executed before the rest request is actually handled.
- registerFunctionScoreParser(Class<? extends ScoreFunctionParser>) - Method in class org.elasticsearch.search.SearchModule
-
- registerGatewayType(String, Class<? extends Gateway>) - Method in class org.elasticsearch.gateway.GatewayModule
-
Adds a custom Discovery type.
- registerHandler(RestRequest.Method, String, RestHandler) - Method in class org.elasticsearch.rest.RestController
-
Registers a rest handler to be execute when the provided method and path match the request.
- registerHeuristicParser(Class<? extends SignificanceHeuristicParser>) - Method in class org.elasticsearch.search.SearchModule
-
- registerHighlighter(String, Class<? extends Highlighter>) - Method in class org.elasticsearch.search.SearchModule
-
- registerHunspellDictionary(String, Dictionary) - Method in class org.elasticsearch.indices.IndicesModule
-
- registerIndexDynamicSetting(String, Validator) - Method in class org.elasticsearch.cluster.ClusterModule
-
- registerIndexTemplateFilter(Class<? extends IndexTemplateFilter>) - Method in class org.elasticsearch.cluster.ClusterModule
-
- registerMapper(String, Mapper.TypeParser) - Method in class org.elasticsearch.indices.IndicesModule
-
Register a mapper for the given type.
- registerMetadataMapper(String, MetadataFieldMapper.TypeParser) - Method in class org.elasticsearch.indices.IndicesModule
-
Register a root mapper under the given name.
- registerModelParser(Class<? extends MovAvgModel.AbstractModelParser>) - Method in class org.elasticsearch.search.SearchModule
-
- registerPipelineParser(Class<? extends PipelineAggregator.Parser>) - Method in class org.elasticsearch.search.SearchModule
-
- registerPrototype(String, ClusterState.Custom) - Static method in class org.elasticsearch.cluster.ClusterState
-
Register a custom index meta data factory.
- registerPrototype(String, IndexMetaData.Custom) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Register a custom index meta data factory.
- registerPrototype(String, MetaData.Custom) - Static method in class org.elasticsearch.cluster.metadata.MetaData
-
Register a custom index meta data factory.
- registerPrototype(Class<T>, NamedWriteable<? extends T>) - Method in class org.elasticsearch.common.io.stream.NamedWriteableRegistry
-
- registerQueryCache(String, Class<? extends QueryCache>) - Method in class org.elasticsearch.index.cache.IndexCacheModule
-
- registerQueryParser(Class<? extends QueryParser>) - Method in class org.elasticsearch.indices.IndicesModule
-
- registerRelevantHeaders(String...) - Method in class org.elasticsearch.rest.RestController
-
- registerRepository(String, Class<? extends Repository>, Class<? extends IndexShardRepository>) - Method in class org.elasticsearch.repositories.RepositoriesModule
-
- registerRepository(RepositoriesService.RegisterRepositoryRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Registers new repository in the cluster
- registerRepository(String, Class<? extends Repository>, Class<? extends IndexShardRepository>) - Method in class org.elasticsearch.repositories.RepositoryTypesRegistry
-
Adds a new repository type to the registry, bound to the given implementation classes.
- RegisterRepositoryRequest(String, String, String, boolean) - Constructor for class org.elasticsearch.repositories.RepositoriesService.RegisterRepositoryRequest
-
Constructs new register repository request
- registerRequestHandler(String, Class<Request>, String, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(String, Callable<Request>, String, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(String, Class<Request>, String, boolean, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(RequestHandlerRegistry<Request>) - Method in class org.elasticsearch.transport.TransportService
-
- registerScript(String, Class<? extends NativeScriptFactory>) - Method in class org.elasticsearch.script.ScriptModule
-
- registerScriptContext(ScriptContext.Plugin) - Method in class org.elasticsearch.script.ScriptModule
-
Registers a custom script context that can be used by plugins to categorize the different operations that they use scripts for.
- registerShardsAllocator(String, Class<? extends ShardsAllocator>) - Method in class org.elasticsearch.cluster.ClusterModule
-
- registerStream(AggregationStreams.Stream, BytesReference...) - Static method in class org.elasticsearch.search.aggregations.AggregationStreams
-
Registers the given stream and associate it with the given types.
- registerStream(BucketStreams.Stream, BytesReference...) - Static method in class org.elasticsearch.search.aggregations.bucket.BucketStreams
-
Registers the given stream and associate it with the given types.
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.children.InternalChildren
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
-
- registerStream(SignificanceHeuristicStreams.Stream) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicStreams
-
Registers the given stream and associate it with the given types.
- registerStream() - Static method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
-
- registerStream() - Static method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
-
- registerStream(MovAvgModelStreams.Stream) - Static method in class org.elasticsearch.search.aggregations.pipeline.movavg.models.MovAvgModelStreams
-
Registers the given stream and associate it with the given types.
- registerStream(PipelineAggregatorStreams.Stream, BytesReference...) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorStreams
-
Registers the given stream and associate it with the given types.
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.InternalExtendedStatsBucket
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
-
- registerStreams() - Static method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
-
- registerSuggester(String, Class<? extends Suggester>) - Method in class org.elasticsearch.search.SearchModule
-
- registerTaskStatus(Task.Status) - Method in class org.elasticsearch.common.network.NetworkModule
-
- rehash(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityBuilder
-
Expert: set to false in case values of this field can already be treated
as 64-bits hash values.
- reinitShadowPrimary(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- 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(ClusterState, String) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- RejoinClusterRequest() - Constructor for class org.elasticsearch.discovery.zen.ZenDiscovery.RejoinClusterRequest
-
- relation(ShapeRelation) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Sets the relation of query shape and indexed shape.
- Releasable - Interface in org.elasticsearch.common.lease
-
- ReleasableBytesStream - Interface in org.elasticsearch.common.io
-
A bytes stream that requires its bytes to be released once no longer used.
- ReleasableBytesStreamOutput - Class in org.elasticsearch.common.io.stream
-
- ReleasableBytesStreamOutput(BigArrays) - Constructor for class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
-
- ReleasableBytesStreamOutput(int, 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
-
- ReleasablePagedBytesReference(BigArrays, ByteArray, int) - Constructor for class org.elasticsearch.common.bytes.ReleasablePagedBytesReference
-
- Releasables - Enum in org.elasticsearch.common.lease
-
- release() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- release() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- release(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
- release() - Method in class org.elasticsearch.index.engine.Engine.GetResult
-
- ReleaseChannelFutureListener - Class in org.elasticsearch.common.netty
-
A channel listener that releases a
Releasable
when
the operation is complete.
- ReleaseChannelFutureListener(Releasable) - Constructor for class org.elasticsearch.common.netty.ReleaseChannelFutureListener
-
- relevantHeaders() - Method in class org.elasticsearch.rest.RestController
-
- relocate(ShardRouting, String, long) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Relocate a shard to another node, adding the target initializing
shard as well as assigning it.
- relocated(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
- relocating() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns true
iff the this shard is currently relocating to
another node.
- relocatingNodeId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The relocating node id the shard is either relocating to or relocating from.
- remaining() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
-
- remaining() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
- remaining - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
-
Deprecated.
- remainingCapacity() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- remoteAddress(TransportAddress) - Method in class org.elasticsearch.transport.TransportMessage
-
- remoteAddress() - Method in class org.elasticsearch.transport.TransportMessage
-
- 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
-
- remove(NodeIndexDeletedAction.Listener) - Method in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
-
- remove(ClusterStateListener) - Method in interface org.elasticsearch.cluster.ClusterService
-
Removes a listener for updated cluster states.
- remove(LocalNodeMasterListener) - Method in interface org.elasticsearch.cluster.ClusterService
-
Remove the given listener for on/off local master events
- remove(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- remove(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
-
- remove() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodeIterator
-
- remove() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodesIterator
-
- remove() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
Unsupported operation, just there for the interface.
- remove(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- remove(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- remove(LocalNodeMasterListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- remove(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- remove(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- remove(K) - Method in class org.elasticsearch.common.collect.MapBuilder
-
- 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(long) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- remove(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- remove(Object, Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- remove(long) - Method in interface org.elasticsearch.common.util.concurrent.ConcurrentMapLong
-
- remove(Object) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- 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(Object) - Method in class org.elasticsearch.common.util.MinimalMap
-
- remove() - Method in class org.elasticsearch.index.mapper.ContentPath
-
- remove(FieldMapper) - Method in class org.elasticsearch.index.mapper.FieldMappers
-
- remove(String) - Method in class org.elasticsearch.index.store.Store.LegacyChecksums
-
- remove(Object) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
-
- remove(Object) - Method in class org.elasticsearch.search.lookup.LeafFieldsLookup
-
- remove() - Method in class org.elasticsearch.search.lookup.PositionIterator
-
- remove(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- remove(Listener) - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Unregisters a listener
- removeAlias(String[], String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
Removes an alias to the index.
- removeAlias(String, String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
Removes an alias to 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.
- removeAlias(String, String[]) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Removes aliases from the index.
- removeAlias(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- removeAll(IntContainer) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- removeAll(IntPredicate) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- removeAll(IntObjectPredicate<? super VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
- removeAll(ObjectContainer<? super KType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- removeAll(ObjectPredicate<? super KType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- removeAll(ObjectObjectPredicate<? super KType, ? super VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
- removeAllAliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- removeAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- 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() - 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).
- removeAttribute(String) - Method in class org.elasticsearch.node.service.NodeService
-
- 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
-
- removeCorruptionMarker() - Method in class org.elasticsearch.index.store.Store
-
Deletes all corruption markers from this store.
- removeCurrent() - Static method in class org.elasticsearch.search.internal.SearchContext
-
- 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.IndexTemplateMetaData.Builder
-
- removeCustom(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- removed() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
-
- removeDeadMembers(Set<String>, String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
- removedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
-
- removedQuery(BytesRef, Query) - Method in class org.elasticsearch.index.percolator.stats.ShardPercolateService
-
- removeFilter(String) - Method in class org.elasticsearch.common.settings.SettingsFilter
-
Removes a simple pattern from the list of filters
- removeGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
-
- removeHandler(String) - Method in class org.elasticsearch.transport.TransportService
-
- removeHostsProvider(UnicastHostsProvider) - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
-
- removeIndex(String, String) - Method in class org.elasticsearch.indices.IndicesService
-
Removes the given index from this service and releases all associated resources.
- removeIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
-
- removeIndexBlocks(String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
-
- removeInitialStateBlock(ClusterBlock) - Method in interface org.elasticsearch.cluster.ClusterService
-
Remove an initial block to be set on the first cluster state created.
- removeInitialStateBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
-
- removeLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.common.component.LifecycleComponent
-
- removeListener() - Method in enum org.elasticsearch.action.ThreadingModel
-
- removeListener(InitialStateDiscoveryListener) - Method in interface org.elasticsearch.discovery.Discovery
-
- removeListener(InitialStateDiscoveryListener) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
-
- removeListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
-
- removeListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
-
- removeListener(InitialStateDiscoveryListener) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- removeListener(IndexingOperationListener) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- removeListener(IndexSettingsService.Listener) - Method in class org.elasticsearch.index.settings.IndexSettingsService
-
- removeListener(IndicesLifecycle.Listener) - Method in interface org.elasticsearch.indices.IndicesLifecycle
-
Remove a listener.
- removeListener(IndicesWarmer.Listener) - Method in class org.elasticsearch.indices.IndicesWarmer
-
- removeListener(IndicesLifecycle.Listener) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- removeListener(NodeSettingsService.Listener) - Method in class org.elasticsearch.node.settings.NodeSettingsService
-
- removeListener(ActionListener<RestoreService.RestoreCompletionResponse>) - Method in class org.elasticsearch.snapshots.RestoreService
-
Removes restore completion listener
- removeListener(SnapshotsService.SnapshotCompletionListener) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Removes snapshot completion listener
- removeMapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- removeMapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- removeOpenIndexOutputs(String) - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
remove and IndexOutput
for a given file.
- removeOperation() - Method in enum org.elasticsearch.action.ThreadingModel
-
- removePercolateQuery(String) - Method in class org.elasticsearch.index.percolator.PercolatorQueriesRegistry
-
- removePlugin(String, Terminal) - Method in class org.elasticsearch.plugins.PluginManager
-
- removeReplica() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
- RemoveRequest(String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveRequest
-
- RemoveResponse(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveResponse
-
- removeShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
-
- removeShard(int, String) - Method in class org.elasticsearch.index.IndexService
-
- removeTemplate(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- removeTemplates(MetaDataIndexTemplateService.RemoveRequest, MetaDataIndexTemplateService.RemoveListener) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService
-
- 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.
- removeTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClientNodesService
-
- removeTypeListener(DocumentTypeListener) - Method in class org.elasticsearch.index.mapper.MapperService
-
- removeTypes() - Static method in class org.elasticsearch.index.query.QueryParseContext
-
- renameAllTempFiles() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
renames all temporary files to their true name, potentially overriding existing files
- renameFile(String, String) - Method in class org.elasticsearch.index.store.Store
-
- renamePattern(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets rename pattern that should be applied to restored indices.
- renamePattern() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns rename pattern
- renamePattern() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns rename pattern
- renameReplacement(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets rename replacement
- renameReplacement() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns rename replacement
- renameReplacement() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns replacement pattern
- renameTempFilesSafe(Map<String, String>) - Method in class org.elasticsearch.index.store.Store
-
Renames all the given files form the key of the map to the
value of the map.
- renderHeader(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.ElasticsearchException
-
- renderSearchTemplate(RenderSearchTemplateRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Return the rendered search request for a given search template.
- renderSearchTemplate(RenderSearchTemplateRequest, ActionListener<RenderSearchTemplateResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Return the rendered search request for a given search template.
- RenderSearchTemplateAction - Class in org.elasticsearch.action.admin.cluster.validate.template
-
- RenderSearchTemplateAction() - Constructor for class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateAction
-
- RenderSearchTemplateRequest - Class in org.elasticsearch.action.admin.cluster.validate.template
-
- RenderSearchTemplateRequest() - Constructor for class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateRequest
-
- RenderSearchTemplateRequestBuilder - Class in org.elasticsearch.action.admin.cluster.validate.template
-
- RenderSearchTemplateRequestBuilder(ElasticsearchClient, RenderSearchTemplateAction) - Constructor for class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateRequestBuilder
-
- RenderSearchTemplateResponse - Class in org.elasticsearch.action.admin.cluster.validate.template
-
- RenderSearchTemplateResponse() - Constructor for class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateResponse
-
- renderThrowable(XContentBuilder, ToXContent.Params, Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
-
- 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(Long, T, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- replace(Long, T) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- replaceMissing(ValuesSource.Bytes, BytesRef) - Static method in enum org.elasticsearch.search.aggregations.support.MissingValues
-
- replaceMissing(ValuesSource.Numeric, Number) - Static method in enum org.elasticsearch.search.aggregations.support.MissingValues
-
- replaceMissing(ValuesSource.Bytes.WithOrdinals, 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
-
- replacePlaceholders(String, PropertyPlaceholder.PlaceholderResolver) - Method in class org.elasticsearch.common.property.PropertyPlaceholder
-
- replacePropertyPlaceholders() - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Runs across all the settings set on this builder and replaces ${...} elements in the
each setting value according to the following logic:
- replay(long...) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
- 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(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ReplicaAfterPrimaryActiveAllocationDecider
-
- replicaFirstActiveInitializingShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
- ReplicaShardAllocator - Class in org.elasticsearch.gateway
-
- ReplicaShardAllocator(Settings) - 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
-
- ReplicationRequest<T extends ReplicationRequest<T>> - Class in org.elasticsearch.action.support.replication
-
- ReplicationRequest() - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
-
- ReplicationRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
-
Creates a new request that inherits headers and context from the request provided as argument.
- ReplicationRequest(ActionRequest, ShardId) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
-
Creates a new request with resolved shard id
- ReplicationRequest(T) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
-
Copy constructor that creates a new request that is a copy of the one provided as an argument.
- ReplicationRequest(T, ActionRequest) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
-
Copy constructor that creates a new request that is a copy of the one provided as an argument.
- 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
-
- ReplicationTask - Class in org.elasticsearch.action.support.replication
-
Task that tracks replication actions.
- ReplicationTask(long, String, String, String, TaskId) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask
-
- ReplicationTask.Status - Class in org.elasticsearch.action.support.replication
-
- 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(String[]) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
-
Sets the list or 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
- RepositoriesMetaData - Class in org.elasticsearch.cluster.metadata
-
Contains metadata about registered snapshot repositories
- RepositoriesMetaData(RepositoryMetaData...) - Constructor for class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Constructs new repository metadata
- RepositoriesModule - Class in org.elasticsearch.repositories
-
Sets up classes for Snapshot/Restore.
- RepositoriesModule() - 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, RepositoryTypesRegistry, Injector) - 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(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Returns repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Sets repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Sets repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Returns 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
-
Snapshot repository interface.
- repository() - Method in exception org.elasticsearch.repositories.RepositoryException
-
Returns repository name
- repository() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Returns snapshot repository
- 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
- 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
-
- RepositoryModule - Class in org.elasticsearch.repositories
-
Binds repository classes for the specific repository type.
- RepositoryModule(RepositoryName, Settings, Settings, RepositoryTypesRegistry) - Constructor for class org.elasticsearch.repositories.RepositoryModule
-
Spawns module for repository with specified name, type and settings
- repositoryName - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
- RepositoryName - Class in org.elasticsearch.repositories
-
Combines together the name and type of the repository
- RepositoryName(String, String) - Constructor for class org.elasticsearch.repositories.RepositoryName
-
- RepositoryNameModule - Class in org.elasticsearch.repositories
-
Binds specific instance of RepositoryName for injection to repository module
- RepositoryNameModule(RepositoryName) - Constructor for class org.elasticsearch.repositories.RepositoryNameModule
-
- RepositorySettings - Class in org.elasticsearch.repositories
-
Combines repository-specific settings with global settings
- RepositorySettings(Settings, Settings) - Constructor for class org.elasticsearch.repositories.RepositorySettings
-
- RepositoryTypesRegistry - Class in org.elasticsearch.repositories
-
- RepositoryTypesRegistry() - Constructor for class org.elasticsearch.repositories.RepositoryTypesRegistry
-
- 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() - Method in class org.elasticsearch.action.ActionRequestBuilder
-
- Request() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
-
- Request(ActionRequest, String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
-
- request() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
-
- request() - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- Request() - Constructor for class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Request
-
- request() - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- request() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction.InternalRequest
-
- Request(String[]) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Request
-
- REQUEST - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
- Request() - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.Request
-
- Request(String...) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.Request
-
- Request() - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
-
- Request(ShardId, String, String[]) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
-
- request() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
-
- Request() - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.Request
-
- Request(ShardId, boolean, Set<String>) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.Request
-
- Request(ShardId, boolean, String...) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.Request
-
- request() - Method in class org.elasticsearch.percolator.PercolateContext
-
- request - Variable in class org.elasticsearch.rest.RestChannel
-
- request() - Method in class org.elasticsearch.rest.RestChannel
-
- request() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- request() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- request() - Method in class org.elasticsearch.search.internal.SearchContext
-
- 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
-
- requestCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
-
- requestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
-
- requestCache - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- requestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- requestCache() - 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() - 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() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
-
- 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
-
- requestedSize() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
-
- requestFactory - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
- requestHandler - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport.HttpChannelPipelineFactory
-
- RequestHandlerRegistry<Request extends TransportRequest> - Class in org.elasticsearch.transport
-
- RequestHandlerRegistry(String, Callable<Request>, TaskManager, TransportRequestHandler<Request>, String, boolean) - Constructor for class org.elasticsearch.transport.RequestHandlerRegistry
-
- requestInjection(Object) - Method in class org.elasticsearch.common.inject.AbstractModule
-
- 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.
- 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(Object) - Method in class org.elasticsearch.common.inject.PrivateModule
-
- requests() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
The list of requests in this bulk request.
- requests() - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
- 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
-
- 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.
- requestStaticInjection(Class<?>...) - Method in class org.elasticsearch.common.inject.PrivateModule
-
- requireBinding(Key<?>) - Method in class org.elasticsearch.common.inject.AbstractModule
-
Adds a dependency from this module to key
.
- 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.PrivateModule
-
Instructs Guice to require a binding to the given key.
- requireBinding(Class<?>) - Method in class org.elasticsearch.common.inject.PrivateModule
-
Instructs Guice to require a binding to the given type.
- required() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
-
- required(boolean) - Method in class org.elasticsearch.common.cli.CliToolConfig.OptionBuilder
-
- required(boolean) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Builder
-
- REQUIRED - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
-
- required() - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- REQUIRED_SIZE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- requiredBits() - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- requireFieldMatch(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
-
- requireFieldMatch(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
Set to true to cause a field to be highlighted only if a query matches that field.
- requireFieldMatch() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- requireFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- REQUIRES_NAME - Static variable in class org.elasticsearch.action.support.DestructiveOperations
-
Setting which controls whether wildcard usage (*, prefix*, _all) is allowed.
- requiresContext() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- requiresLayout() - Method in class org.elasticsearch.common.logging.log4j.TerminalAppender
-
- 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, AllocationCommands) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
- reroute(ClusterState, AllocationCommands, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
- 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(String) - Method in class org.elasticsearch.cluster.routing.RoutingService
-
Initiates a reroute.
- 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.
- 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
-
- rescore() - Method in class org.elasticsearch.percolator.PercolateContext
-
- rescore() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- rescore() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- rescore() - Method in class org.elasticsearch.search.internal.SearchContext
-
- rescore(TopDocs, SearchContext, RescoreSearchContext) - Method in class org.elasticsearch.search.rescore.QueryRescorer
-
- rescore(TopDocs, SearchContext, RescoreSearchContext) - Method in interface org.elasticsearch.search.rescore.Rescorer
-
Modifies the result of the previously executed search (
TopDocs
)
in place based on the given
RescoreSearchContext
.
- RescoreBuilder - Class in org.elasticsearch.search.rescore
-
- RescoreBuilder() - Constructor for class org.elasticsearch.search.rescore.RescoreBuilder
-
- RescoreBuilder.QueryRescorer - Class in org.elasticsearch.search.rescore
-
- RescoreBuilder.Rescorer - Class in org.elasticsearch.search.rescore
-
- RescoreParseElement - Class in org.elasticsearch.search.rescore
-
- RescoreParseElement() - Constructor for class org.elasticsearch.search.rescore.RescoreParseElement
-
- RescorePhase - Class in org.elasticsearch.search.rescore
-
- RescorePhase(Settings) - Constructor for class org.elasticsearch.search.rescore.RescorePhase
-
- rescoreQueryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
-
- rescorer(RescoreBuilder.Rescorer) - Method in class org.elasticsearch.search.rescore.RescoreBuilder
-
- Rescorer(String) - Constructor for class org.elasticsearch.search.rescore.RescoreBuilder.Rescorer
-
- Rescorer - Interface in org.elasticsearch.search.rescore
-
A query rescorer interface used to re-rank the Top-K results of a previously
executed search.
- rescorer() - Method in class org.elasticsearch.search.rescore.RescoreSearchContext
-
- RescoreSearchContext - Class in org.elasticsearch.search.rescore
-
- RescoreSearchContext(String, int, Rescorer) - Constructor for class org.elasticsearch.search.rescore.RescoreSearchContext
-
- resendShardFailed(ShardRouting, String, DiscoveryNode, String, Throwable) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.UniqueTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.PrefixAnalyzer.PrefixTokenFilter
-
- reset(QueryParserSettings) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
-
- reset(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateObserver
-
reset this observer to the give cluster state.
- 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.compress.CompressedStreamInput
-
- reset(double, double) - Method in class org.elasticsearch.common.geo.GeoPoint
-
- 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.FastCharArrayReader
-
Resets the stream to the most recent mark, or to the beginning if it has
never been marked.
- reset() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Resets the buffer so that you can use it again without
throwing away the already allocated buffer.
- reset() - Method in class org.elasticsearch.common.io.FastStringReader
-
Resets the stream to the most recent mark, or to the beginning of the
string if it has never been marked.
- 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.StreamInput
-
Resets the stream.
- 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.all.AllEntries
-
- reset() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
-
- reset() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
-
resets (clears) this timer before next execution.
- reset(Throwable) - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
-
Resets the barrier to its initial state.
- reset() - Method in class org.elasticsearch.gateway.Gateway
-
- reset() - Method in class org.elasticsearch.index.analysis.NumericTokenizer
-
- reset() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
-
- reset(String) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
-
- reset() - Method in class org.elasticsearch.index.mapper.ContentPath
-
- reset(XContentParser, ParseContext.Document, SourceToParse) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- reset(XContentParser) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- 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(InternalSearchHit, LeafReaderContext, int, IndexSearcher) - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
-
- reset() - Method in class org.elasticsearch.search.internal.InternalSearchHits.StreamContext
-
- reset() - Method in class org.elasticsearch.search.lookup.CachedPositionIterator
-
- reset() - Method in class org.elasticsearch.search.lookup.PositionIterator
-
- reset() - Method in class org.elasticsearch.search.suggest.completion.CompletionTokenStream
-
- reset(TokenStream) - Method in class org.elasticsearch.search.suggest.SuggestUtils.TokenConsumer
-
- reset() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- resetAndLog(String) - Method in class org.elasticsearch.common.inject.internal.Stopwatch
-
Resets and logs elapsed time in milliseconds.
- resetCookies - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- resetDigest() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
-
- resetDigest() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
-
- resetFromGeoHash(String) - Method in class org.elasticsearch.common.geo.GeoPoint
-
- resetFromGeoHash(long) - 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
-
- resetLat(double) - Method in class org.elasticsearch.common.geo.GeoPoint
-
- resetLon(double) - Method in class org.elasticsearch.common.geo.GeoPoint
-
- resetRecovery() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- resize(ByteArray, 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(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(ObjectArray<T>, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
-
- resize(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
- resize(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
-
- resolve(String) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
-
- resolve(CommandLine) - Static method in enum org.elasticsearch.common.cli.Terminal.Verbosity
-
- resolve(byte) - Static method in enum org.elasticsearch.common.rounding.DateTimeUnit
-
- resolve(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment.NodePath
-
Resolves the given shards directory against this NodePath
- resolve(Index) - Method in class org.elasticsearch.env.NodeEnvironment.NodePath
-
Resolves the given indexes directory against this NodePath
- 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, DeleteRequest) - Static method in class org.elasticsearch.action.delete.TransportDeleteAction
-
- resolveAndValidateRouting(MetaData, String, UpdateRequest) - Static method in class org.elasticsearch.action.update.TransportUpdateAction
-
- resolveBindHostAddresses(String[]) - Method in class org.elasticsearch.common.network.NetworkService
-
Resolves bindHosts
to a list of internet addresses.
- resolveBucketValue(InternalMultiBucketAggregation<?, ? extends MultiBucketsAggregation.Bucket>, MultiBucketsAggregation.Bucket, 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(InternalMultiBucketAggregation<?, ? extends MultiBucketsAggregation.Bucket>, MultiBucketsAggregation.Bucket, List<String>, BucketHelpers.GapPolicy) - Static method in class org.elasticsearch.search.aggregations.pipeline.BucketHelpers
-
- resolveClosestNestedObjectMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
- resolveCustomLocation(Settings, ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Resolve the custom path for a index's shard.
- 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.
- resolveDistance(String) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- resolveForScript(String) - Static method in enum org.elasticsearch.search.aggregations.support.ValueType
-
- resolveFromName(String) - Static method in enum org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesMethod
-
- resolveIfPossible(String) - Method in interface org.elasticsearch.common.network.NetworkService.CustomNameResolver
-
Resolves a custom value handling, return null if can't handle it.
- 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() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
-
- resolveIndex(ExplainRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
-
- resolveIndex(GetRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
-
- resolveIndex(MultiGetShardRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
-
- resolveIndex(TransportShardMultiPercolateAction.Request) - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
-
- resolveIndex() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
True if provided index should be resolved when resolving request
- resolveIndex(Request) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
- resolveIndex(MultiTermVectorsShardRequest) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
-
- resolveIndex(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
-
- resolveIndex() - Method in class org.elasticsearch.index.shard.ShardPath
-
- resolveIndexRouting(String, String) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
Returns indexing routing for the given index.
- resolveNode(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Resolve a node with a given id
- resolveNodes(NodesRequest, ClusterState) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
- resolveNodes(TasksRequest, ClusterState) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
- resolveNodes(TransportNodesListGatewayStartedShards.Request, ClusterState) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
-
- resolveNodes(TransportNodesListShardStoreMetaData.Request, ClusterState) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
-
- resolveNodesIds(String...) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
- resolvePlaceholder(String) - Method in interface org.elasticsearch.common.property.PropertyPlaceholder.PlaceholderResolver
-
Resolves the supplied placeholder name into the replacement value.
- 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(MetaData, String, DeleteRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
-
- resolveRequest(ClusterState, TransportSingleShardAction<ExplainRequest, ExplainResponse>.InternalRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
-
- resolveRequest(ClusterState, TransportSingleShardAction<GetRequest, GetResponse>.InternalRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
-
- resolveRequest(ClusterState, TransportSingleShardAction<MultiGetShardRequest, MultiGetShardResponse>.InternalRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
-
- resolveRequest(MetaData, String, IndexRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
-
- resolveRequest(MetaData, String, Request) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Resolves the target shard id of the incoming request.
- resolveRequest(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
Resolves the request.
- resolveRequest(ClusterState, TransportSingleShardAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
- resolveRequest(ClusterState, TransportSingleShardAction<TermVectorsRequest, TermVectorsResponse>.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
-
- resolveRequest(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
-
- resolveSearchRouting(ClusterState, String, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Resolves the search routing if in the expression aliases are used.
- resolveSort(String) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- resolveStatesToBeWritten(ImmutableSet<String>, Set<String>, 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.
- resolveStrategy(String) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- resolveSuggestMode(String) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- 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(HasAggregations) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Resolves the value pointed by this path given an aggregations root
- ResourceNotFoundException - Exception in org.elasticsearch
-
- 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.
- ResourceWatcherModule - Class in org.elasticsearch.watcher
-
- ResourceWatcherModule() - Constructor for class org.elasticsearch.watcher.ResourceWatcherModule
-
- ResourceWatcherService - Class in org.elasticsearch.watcher
-
- ResourceWatcherService(Settings, ThreadPool) - Constructor for class org.elasticsearch.watcher.ResourceWatcherService
-
- ResourceWatcherService.Frequency - Enum in org.elasticsearch.watcher
-
- Response() - Constructor for class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response
-
- response() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response.Item
-
- response - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction.WriteResult
-
- response() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.WriteResult
-
- Response(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Response
-
- response - Variable in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
- 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
-
- REST_DECODER - Static variable in class org.elasticsearch.rest.support.RestUtils
-
- REST_EXCEPTION_SKIP_CAUSE - Static variable in exception org.elasticsearch.ElasticsearchException
-
- REST_EXCEPTION_SKIP_CAUSE_DEFAULT - Static variable in exception org.elasticsearch.ElasticsearchException
-
- REST_EXCEPTION_SKIP_STACK_TRACE - Static variable in exception org.elasticsearch.ElasticsearchException
-
- REST_EXCEPTION_SKIP_STACK_TRACE_DEFAULT - Static variable in exception org.elasticsearch.ElasticsearchException
-
- RestActionListener<Response> - Class in org.elasticsearch.rest.action.support
-
- RestActionListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.support.RestActionListener
-
- RestActionModule - Class in org.elasticsearch.rest.action
-
- RestActionModule(List<Class<? extends BaseRestHandler>>) - Constructor for class org.elasticsearch.rest.action.RestActionModule
-
- RestActions - Class in org.elasticsearch.rest.action.support
-
- RestActions() - Constructor for class org.elasticsearch.rest.action.support.RestActions
-
- RestAliasAction - Class in org.elasticsearch.rest.action.cat
-
- RestAliasAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestAliasAction
-
- RestAliasesExistAction - Class in org.elasticsearch.rest.action.admin.indices.alias.head
-
- RestAliasesExistAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.alias.head.RestAliasesExistAction
-
- RestAllocationAction - Class in org.elasticsearch.rest.action.cat
-
- RestAllocationAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestAllocationAction
-
- RestAnalyzeAction - Class in org.elasticsearch.rest.action.admin.indices.analyze
-
- RestAnalyzeAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction
-
- RestAnalyzeAction.Fields - Class in org.elasticsearch.rest.action.admin.indices.analyze
-
- restart(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
-
- RestBuilderListener<Response> - Class in org.elasticsearch.rest.action.support
-
- RestBuilderListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.support.RestBuilderListener
-
- RestBulkAction - Class in org.elasticsearch.rest.action.bulk
-
{ "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, Client) - Constructor for class org.elasticsearch.rest.action.bulk.RestBulkAction
-
- RestCancelTasksAction - Class in org.elasticsearch.rest.action.admin.cluster.node.tasks
-
- RestCancelTasksAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.node.tasks.RestCancelTasksAction
-
- RestCatAction - Class in org.elasticsearch.rest.action.cat
-
- RestCatAction(Settings, RestController, Set<AbstractCatAction>, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestCatAction
-
- RestChannel - Class in org.elasticsearch.rest
-
A channel used to construct bytes / builder based outputs, and send responses.
- RestChannel(RestRequest, boolean) - Constructor for class org.elasticsearch.rest.RestChannel
-
- RestClearIndicesCacheAction - Class in org.elasticsearch.rest.action.admin.indices.cache.clear
-
- RestClearIndicesCacheAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction
-
- RestClearIndicesCacheAction.Fields - Class in org.elasticsearch.rest.action.admin.indices.cache.clear
-
- RestClearScrollAction - Class in org.elasticsearch.rest.action.search
-
- RestClearScrollAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.search.RestClearScrollAction
-
- RestCloseIndexAction - Class in org.elasticsearch.rest.action.admin.indices.close
-
- RestCloseIndexAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.close.RestCloseIndexAction
-
- RestClusterGetSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster.settings
-
- RestClusterGetSettingsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.settings.RestClusterGetSettingsAction
-
- RestClusterHealthAction - Class in org.elasticsearch.rest.action.admin.cluster.health
-
- RestClusterHealthAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.health.RestClusterHealthAction
-
- RestClusterRerouteAction - Class in org.elasticsearch.rest.action.admin.cluster.reroute
-
- RestClusterRerouteAction(Settings, RestController, Client, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.reroute.RestClusterRerouteAction
-
- RestClusterSearchShardsAction - Class in org.elasticsearch.rest.action.admin.cluster.shards
-
- RestClusterSearchShardsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.shards.RestClusterSearchShardsAction
-
- RestClusterStateAction - Class in org.elasticsearch.rest.action.admin.cluster.state
-
- RestClusterStateAction(Settings, RestController, Client, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.state.RestClusterStateAction
-
- RestClusterStatsAction - Class in org.elasticsearch.rest.action.admin.cluster.stats
-
- RestClusterStatsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.stats.RestClusterStatsAction
-
- RestClusterUpdateSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster.settings
-
- RestClusterUpdateSettingsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.settings.RestClusterUpdateSettingsAction
-
- restContentType() - Method in enum org.elasticsearch.common.xcontent.XContentType
-
- RestController - Class in org.elasticsearch.rest
-
- RestController(Settings) - Constructor for class org.elasticsearch.rest.RestController
-
- RestCountAction - Class in org.elasticsearch.rest.action.cat
-
- RestCountAction(Settings, RestController, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestCountAction
-
- RestCountAction - Class in org.elasticsearch.rest.action.count
-
- RestCountAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.count.RestCountAction
-
- RestCreateIndexAction - Class in org.elasticsearch.rest.action.admin.indices.create
-
- RestCreateIndexAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.create.RestCreateIndexAction
-
- RestCreateSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster.snapshots.create
-
Creates a new snapshot
- RestCreateSnapshotAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.snapshots.create.RestCreateSnapshotAction
-
- RestDeleteAction - Class in org.elasticsearch.rest.action.delete
-
- RestDeleteAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.delete.RestDeleteAction
-
- RestDeleteIndexAction - Class in org.elasticsearch.rest.action.admin.indices.delete
-
- RestDeleteIndexAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.delete.RestDeleteIndexAction
-
- RestDeleteIndexedScriptAction - Class in org.elasticsearch.rest.action.script
-
- RestDeleteIndexedScriptAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.script.RestDeleteIndexedScriptAction
-
- RestDeleteIndexedScriptAction(Settings, RestController, boolean, Client) - Constructor for class org.elasticsearch.rest.action.script.RestDeleteIndexedScriptAction
-
- RestDeleteIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices.template.delete
-
- RestDeleteIndexTemplateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.template.delete.RestDeleteIndexTemplateAction
-
- RestDeleteRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster.repositories.delete
-
Unregisters a repository
- RestDeleteRepositoryAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.repositories.delete.RestDeleteRepositoryAction
-
- RestDeleteSearchTemplateAction - Class in org.elasticsearch.rest.action.template
-
- RestDeleteSearchTemplateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.template.RestDeleteSearchTemplateAction
-
- RestDeleteSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster.snapshots.delete
-
Deletes a snapshot
- RestDeleteSnapshotAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.snapshots.delete.RestDeleteSnapshotAction
-
- RestDeleteWarmerAction - Class in org.elasticsearch.rest.action.admin.indices.warmer.delete
-
- RestDeleteWarmerAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.warmer.delete.RestDeleteWarmerAction
-
- RestExistsAction - Class in org.elasticsearch.rest.action.exists
-
- RestExistsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.exists.RestExistsAction
-
Deprecated.
- RestExplainAction - Class in org.elasticsearch.rest.action.explain
-
Rest action for computing a score explanation for specific documents.
- RestExplainAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.explain.RestExplainAction
-
- 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, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestFielddataAction
-
- RestFieldStatsAction - Class in org.elasticsearch.rest.action.fieldstats
-
- RestFieldStatsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.fieldstats.RestFieldStatsAction
-
- RestFilter - Class in org.elasticsearch.rest
-
A filter allowing to filter rest operations.
- RestFilter() - Constructor for class org.elasticsearch.rest.RestFilter
-
- RestFilterChain - Interface in org.elasticsearch.rest
-
A filter chain allowing to continue and process the rest request.
- RestFlushAction - Class in org.elasticsearch.rest.action.admin.indices.flush
-
- RestFlushAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.flush.RestFlushAction
-
- RestForceMergeAction - Class in org.elasticsearch.rest.action.admin.indices.forcemerge
-
- RestForceMergeAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.forcemerge.RestForceMergeAction
-
- RestGetAction - Class in org.elasticsearch.rest.action.get
-
- RestGetAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.get.RestGetAction
-
- RestGetAliasesAction - Class in org.elasticsearch.rest.action.admin.indices.alias.get
-
- RestGetAliasesAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.alias.get.RestGetAliasesAction
-
- RestGetFieldMappingAction - Class in org.elasticsearch.rest.action.admin.indices.mapping.get
-
- RestGetFieldMappingAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.mapping.get.RestGetFieldMappingAction
-
- RestGetIndexedScriptAction - Class in org.elasticsearch.rest.action.script
-
- RestGetIndexedScriptAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.script.RestGetIndexedScriptAction
-
- RestGetIndexedScriptAction(Settings, RestController, boolean, Client) - Constructor for class org.elasticsearch.rest.action.script.RestGetIndexedScriptAction
-
- RestGetIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices.template.get
-
- RestGetIndexTemplateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.template.get.RestGetIndexTemplateAction
-
- RestGetIndicesAction - Class in org.elasticsearch.rest.action.admin.indices.get
-
- RestGetIndicesAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.get.RestGetIndicesAction
-
- RestGetIndicesAliasesAction - Class in org.elasticsearch.rest.action.admin.indices.alias.get
-
Deprecated.
- RestGetIndicesAliasesAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.alias.get.RestGetIndicesAliasesAction
-
Deprecated.
- RestGetMappingAction - Class in org.elasticsearch.rest.action.admin.indices.mapping.get
-
- RestGetMappingAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.mapping.get.RestGetMappingAction
-
- RestGetRepositoriesAction - Class in org.elasticsearch.rest.action.admin.cluster.repositories.get
-
Returns repository information
- RestGetRepositoriesAction(Settings, RestController, Client, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.repositories.get.RestGetRepositoriesAction
-
- RestGetSearchTemplateAction - Class in org.elasticsearch.rest.action.template
-
- RestGetSearchTemplateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.template.RestGetSearchTemplateAction
-
- RestGetSettingsAction - Class in org.elasticsearch.rest.action.admin.indices.settings
-
- RestGetSettingsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.settings.RestGetSettingsAction
-
- RestGetSnapshotsAction - Class in org.elasticsearch.rest.action.admin.cluster.snapshots.get
-
Returns information about snapshot
- RestGetSnapshotsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.snapshots.get.RestGetSnapshotsAction
-
- RestGetSourceAction - Class in org.elasticsearch.rest.action.get
-
- RestGetSourceAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.get.RestGetSourceAction
-
- RestGetWarmerAction - Class in org.elasticsearch.rest.action.admin.indices.warmer.get
-
- RestGetWarmerAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.warmer.get.RestGetWarmerAction
-
- RestHandler - Interface in org.elasticsearch.rest
-
Handler for REST requests
- RestHeadAction - Class in org.elasticsearch.rest.action.get
-
- RestHeadAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.get.RestHeadAction
-
- RestHeadIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices.template.head
-
- RestHeadIndexTemplateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.template.head.RestHeadIndexTemplateAction
-
- RestHealthAction - Class in org.elasticsearch.rest.action.cat
-
- RestHealthAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestHealthAction
-
- RestIndexAction - Class in org.elasticsearch.rest.action.index
-
- RestIndexAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.index.RestIndexAction
-
- RestIndexDeleteAliasesAction - Class in org.elasticsearch.rest.action.admin.indices.alias.delete
-
- RestIndexDeleteAliasesAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.alias.delete.RestIndexDeleteAliasesAction
-
- RestIndexPutAliasAction - Class in org.elasticsearch.rest.action.admin.indices.alias.put
-
- RestIndexPutAliasAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.alias.put.RestIndexPutAliasAction
-
- RestIndicesAction - Class in org.elasticsearch.rest.action.cat
-
- RestIndicesAction(Settings, RestController, Client, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.rest.action.cat.RestIndicesAction
-
- RestIndicesAliasesAction - Class in org.elasticsearch.rest.action.admin.indices.alias
-
- RestIndicesAliasesAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.alias.RestIndicesAliasesAction
-
- RestIndicesExistsAction - Class in org.elasticsearch.rest.action.admin.indices.exists.indices
-
- RestIndicesExistsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.exists.indices.RestIndicesExistsAction
-
- RestIndicesSegmentsAction - Class in org.elasticsearch.rest.action.admin.indices.segments
-
- RestIndicesSegmentsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.segments.RestIndicesSegmentsAction
-
- RestIndicesShardStoresAction - Class in org.elasticsearch.rest.action.admin.indices.shards
-
- RestIndicesShardStoresAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.shards.RestIndicesShardStoresAction
-
- RestIndicesStatsAction - Class in org.elasticsearch.rest.action.admin.indices.stats
-
- RestIndicesStatsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.stats.RestIndicesStatsAction
-
- RestListTasksAction - Class in org.elasticsearch.rest.action.admin.cluster.node.tasks
-
- RestListTasksAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.node.tasks.RestListTasksAction
-
- RestMainAction - Class in org.elasticsearch.rest.action.main
-
- RestMainAction(Settings, Version, RestController, ClusterName, Client, ClusterService) - Constructor for class org.elasticsearch.rest.action.main.RestMainAction
-
- RestMasterAction - Class in org.elasticsearch.rest.action.cat
-
- RestMasterAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestMasterAction
-
- RestModule - Class in org.elasticsearch.rest
-
- RestModule(Settings) - Constructor for class org.elasticsearch.rest.RestModule
-
- RestMultiGetAction - Class in org.elasticsearch.rest.action.get
-
- RestMultiGetAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.get.RestMultiGetAction
-
- RestMultiPercolateAction - Class in org.elasticsearch.rest.action.percolate
-
- RestMultiPercolateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.percolate.RestMultiPercolateAction
-
- RestMultiSearchAction - Class in org.elasticsearch.rest.action.search
-
- RestMultiSearchAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.search.RestMultiSearchAction
-
- RestMultiTermVectorsAction - Class in org.elasticsearch.rest.action.termvectors
-
- RestMultiTermVectorsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.termvectors.RestMultiTermVectorsAction
-
- RestNodeAttrsAction - Class in org.elasticsearch.rest.action.cat
-
- RestNodeAttrsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
-
- RestNodesAction - Class in org.elasticsearch.rest.action.cat
-
- RestNodesAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestNodesAction
-
- RestNodesHotThreadsAction - Class in org.elasticsearch.rest.action.admin.cluster.node.hotthreads
-
- RestNodesHotThreadsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.node.hotthreads.RestNodesHotThreadsAction
-
- RestNodesInfoAction - Class in org.elasticsearch.rest.action.admin.cluster.node.info
-
- RestNodesInfoAction(Settings, RestController, Client, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.node.info.RestNodesInfoAction
-
- RestNodesStatsAction - Class in org.elasticsearch.rest.action.admin.cluster.node.stats
-
- RestNodesStatsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.node.stats.RestNodesStatsAction
-
- RestOpenIndexAction - Class in org.elasticsearch.rest.action.admin.indices.open
-
- RestOpenIndexAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.open.RestOpenIndexAction
-
- restorable() - Method in enum org.elasticsearch.snapshots.SnapshotState
-
Returns true if snapshot can be restored (at least partially)
- restore(SnapshotId, Version, ShardId, ShardId, RecoveryState) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
Restores snapshot of the shard.
- restore(SnapshotId, Version, ShardId, ShardId, RecoveryState) - Method in interface org.elasticsearch.index.snapshots.IndexShardRepository
-
Restores snapshot of the shard.
- 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 - Class in org.elasticsearch.cluster
-
Meta data about restore processes that are currently executing
- RestoreInProgress(List<RestoreInProgress.Entry>) - Constructor for class org.elasticsearch.cluster.RestoreInProgress
-
Constructs new restore metadata
- RestoreInProgress(RestoreInProgress.Entry...) - Constructor for class org.elasticsearch.cluster.RestoreInProgress
-
Constructs new restore metadata
- 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
- RestoreRequest(String, String, String, String[], IndicesOptions, String, String, Settings, TimeValue, boolean, boolean, boolean, Settings, String[]) - Constructor for class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Constructs new restore request
- RestoreService - Class in org.elasticsearch.snapshots
-
Service responsible for restoring snapshots
- RestoreService(Settings, ClusterService, RepositoriesService, TransportService, AllocationService, MetaDataCreateIndexService, DynamicSettings, MetaDataIndexUpgradeService) - Constructor for class org.elasticsearch.snapshots.RestoreService
-
- RestoreService.RestoreCompletionResponse - Class in org.elasticsearch.snapshots
-
- RestoreService.RestoreRequest - Class in org.elasticsearch.snapshots
-
Restore snapshot request
- RestoreService.UpdateIndexShardRestoreStatusRequest - Class in org.elasticsearch.snapshots
-
Internal class that is used to send notifications about finished shard restore operations to master node
- 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(RestoreService.RestoreRequest, ActionListener<RestoreInfo>) - 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 - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Restore snapshot request
- RestoreSnapshotRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
- RestoreSnapshotRequest(String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Constructs a new put repository request with the provided repository and snapshot names.
- restoreSnapshotRequest(String, String) - Static method in class org.elasticsearch.client.Requests
-
Restores new snapshot
- 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
- RestoreSource - Class in org.elasticsearch.cluster.routing
-
Represents snapshot and index from which a recovering index should be restored
- RestoreSource(SnapshotId, Version, String) - Constructor for class org.elasticsearch.cluster.routing.RestoreSource
-
- restoreSource() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Snapshot id and repository where this shard is being restored from
- restoreThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
- restoreThrottleTimeInNanos() - Method in interface org.elasticsearch.repositories.Repository
-
Returns restore throttle time in nanoseconds
- RestPendingClusterTasksAction - Class in org.elasticsearch.rest.action.admin.cluster.tasks
-
- RestPendingClusterTasksAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.tasks.RestPendingClusterTasksAction
-
- RestPendingClusterTasksAction - Class in org.elasticsearch.rest.action.cat
-
- RestPendingClusterTasksAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
-
- RestPercolateAction - Class in org.elasticsearch.rest.action.percolate
-
- RestPercolateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.percolate.RestPercolateAction
-
- RestPluginsAction - Class in org.elasticsearch.rest.action.cat
-
- RestPluginsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestPluginsAction
-
- RestPutIndexedScriptAction - Class in org.elasticsearch.rest.action.script
-
- RestPutIndexedScriptAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.script.RestPutIndexedScriptAction
-
- RestPutIndexedScriptAction(Settings, RestController, boolean, Client) - Constructor for class org.elasticsearch.rest.action.script.RestPutIndexedScriptAction
-
- RestPutIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices.template.put
-
- RestPutIndexTemplateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.template.put.RestPutIndexTemplateAction
-
- RestPutMappingAction - Class in org.elasticsearch.rest.action.admin.indices.mapping.put
-
- RestPutMappingAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.mapping.put.RestPutMappingAction
-
- RestPutRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster.repositories.put
-
Registers repositories
- RestPutRepositoryAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.repositories.put.RestPutRepositoryAction
-
- RestPutSearchTemplateAction - Class in org.elasticsearch.rest.action.template
-
- RestPutSearchTemplateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.template.RestPutSearchTemplateAction
-
- RestPutWarmerAction - Class in org.elasticsearch.rest.action.admin.indices.warmer.put
-
- RestPutWarmerAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.warmer.put.RestPutWarmerAction
-
- RestRecoveryAction - Class in org.elasticsearch.rest.action.admin.indices.recovery
-
REST handler to report on index recoveries.
- RestRecoveryAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.recovery.RestRecoveryAction
-
- 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, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestRecoveryAction
-
- RestRefreshAction - Class in org.elasticsearch.rest.action.admin.indices.refresh
-
- RestRefreshAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.refresh.RestRefreshAction
-
- RestRenderSearchTemplateAction - Class in org.elasticsearch.rest.action.admin.indices.validate.template
-
- RestRenderSearchTemplateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.validate.template.RestRenderSearchTemplateAction
-
- RestRepositoriesAction - Class in org.elasticsearch.rest.action.cat
-
Cat API class to display information about snapshot repositories
- RestRepositoriesAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestRepositoriesAction
-
- RestRequest - Class in org.elasticsearch.rest
-
- RestRequest() - Constructor for class org.elasticsearch.rest.RestRequest
-
- RestRequest.Method - Enum in org.elasticsearch.rest
-
- RestResponse - Class in org.elasticsearch.rest
-
- RestResponse() - Constructor for class org.elasticsearch.rest.RestResponse
-
- RestResponseListener<Response> - Class in org.elasticsearch.rest.action.support
-
- RestResponseListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.support.RestResponseListener
-
- RestRestoreSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster.snapshots.restore
-
Restores a snapshot
- RestRestoreSnapshotAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.snapshots.restore.RestRestoreSnapshotAction
-
- RestSearchAction - Class in org.elasticsearch.rest.action.search
-
- RestSearchAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.search.RestSearchAction
-
- RestSearchScrollAction - Class in org.elasticsearch.rest.action.search
-
- RestSearchScrollAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.search.RestSearchScrollAction
-
- RestSegmentsAction - Class in org.elasticsearch.rest.action.cat
-
- RestSegmentsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestSegmentsAction
-
- RestShardsAction - Class in org.elasticsearch.rest.action.cat
-
- RestShardsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestShardsAction
-
- RestSnapshotAction - Class in org.elasticsearch.rest.action.cat
-
Cat API class to display information about snapshots
- RestSnapshotAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestSnapshotAction
-
- RestSnapshotsStatusAction - Class in org.elasticsearch.rest.action.admin.cluster.snapshots.status
-
Returns status of currently running snapshot
- RestSnapshotsStatusAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.snapshots.status.RestSnapshotsStatusAction
-
- restStatus() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
-
- RestStatus - Enum in org.elasticsearch.rest
-
- RestStatusToXContentListener<Response extends StatusToXContent> - Class in org.elasticsearch.rest.action.support
-
- RestStatusToXContentListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.support.RestStatusToXContentListener
-
- RestSuggestAction - Class in org.elasticsearch.rest.action.suggest
-
- RestSuggestAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.suggest.RestSuggestAction
-
- RestSyncedFlushAction - Class in org.elasticsearch.rest.action.admin.indices.flush
-
- RestSyncedFlushAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.flush.RestSyncedFlushAction
-
- RestTable - Class in org.elasticsearch.rest.action.support
-
- RestTable() - Constructor for class org.elasticsearch.rest.action.support.RestTable
-
- RestTermVectorsAction - Class in org.elasticsearch.rest.action.termvectors
-
This class parses the json request and translates it into a
TermVectorsRequest.
- RestTermVectorsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.termvectors.RestTermVectorsAction
-
- RestThreadPoolAction - Class in org.elasticsearch.rest.action.cat
-
- RestThreadPoolAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.cat.RestThreadPoolAction
-
- RestToXContentListener<Response extends ToXContent> - Class in org.elasticsearch.rest.action.support
-
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.support.RestToXContentListener
-
- RestTypesExistsAction - Class in org.elasticsearch.rest.action.admin.indices.exists.types
-
Rest api for checking if a type exists.
- RestTypesExistsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.exists.types.RestTypesExistsAction
-
- RestUpdateAction - Class in org.elasticsearch.rest.action.update
-
- RestUpdateAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.update.RestUpdateAction
-
- RestUpdateSettingsAction - Class in org.elasticsearch.rest.action.admin.indices.settings
-
- RestUpdateSettingsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.settings.RestUpdateSettingsAction
-
- RestUpgradeAction - Class in org.elasticsearch.rest.action.admin.indices.upgrade
-
- RestUpgradeAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.upgrade.RestUpgradeAction
-
- RestUtils - Class in org.elasticsearch.rest.support
-
- RestUtils() - Constructor for class org.elasticsearch.rest.support.RestUtils
-
- RestValidateQueryAction - Class in org.elasticsearch.rest.action.admin.indices.validate.query
-
- RestValidateQueryAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.validate.query.RestValidateQueryAction
-
- RestVerifyRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster.repositories.verify
-
Registers repositories
- RestVerifyRepositoryAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.repositories.verify.RestVerifyRepositoryAction
-
- Result(Streamable, UpdateHelper.Operation, Map<String, Object>, XContentType) - Constructor for class org.elasticsearch.action.update.UpdateHelper.Result
-
- Result(boolean, RoutingTable) - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
-
- Result(boolean, RoutingTable, RoutingExplanations) - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
-
- result() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
-
- Result(Correction[], double) - Constructor for class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker.Result
-
- resultingState - Variable in class org.elasticsearch.cluster.ClusterStateTaskExecutor.BatchResult
-
- resume() - Method in class org.elasticsearch.watcher.WatcherHandle
-
- resumeEncoding() - Method in class org.elasticsearch.common.Base64.OutputStream
-
Resumes encoding of the stream.
- 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.
- reThrowIfNotNull(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
Throws the specified exception.
- retrieve(String) - Method in class org.elasticsearch.common.path.PathTrie
-
- retrieve(String, Map<String, String>) - Method in class org.elasticsearch.common.path.PathTrie
-
- retrieve(String[], int, Map<String, String>) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
-
- 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.
- 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
-
- retryDelayNetwork() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- retryDelayStateSync() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- RetryListener(TransportClientNodesService.NodeListenerCallback<Response>, ActionListener<Response>, List<DiscoveryNode>, int) - Constructor for class org.elasticsearch.client.transport.TransportClientNodesService.RetryListener
-
- 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.
- retryOnConflict() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- retryOnFailure(Throwable) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
- retryOnFailure(Throwable) - Method in class org.elasticsearch.action.update.TransportUpdateAction
-
- RetryOnPrimaryException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnPrimaryException
-
- RetryOnPrimaryException(StreamInput) - Constructor for exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnPrimaryException
-
- RetryOnReplicaException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException
-
- RetryOnReplicaException(StreamInput) - Constructor for exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException
-
- retryPrimaryException(Throwable) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- retryRecovery(RecoveryStatus, String, TimeValue, StartRecoveryRequest) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
- 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.http.netty.NettyHttpServerTransport
-
- 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
-
- ReverseNested - Interface in org.elasticsearch.search.aggregations.bucket.nested
-
A reverse nested
aggregation.
- ReverseNestedAggregator - Class in org.elasticsearch.search.aggregations.bucket.nested
-
- ReverseNestedAggregator(String, AggregatorFactories, ObjectMapper, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
-
- ReverseNestedAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.nested
-
- ReverseNestedBuilder - Class in org.elasticsearch.search.aggregations.bucket.nested
-
- ReverseNestedBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedBuilder
-
Sole constructor.
- ReverseNestedParser - Class in org.elasticsearch.search.aggregations.bucket.nested
-
- ReverseNestedParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedParser
-
- ReverseTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- ReverseTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ReverseTokenFilterFactory
-
- revision - Variable in class org.elasticsearch.Version
-
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.BlendedTermQuery
-
- rewrite() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
-
- rewrite(boolean) - 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.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be rewritten into primitive queries
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
-
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.IndexCacheableQuery
-
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
-
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
- 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(IndexReader) - Method in class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
-
Deprecated.
- rewrite(IndexReader) - Method in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- rewrite(IndexReader) - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
-
Deprecated.
- rewrite(IndexReader) - Method in class org.elasticsearch.index.search.child.ParentQuery
-
Deprecated.
- rewrite(IndexReader) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeQuery
-
- rewrite(IndexReader) - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
-
- rewrite(Query) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
- rewriteMethod() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- rewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- RIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- Ring(P) - Constructor for class org.elasticsearch.common.geo.builders.BasePolygonBuilder.Ring
-
- Ring(P, ArrayList<Coordinate>) - Constructor for class org.elasticsearch.common.geo.builders.BasePolygonBuilder.Ring
-
- ring(int, boolean, boolean, BaseLineStringBuilder<?>, Coordinate[], int, ShapeBuilder.Edge[], int, int) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
-
Create a connected list of a list of coordinates
- rint(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- rint(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- rint(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- rint(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- rint(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- rollback() - Method in class org.elasticsearch.index.translog.Translog
-
- RomanianAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- RomanianAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.RomanianAnalyzerProvider
-
- 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.
- rootLogger() - Method in class org.elasticsearch.common.logging.ESLoggerFactory
-
- rootLogger() - Method in class org.elasticsearch.common.logging.jdk.JdkESLoggerFactory
-
- rootLogger() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLoggerFactory
-
- rootLogger() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLoggerFactory
-
- rootObject(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- RootObjectMapper - Class in org.elasticsearch.index.mapper.object
-
- RootObjectMapper.Builder - Class in org.elasticsearch.index.mapper.object
-
- RootObjectMapper.Defaults - Class in org.elasticsearch.index.mapper.object
-
- RootObjectMapper.TypeParser - Class in org.elasticsearch.index.mapper.object
-
- rotate(List<T>, int) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
Return a rotated view of the given list with the given distance.
- RotationShardShuffler - Class in org.elasticsearch.cluster.routing
-
- RotationShardShuffler(int) - Constructor for class org.elasticsearch.cluster.routing.RotationShardShuffler
-
- rotl64(long, int) - Static method in class org.elasticsearch.common.util.BloomFilter
-
- round(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- round(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- round(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- round(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- round(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- round(long) - Method in class org.elasticsearch.common.rounding.Rounding
-
Rounds the given value, equivalent to calling roundValue(roundKey(value))
.
- Rounding - Class in org.elasticsearch.common.rounding
-
A strategy for rounding long values.
- Rounding() - Constructor for class org.elasticsearch.common.rounding.Rounding
-
- Rounding.FactorRounding - Class in org.elasticsearch.common.rounding
-
- Rounding.Interval - Class in org.elasticsearch.common.rounding
-
Rounding strategy which is based on an interval
rounded = value - (value % interval)
- Rounding.OffsetRounding - Class in org.elasticsearch.common.rounding
-
- Rounding.Streams - Class in org.elasticsearch.common.rounding
-
- roundKey(long) - Method in class org.elasticsearch.common.rounding.Rounding.FactorRounding
-
- roundKey(long, long) - Static method in class org.elasticsearch.common.rounding.Rounding.Interval
-
- roundKey(long) - Method in class org.elasticsearch.common.rounding.Rounding.Interval
-
- roundKey(long) - Method in class org.elasticsearch.common.rounding.Rounding.OffsetRounding
-
- roundKey(long) - Method in class org.elasticsearch.common.rounding.Rounding
-
Given a value, compute a key that uniquely identifies the rounded value although it is not necessarily equal to the rounding value itself.
- roundValue(long, long) - Static method in class org.elasticsearch.common.rounding.Rounding.Interval
-
- 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(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.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.admin.indices.alias.Alias
-
Associates a routing value to the alias
- routing(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
- routing - Variable in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
- routing() - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
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.count.CountRequest
-
Deprecated.
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.count.CountRequest
-
Deprecated.
The routing values to control the shards that the search will be executed on.
- routing(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Controls the shard routing of the request.
- routing() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Controls the shard routing of the delete request.
- routing(String) - Method in interface org.elasticsearch.action.DocumentRequest
-
Set the routing for this request
- routing() - Method in interface org.elasticsearch.action.DocumentRequest
-
Get the routing for this request
- routing - Variable in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
- routing() - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
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.exists.ExistsRequest
-
Deprecated.
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.exists.ExistsRequest
-
Deprecated.
The routing values to control the shards that the search will be executed on.
- routing() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- 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() - Method in class org.elasticsearch.action.get.GetRequest
-
- routing(String) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
The routing associated with this document.
- routing() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- routing(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Controls the shard routing of the request.
- routing() - Method in class org.elasticsearch.action.index.IndexRequest
-
Controls the shard routing of the request.
- routing() - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- routing(String) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- 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(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.search.SearchRequest
-
The routing values to control the shards that the search will be executed on.
- routing() - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
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.suggest.SuggestRequest
-
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.suggest.SuggestRequest
-
The routing values to control the shards that the search will be executed on.
- routing() - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyRequest
-
- routing() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- 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() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Controls the shard routing of the request.
- routing(String) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- routing(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- routing() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
The routing value parsed, null if does not require parsing, or not resolved.
- routing() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
- Routing(boolean, String) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
-
- routing() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- 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(String) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- ROUTING - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item.Field
-
- routing() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- routing(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- routing() - Method in class org.elasticsearch.index.translog.Translog.Create
-
- routing() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- routing - Variable in class org.elasticsearch.index.translog.Translog.Source
-
- RoutingAllocation - Class in org.elasticsearch.cluster.routing.allocation
-
- RoutingAllocation(AllocationDeciders, RoutingNodes, DiscoveryNodes, ClusterInfo, long) - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
- RoutingAllocation.Result - Class in org.elasticsearch.cluster.routing.allocation
-
- routingEntry() - Method in class org.elasticsearch.index.shard.IndexShard
-
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
-
- 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.internal
-
- RoutingFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- RoutingFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- RoutingFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- 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 single
DiscoveryNode
including all shards
that are hosted on that nodes.
- RoutingNode(String, DiscoveryNode) - Constructor for class org.elasticsearch.cluster.routing.RoutingNode
-
- RoutingNode(String, DiscoveryNode, List<ShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.RoutingNode
-
- routingNodeIter(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- RoutingNodeIterator(RoutingNode) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodeIterator
-
- routingNodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get current routing nodes
- RoutingNodes - Class in org.elasticsearch.cluster.routing
-
- RoutingNodes(ClusterState) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
-
- RoutingNodes(ClusterState, boolean) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
-
- RoutingNodes.RoutingNodeIterator - Class in org.elasticsearch.cluster.routing
-
- RoutingNodes.RoutingNodesIterator - Class in org.elasticsearch.cluster.routing
-
- RoutingNodes.UnassignedShards - Class in org.elasticsearch.cluster.routing
-
- RoutingNodes.UnassignedShards.UnassignedIterator - Class in org.elasticsearch.cluster.routing
-
- RoutingNodesIterator(Iterator<RoutingNode>) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodesIterator
-
- routingParsingStillNeeded() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Is routing parsing still needed?
- routingRequired(String, String) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- routingResolved() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Has routing been resolved during the parsing phase.
- routingResult(RoutingAllocation.Result) - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- RoutingService - Class in org.elasticsearch.cluster.routing
-
- RoutingService(Settings, ThreadPool, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.routing.RoutingService
-
- routingTable() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
-
- routingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
-
- routingTable(RoutingTable.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- routingTable(RoutingTable) - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- routingTable() - Method in class org.elasticsearch.cluster.ClusterState
-
- routingTable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
-
- routingTable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get routing table of current nodes
- routingTable() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- 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
-
- 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.
- RoutingTableValidation - Class in org.elasticsearch.cluster.routing
-
Encapsulates the result of a routing table validation and provides access to
validation failures.
- RoutingTableValidation() - Constructor for class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- RoutingValidationException - Exception in org.elasticsearch.cluster.routing
-
- RoutingValidationException(RoutingTableValidation) - Constructor for exception org.elasticsearch.cluster.routing.RoutingValidationException
-
- RoutingValidationException(StreamInput) - Constructor for exception org.elasticsearch.cluster.routing.RoutingValidationException
-
- run() - Method in class org.elasticsearch.cluster.InternalClusterInfoService.SubmitReschedulingClusterInfoUpdatedJob
-
- run() - Method in interface org.elasticsearch.common.util.CancellableThreads.Interruptable
-
- run() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
- run() - Method in class org.elasticsearch.common.util.concurrent.LoggingRunnable
-
- run() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
-
- run() - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.FieldDataCacheCleaner
-
- run() - Method in class org.elasticsearch.script.AbstractDoubleSearchScript
-
- run() - Method in class org.elasticsearch.script.AbstractFloatSearchScript
-
- run() - Method in class org.elasticsearch.script.AbstractLongSearchScript
-
- run() - Method in interface org.elasticsearch.script.ExecutableScript
-
Executes the script.
- runAsDouble() - Method in class org.elasticsearch.script.AbstractDoubleSearchScript
-
- runAsDouble() - Method in class org.elasticsearch.script.AbstractFloatSearchScript
-
- runAsDouble() - Method in class org.elasticsearch.script.AbstractLongSearchScript
-
- runAsDouble() - Method in class org.elasticsearch.script.AbstractSearchScript
-
- runAsDouble() - Method in interface org.elasticsearch.script.LeafSearchScript
-
- runAsFloat() - Method in class org.elasticsearch.script.AbstractDoubleSearchScript
-
- runAsFloat() - Method in class org.elasticsearch.script.AbstractFloatSearchScript
-
- runAsFloat() - Method in class org.elasticsearch.script.AbstractLongSearchScript
-
- runAsFloat() - Method in class org.elasticsearch.script.AbstractSearchScript
-
- runAsFloat() - Method in interface org.elasticsearch.script.LeafSearchScript
-
- runAsLong() - Method in class org.elasticsearch.script.AbstractDoubleSearchScript
-
- runAsLong() - Method in class org.elasticsearch.script.AbstractFloatSearchScript
-
- runAsLong() - Method in class org.elasticsearch.script.AbstractLongSearchScript
-
- runAsLong() - Method in class org.elasticsearch.script.AbstractSearchScript
-
- runAsLong() - Method in interface org.elasticsearch.script.LeafSearchScript
-
- runDeferredCollections(long...) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- runOnlyOnMaster() - Method in class org.elasticsearch.cluster.ClusterStateNonMasterUpdateTask
-
- runOnlyOnMaster() - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor
-
indicates whether this task should only run if current node is master
- RussianAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- RussianAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.RussianAnalyzerProvider
-
- RussianStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- RussianStemTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.RussianStemTokenFilterFactory
-
- 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
-
- SAME - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- SAME_HOST_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
-
- sameHost(TransportAddress) - Method in class org.elasticsearch.common.transport.DummyTransportAddress
-
- sameHost(TransportAddress) - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- sameHost(TransportAddress) - Method in class org.elasticsearch.common.transport.LocalTransportAddress
-
- sameHost(TransportAddress) - Method in interface org.elasticsearch.common.transport.TransportAddress
-
- sameOrAfter(Priority) - Method in class org.elasticsearch.common.Priority
-
- SameShardAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that prevents multiple instances of the same shard to
be allocated on the same node.
- SameShardAllocationDecider(Settings) - 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
-
Builder for the
Sampler
aggregation.
- SamplerAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
-
Sole constructor.
- SamplerAggregator - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
Aggregate on only the top-scoring docs on a shard.
- SamplerAggregator(String, int, AggregatorFactories, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
-
- SamplerAggregator.DiversifiedFactory - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
- SamplerAggregator.ExecutionMode - Enum in org.elasticsearch.search.aggregations.bucket.sampler
-
- SamplerAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
- SamplerParser - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
- SamplerParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerParser
-
- sandboxed() - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
-
- sandboxed() - Method in class org.elasticsearch.script.NativeScriptEngineService
-
- sandboxed() - Method in interface org.elasticsearch.script.ScriptEngineService
-
- scalb(Double, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- scalb(Float, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- SCALE - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
-
- SCAN_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- SCAN_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- scanContext() - Method in class org.elasticsearch.percolator.PercolateContext
-
- scanContext() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- scanContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- scanContext() - Method in class org.elasticsearch.search.internal.SearchContext
-
- ScanContext - Class in org.elasticsearch.search.scan
-
The scan context allows to optimize readers we already processed during scanning.
- ScanContext() - Constructor for class org.elasticsearch.search.scan.ScanContext
-
- ScanContext.ScanCollector - Class in org.elasticsearch.search.scan
-
- ScandinavianFoldingFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory for ScandinavianFoldingFilter
- ScandinavianFoldingFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ScandinavianFoldingFilterFactory
-
- ScandinavianNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory for ScandinavianNormalizationFilter
- ScandinavianNormalizationFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ScandinavianNormalizationFilterFactory
-
- schedule(TimeValue, String, Runnable) - Method in class org.elasticsearch.threadpool.ThreadPool
-
- scheduler() - Method in class org.elasticsearch.threadpool.ThreadPool
-
- scheduleWithFixedDelay(Runnable, TimeValue) - Method in class org.elasticsearch.threadpool.ThreadPool
-
- Scope - Interface in org.elasticsearch.common.inject
-
A scope is a level of visibility that instances provided by Guice may have.
- scope(Key<T>, Provider<T>) - Method in interface org.elasticsearch.common.inject.Scope
-
Scopes a provider.
- 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_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(int, float) - Method in class org.elasticsearch.common.lucene.search.function.LeafScoreFunction
-
- score() - Method in class org.elasticsearch.index.search.child.ConstantScorer
-
- score() - Method in class org.elasticsearch.script.AbstractSearchScript
-
Returns the current score and only applicable when used as a scoring script in a custom score query!.
- score(float) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- score() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- score() - Method in interface org.elasticsearch.search.SearchHit
-
The score.
- score - Variable in class org.elasticsearch.search.suggest.phrase.Correction
-
- score - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
-
- score(DirectCandidateGenerator.Candidate[], DirectCandidateGenerator.CandidateSet[], int, int) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- SCORE - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion
-
- Score() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Score
-
- SCORE_COMPARATOR - Static variable in class org.elasticsearch.search.suggest.SuggestUtils
-
- SCORE_ERROR_MESSAGE - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
-
- SCORE_FIELD_NAME - Static variable in class org.elasticsearch.search.sort.SortParseElement
-
- 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.LaplaceScorer
-
- scoreBigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpoatingScorer
-
- scoreBigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoffScorer
-
- scoreBigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- ScoreComparator() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggester.ScoreComparator
-
- ScoreFunction - Class in org.elasticsearch.common.lucene.search.function
-
- ScoreFunction(CombineFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.ScoreFunction
-
- ScoreFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
-
- ScoreFunctionBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
- ScoreFunctionBuilders - Class in org.elasticsearch.index.query.functionscore
-
- ScoreFunctionBuilders() - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- ScoreFunctionParser - Interface in org.elasticsearch.index.query.functionscore
-
- ScoreFunctionParserMapper - Class in org.elasticsearch.index.query.functionscore
-
- ScoreFunctionParserMapper(Set<ScoreFunctionParser>) - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionParserMapper
-
- scoreMode(String) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Score mode defines how results of individual score functions will be aggregated.
- scoreMode(String) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
-
Defines how the scores from the matching child documents are mapped into the parent document.
- scoreMode(String) - Method in class org.elasticsearch.index.query.HasParentQueryBuilder
-
Defines how the parent score is mapped into the child documents.
- scoreMode(String) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
The score mode.
- scoreMode() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
-
- scoreOrdered() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
-
- scorer - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- scorer(LeafReaderContext) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
-
Deprecated.
- scorer(LeafReaderContext) - Method in class org.elasticsearch.search.profile.ProfileWeight
-
- ScorerAware - Interface in org.elasticsearch.common.lucene
-
- scores() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
-
- scores - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCollector
-
Deprecated.
- 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
-
- scoreTrigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.LaplaceScorer
-
- scoreTrigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpoatingScorer
-
- scoreTrigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoffScorer
-
- scoreTrigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- scoreType(String) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
-
Deprecated.
- scoreType(String) - Method in class org.elasticsearch.index.query.HasParentQueryBuilder
-
Deprecated.
- scoreType - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- ScoreType - Enum in org.elasticsearch.index.search.child
-
Defines how scores from child documents are mapped into the parent document.
- scoreUnigram(DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- script() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
- script(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
- script() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- script(Script) - Method in class org.elasticsearch.action.update.UpdateRequest
-
The script to execute.
- script(String, ScriptService.ScriptType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- script(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- script(String, ScriptService.ScriptType, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- script(String, String, ScriptService.ScriptType, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- Script - Class in org.elasticsearch.script
-
Script holds all the parameters necessary to compile or find in cache and then execute a script.
- Script(String) - Constructor for class org.elasticsearch.script.Script
-
Constructor for simple inline script.
- Script(String, String) - Constructor for class org.elasticsearch.script.Script
-
For sub-classes to use to override the default language
- Script(String, ScriptService.ScriptType, String, Map<String, ? extends Object>) - Constructor for class org.elasticsearch.script.Script
-
Constructor for Script.
- SCRIPT - Static variable in interface org.elasticsearch.script.Script.ScriptField
-
- script() - Method in class org.elasticsearch.script.ScriptParameterParser.ScriptParameterValue
-
- script(Script) - Method in class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
-
The script to use for this aggregation
- script(Script) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptBuilder
-
- script(Script) - Method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorBuilder
-
- Script(SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
-
- Script(SearchScript, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
-
- script() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- script(SearchScript) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- script(Script) - Method in class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
-
Sets the script which generates the values.
- script() - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsContext.ScriptField
-
- Script.ScriptField - Interface in org.elasticsearch.script
-
- Script.ScriptParseException - Exception in org.elasticsearch.script
-
- SCRIPT_AUTO_RELOAD_ENABLED_SETTING - Static variable in class org.elasticsearch.script.ScriptService
-
- SCRIPT_CACHE_EXPIRE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
-
- SCRIPT_CACHE_SIZE_DEFAULT - Static variable in class org.elasticsearch.script.ScriptService
-
- SCRIPT_CACHE_SIZE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
-
- SCRIPT_FILE - Static variable in class org.elasticsearch.script.ScriptService
-
- SCRIPT_ID - Static variable in class org.elasticsearch.script.ScriptService
-
- SCRIPT_INDEX - Static variable in class org.elasticsearch.script.ScriptService
-
- SCRIPT_INLINE - Static variable in class org.elasticsearch.script.ScriptService
-
- SCRIPT_LANG - Static variable in class org.elasticsearch.script.ScriptService
-
- scriptable(boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser.Builder
-
- ScriptBytesValues - Class in org.elasticsearch.search.aggregations.support.values
-
- ScriptBytesValues(LeafSearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
-
- ScriptContext - Interface in org.elasticsearch.script
-
Context of an operation that uses scripts as part of its execution.
- ScriptContext.Plugin - Class in org.elasticsearch.script
-
Custom operation exposed via plugin, which makes use of scripts as part of its execution
- ScriptContext.Standard - Enum in org.elasticsearch.script
-
Standard operations that make use of scripts as part of their execution.
- ScriptContextRegistry - Class in org.elasticsearch.script
-
Registry for operations that use scripts as part of their execution.
- ScriptContextRegistry(Iterable<ScriptContext.Plugin>) - Constructor for class org.elasticsearch.script.ScriptContextRegistry
-
- ScriptDocValues<T> - Interface in org.elasticsearch.index.fielddata
-
Script level doc values, the assumption is that any implementation will implement a getValue
and a getValues
that return the relevant type that then can be used in scripts.
- 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
-
- ScriptDoubleValues(LeafSearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
-
- scriptedMetric(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
- ScriptedMetric - Interface in org.elasticsearch.search.aggregations.metrics.scripted
-
A metric aggregation that computes both its final and intermediate states using scripts.
- ScriptedMetricAggregator - Class in org.elasticsearch.search.aggregations.metrics.scripted
-
- ScriptedMetricAggregator(String, Script, Script, Script, Script, Map<String, Object>, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
-
- ScriptedMetricAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.scripted
-
- ScriptedMetricBuilder - Class in org.elasticsearch.search.aggregations.metrics.scripted
-
- ScriptedMetricBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
-
Sole constructor.
- ScriptedMetricParser - Class in org.elasticsearch.search.aggregations.metrics.scripted
-
- ScriptedMetricParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- scriptedUpsert() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- scriptedUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- ScriptEngineService - Interface in org.elasticsearch.script
-
- ScriptException - Exception in org.elasticsearch.script
-
- ScriptException(String) - Constructor for exception org.elasticsearch.script.ScriptException
-
- ScriptException(String, Throwable) - Constructor for exception org.elasticsearch.script.ScriptException
-
- ScriptException(StreamInput) - Constructor for exception org.elasticsearch.script.ScriptException
-
- 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, SearchScript, boolean) - Constructor for class org.elasticsearch.search.fetch.script.ScriptFieldsContext.ScriptField
-
- scriptFields() - Method in class org.elasticsearch.percolator.PercolateContext
-
- scriptFields() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- 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
-
- ScriptFieldsContext - Class in org.elasticsearch.search.fetch.script
-
- ScriptFieldsContext() - Constructor for class org.elasticsearch.search.fetch.script.ScriptFieldsContext
-
- ScriptFieldsContext.ScriptField - Class in org.elasticsearch.search.fetch.script
-
- ScriptFieldsFetchSubPhase - Class in org.elasticsearch.search.fetch.script
-
- ScriptFieldsFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.script.ScriptFieldsFetchSubPhase
-
- ScriptFieldsParseElement - Class in org.elasticsearch.search.fetch.script
-
"script_fields" : {
"test1" : {
"script" : "doc['field_name'].value"
},
"test2" : {
"script" : "..."
}
}
- ScriptFieldsParseElement() - Constructor for class org.elasticsearch.search.fetch.script.ScriptFieldsParseElement
-
- scriptFieldToXContent(String, ScriptService.ScriptType, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.Script
-
- scriptFieldToXContent(String, ScriptService.ScriptType, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.Template
-
- scriptFunction(Script) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- scriptFunction(String) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
-
- ScriptHeuristic - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- ScriptHeuristic(ExecutableScript, Script) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
-
- ScriptHeuristic.LongAccessor - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- ScriptHeuristic.ScriptHeuristicBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- ScriptHeuristic.ScriptHeuristicParser - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- ScriptHeuristicBuilder() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicBuilder
-
- ScriptHeuristicParser(ScriptService) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicParser
-
- scriptLang() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
The scriptLang of the document to delete.
- scriptLang(String) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
Sets the scriptLang of the document to delete.
- scriptLang - Variable in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- scriptLang(String) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
Sets the language of the script to fetch.
- scriptLang() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- scriptLang() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
The type of the indexed document.
- scriptLang(String) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets the type of the indexed document.
- scriptLang(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- scriptLang() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- ScriptLongValues - Class in org.elasticsearch.search.aggregations.support.values
-
LongValues
implementation which is based on a script
- ScriptLongValues(LeafSearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
-
- ScriptMetrics - Class in org.elasticsearch.script
-
- ScriptMetrics() - Constructor for class org.elasticsearch.script.ScriptMetrics
-
- ScriptModes - Class in org.elasticsearch.script
-
Holds the ScriptMode
s for each of the different scripting languages available,
each script source and each scripted operation.
- ScriptModule - Class in org.elasticsearch.script
-
- ScriptModule(Settings) - Constructor for class org.elasticsearch.script.ScriptModule
-
- ScriptParameterParser - Class in org.elasticsearch.script
-
- ScriptParameterParser() - Constructor for class org.elasticsearch.script.ScriptParameterParser
-
- ScriptParameterParser(Set<String>) - Constructor for class org.elasticsearch.script.ScriptParameterParser
-
- ScriptParameterParser.ScriptParameterValue - Class in org.elasticsearch.script
-
- ScriptParameterValue(String, ScriptService.ScriptType) - Constructor for class org.elasticsearch.script.ScriptParameterParser.ScriptParameterValue
-
- scriptParams() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- scriptParams(Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- ScriptParseException(String, Object...) - Constructor for exception org.elasticsearch.script.Script.ScriptParseException
-
- ScriptParseException(StreamInput) - Constructor for exception org.elasticsearch.script.Script.ScriptParseException
-
- 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(Script) - Constructor for class org.elasticsearch.index.query.ScriptQueryBuilder
-
- ScriptQueryParser - Class in org.elasticsearch.index.query
-
- ScriptQueryParser() - Constructor for class org.elasticsearch.index.query.ScriptQueryParser
-
- scriptRemoved(CompiledScript) - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
-
- scriptRemoved(CompiledScript) - Method in class org.elasticsearch.script.NativeScriptEngineService
-
- scriptRemoved(CompiledScript) - Method in interface org.elasticsearch.script.ScriptEngineService
-
Handler method called when a script is removed from the Guava cache.
- ScriptScoreFunction - Class in org.elasticsearch.common.lucene.search.function
-
- ScriptScoreFunction(Script, SearchScript) - Constructor for class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
-
- ScriptScoreFunctionBuilder - Class in org.elasticsearch.index.query.functionscore.script
-
A function that uses a script to compute or influence the score of documents
that match with the inner query or filter.
- ScriptScoreFunctionBuilder(Script) - Constructor for class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionBuilder
-
- ScriptScoreFunctionParser - Class in org.elasticsearch.index.query.functionscore.script
-
- ScriptScoreFunctionParser() - Constructor for class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionParser
-
- scriptService() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- scriptService() - Method in class org.elasticsearch.percolator.PercolateContext
-
- ScriptService - Class in org.elasticsearch.script
-
- ScriptService(Settings, Environment, Set<ScriptEngineService>, ResourceWatcherService, ScriptContextRegistry) - Constructor for class org.elasticsearch.script.ScriptService
-
- scriptService() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
- scriptService() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- scriptService() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- scriptService() - Method in class org.elasticsearch.search.internal.SearchContext
-
- ScriptService.ScriptType - Enum in org.elasticsearch.script
-
The type of a script, more specifically where it gets loaded from:
- provided dynamically at request time
- loaded from an index
- loaded from file
- scriptsFile() - Method in class org.elasticsearch.env.Environment
-
Location of on-disk scripts
- scriptSort(Script, String) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a new script based sort.
- scriptSort(String, String) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
- ScriptSortBuilder - Class in org.elasticsearch.search.sort
-
Script sort builder allows to sort based on a custom script expression.
- ScriptSortBuilder(Script, String) - Constructor for class org.elasticsearch.search.sort.ScriptSortBuilder
-
Constructs a script sort builder with the given script.
- ScriptSortBuilder(String, String) - Constructor for class org.elasticsearch.search.sort.ScriptSortBuilder
-
- ScriptSortParser - Class in org.elasticsearch.search.sort
-
- ScriptSortParser() - Constructor for class org.elasticsearch.search.sort.ScriptSortParser
-
- ScriptStats - Class in org.elasticsearch.script
-
- ScriptStats() - Constructor for class org.elasticsearch.script.ScriptStats
-
- ScriptStats(long, long) - Constructor for class org.elasticsearch.script.ScriptStats
-
- scriptString() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- scriptType() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- scriptType() - Method in class org.elasticsearch.script.ScriptParameterParser.ScriptParameterValue
-
- 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.SearchRequest
-
If set, will enable scrolling of the search request.
- scroll(TimeValue) - 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.SearchRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- 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.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request.
- scroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
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() - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
-
- scroll(Scroll) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
-
- scroll - Variable in class org.elasticsearch.search.internal.ScrollContext
-
- 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 - Class in org.elasticsearch.search
-
A scroll enables scrolling of search request.
- Scroll(TimeValue) - Constructor for class org.elasticsearch.search.Scroll
-
Constructs a new scroll of the provided keep alive.
- scrollContext() - Method in class org.elasticsearch.percolator.PercolateContext
-
- scrollContext(ScrollContext) - Method in class org.elasticsearch.percolator.PercolateContext
-
- scrollContext() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- scrollContext(ScrollContext) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- scrollContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- scrollContext(ScrollContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- 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
-
- scrollContext() - Method in class org.elasticsearch.search.internal.SearchContext
-
- scrollContext(ScrollContext) - Method in class org.elasticsearch.search.internal.SearchContext
-
- scrollContext(ScrollContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- ScrollFreeContextRequest() - Constructor for class org.elasticsearch.search.action.SearchServiceTransportAction.ScrollFreeContextRequest
-
- scrollId(String) - Method in class org.elasticsearch.action.search.SearchResponse
-
- scrollId() - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
The scroll id used to scroll the search.
- scrollId(String) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
- scrollIds() - Method in class org.elasticsearch.action.search.ClearScrollRequest
-
- scrollIds(List<String>) - Method in class org.elasticsearch.action.search.ClearScrollRequest
-
- ScrollQueryFetchSearchResult - Class in org.elasticsearch.search.fetch
-
- ScrollQueryFetchSearchResult() - 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(QuerySearchResult, SearchShardTarget) - Constructor for class org.elasticsearch.search.query.ScrollQuerySearchResult
-
- search - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- search(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- search() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- 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, 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) - Method in class org.elasticsearch.client.support.AbstractClient
-
- search(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
- search - Variable in class org.elasticsearch.index.engine.Segment
-
- search(CompiledScript, SearchLookup, Map<String, Object>) - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
-
- search(CompiledScript, SearchLookup, Map<String, Object>) - Method in class org.elasticsearch.script.NativeScriptEngineService
-
- search(CompiledScript, SearchLookup, Map<String, Object>) - Method in interface org.elasticsearch.script.ScriptEngineService
-
- search(SearchLookup, Script, ScriptContext, Map<String, String>) - Method in class org.elasticsearch.script.ScriptService
-
Compiles (or retrieves from cache) and executes the provided search script
- SEARCH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- SEARCH_ANALYZER - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- SEARCH_CONTROLLER_OPTIMIZE_SINGLE_SHARD_KEY - Static variable in class org.elasticsearch.search.controller.SearchPhaseController
-
- SearchAction - Class in org.elasticsearch.action.search
-
- searchAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
-
- 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(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- searchAnalyzer() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- searchAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService
-
- searchContext - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- searchContext() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
- SearchContext - Class in org.elasticsearch.search.internal
-
- SearchContext(ParseFieldMatcher, HasContextAndHeaders) - 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) - 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(SearchContext, String) - Constructor for exception org.elasticsearch.search.SearchContextException
-
- SearchContextException(SearchContext, String, Throwable) - Constructor for exception org.elasticsearch.search.SearchContextException
-
- SearchContextException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchContextException
-
- SearchContextHighlight - Class in org.elasticsearch.search.highlight
-
- SearchContextHighlight(Collection<SearchContextHighlight.Field>) - Constructor for class org.elasticsearch.search.highlight.SearchContextHighlight
-
- SearchContextHighlight.Field - Class in org.elasticsearch.search.highlight
-
- SearchContextHighlight.FieldOptions - Class in org.elasticsearch.search.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
-
- searcher() - Method in class org.elasticsearch.index.engine.Engine.GetResult
-
- Searcher(String, IndexSearcher) - Constructor for class org.elasticsearch.index.engine.Engine.Searcher
-
- searcher() - Method in class org.elasticsearch.index.engine.Engine.Searcher
-
- searcher() - Method in class org.elasticsearch.indices.IndicesWarmer.WarmerContext
-
Return a searcher instance that only wraps the segments to warm.
- searcher() - Method in class org.elasticsearch.percolator.PercolateContext
-
- searcher() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- searcher() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- searcher() - Method in class org.elasticsearch.search.internal.SearchContext
-
- SearchException - Exception in org.elasticsearch.search
-
- SearchException(SearchShardTarget, String) - Constructor for exception org.elasticsearch.search.SearchException
-
- SearchException(SearchShardTarget, String, Throwable) - Constructor for exception org.elasticsearch.search.SearchException
-
- SearchException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchException
-
- searchFilter(String...) - Method in class org.elasticsearch.index.mapper.MapperService
-
A filter for search.
- searchFilter(String[]) - Method in class org.elasticsearch.percolator.PercolateContext
-
- searchFilter(String[]) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- searchFilter(String[]) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- searchFilter(String[]) - Method in class org.elasticsearch.search.internal.SearchContext
-
- searchFilter(String[]) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- SearchFreeContextRequest() - Constructor for class org.elasticsearch.search.action.SearchServiceTransportAction.SearchFreeContextRequest
-
- SearchHit - Interface in org.elasticsearch.search
-
A single search hit.
- SearchHit.NestedIdentity - Interface in org.elasticsearch.search
-
Encapsulates the nested identity of a hit.
- SearchHitField - Interface in org.elasticsearch.search
-
A single field name and values part of a
SearchHit
.
- SearchHits - Interface in org.elasticsearch.search
-
The hits of a search request.
- SearchLookup - Class in org.elasticsearch.search.lookup
-
- SearchLookup(MapperService, IndexFieldDataService, String[]) - Constructor for class org.elasticsearch.search.lookup.SearchLookup
-
- SearchModule - Class in org.elasticsearch.search
-
- SearchModule() - Constructor for class org.elasticsearch.search.SearchModule
-
- SearchParseElement - Interface in org.elasticsearch.search
-
- SearchParseException - Exception in org.elasticsearch.search
-
- SearchParseException(SearchContext, String, XContentLocation) - Constructor for exception org.elasticsearch.search.SearchParseException
-
- SearchParseException(SearchContext, String, XContentLocation, Throwable) - Constructor for exception org.elasticsearch.search.SearchParseException
-
- SearchParseException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchParseException
-
- SearchPhase - Interface in org.elasticsearch.search
-
- SearchPhaseController - Class in org.elasticsearch.search.controller
-
- SearchPhaseController(Settings, BigArrays, ScriptService) - Constructor for class org.elasticsearch.search.controller.SearchPhaseController
-
- SearchPhaseExecutionException - Exception in org.elasticsearch.action.search
-
- SearchPhaseExecutionException(String, String, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
-
- SearchPhaseExecutionException(String, String, Throwable, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
-
- SearchPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
-
- SearchPhaseResult - Interface in org.elasticsearch.search
-
- 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
-
- searchQuotedAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
-
- searchRequest(SearchRequest) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
Sets the search request to warm.
- searchRequest(SearchRequestBuilder) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
Sets the search request to warm.
- searchRequest() - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
- 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(SearchRequest, ActionRequest) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Copy constructor that creates a new search request that is a copy of the one provided as an argument.
- SearchRequest(ActionRequest) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request starting from the provided request, meaning that it will
inherit its headers and context
- SearchRequest(String...) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request against the indices.
- SearchRequest(String[], byte[]) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request against the provided indices with the given search source.
- searchRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a search request against one or more indices.
- 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(InternalSearchResponse, String, int, int, long, ShardSearchFailure[]) - Constructor for class org.elasticsearch.action.search.SearchResponse
-
- searchRouting() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the search routing value associated with the alias
- 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() - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- searchRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
- searchRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
-
- searchRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- searchRoutingValues() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
-
- SearchScript - Interface in org.elasticsearch.script
-
A search script.
- searchScroll(SearchScrollRequest) - 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 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 class org.elasticsearch.client.support.AbstractClient
-
- SearchScrollAction - Class in org.elasticsearch.action.search
-
- SearchScrollRequest - Class in org.elasticsearch.action.search
-
- SearchScrollRequest() - Constructor for class org.elasticsearch.action.search.SearchScrollRequest
-
- SearchScrollRequest(String) - Constructor for class org.elasticsearch.action.search.SearchScrollRequest
-
- SearchScrollRequest(ActionRequest) - Constructor for class org.elasticsearch.action.search.SearchScrollRequest
-
Creates a scroll request caused by some other request, which is provided as an
argument so that its headers and context can be copied to the new request
- searchScrollRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a search scroll request allowing to continue searching a previous search request.
- 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() - Method in class org.elasticsearch.index.shard.IndexShard
-
- SearchService - Class in org.elasticsearch.search
-
- SearchService(Settings, NodeSettingsService, ClusterService, IndicesService, IndicesWarmer, ThreadPool, ScriptService, PageCacheRecycler, BigArrays, DfsPhase, QueryPhase, FetchPhase, IndicesRequestCache) - Constructor for class org.elasticsearch.search.SearchService
-
- SearchServiceTransportAction - Class in org.elasticsearch.search.action
-
An encapsulation of
SearchService
operations exposed through
transport.
- SearchServiceTransportAction(Settings, TransportService, SearchService) - Constructor for class org.elasticsearch.search.action.SearchServiceTransportAction
-
- SearchServiceTransportAction.ClearScrollContextsRequest - Class in org.elasticsearch.search.action
-
- SearchServiceTransportAction.ScrollFreeContextRequest - Class in org.elasticsearch.search.action
-
- SearchServiceTransportAction.SearchFreeContextRequest - Class in org.elasticsearch.search.action
-
- SearchServiceTransportAction.SearchFreeContextResponse - Class in org.elasticsearch.search.action
-
- 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
-
- searchShardsCount(ClusterState, String[], Map<String, Set<String>>) - 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, String, int) - Constructor for class org.elasticsearch.search.SearchShardTarget
-
- searchSimilarity() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- SearchSlowLog - Class in org.elasticsearch.index.search.stats
-
- 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.
- 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 - Class in org.elasticsearch.index.search.stats
-
- SearchStats() - 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(String...) - Method in class org.elasticsearch.index.shard.IndexShard
-
- SearchStats.Stats - Class in org.elasticsearch.index.search.stats
-
- searchTimedOut(boolean) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- searchTimedOut() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- searchType(SearchType) - Method in class org.elasticsearch.action.search.SearchRequest
-
- searchType(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
- searchType() - Method in class org.elasticsearch.action.search.SearchRequest
-
The tye of search to execute.
- SearchType - Enum in org.elasticsearch.action.search
-
Search type represent the manner at which the search operation is executed.
- searchType() - Method in class org.elasticsearch.percolator.PercolateContext
-
- searchType(SearchType) - Method in class org.elasticsearch.percolator.PercolateContext
-
- searchType() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- searchType(SearchType) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- searchType() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- searchType(SearchType) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- searchType() - Method in class org.elasticsearch.search.internal.SearchContext
-
- searchType(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(SearchType) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- 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
-
- seconds() - Method in class org.elasticsearch.common.unit.TimeValue
-
- seconds(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
-
- secondsFrac() - Method in class org.elasticsearch.common.unit.TimeValue
-
- SECRET_PROMPT_VALUE - Static variable in class org.elasticsearch.node.internal.InternalSettingsPreparer
-
- seed(int) - Method in class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionBuilder
-
Sets the seed based on which the random number will be generated.
- seed(long) - Method in class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionBuilder
-
seed variant taking a long value.
- seed(String) - Method in class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionBuilder
-
seed variant taking a String value.
- seek(long) - Method in class org.elasticsearch.common.compress.CompressedIndexInput
-
Deprecated.
- 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(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.FreqTermsEnum
-
- seenDateFormats - Variable in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
-
- 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.index.engine.Engine
-
Tries to extract a segment reader from the given index reader.
- segments - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- segments(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- segments() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- 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(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.ShadowEngine
-
- segmentsStats() - 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() - Method in class org.elasticsearch.index.shard.IndexShard
-
- select(SortedNumericDocValues, long) - 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) - 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(SortedNumericDoubleValues, double) - 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) - 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.
- 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) - 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(RandomAccessOrds) - 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(RandomAccessOrds, BitSet, DocIdSetIterator) - 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(MultiValueMode.UnsortedNumericDoubleValues, double) - 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.
- 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.
- SelectedType(String, Class<T>) - Constructor for class org.elasticsearch.common.util.ExtensionPoint.SelectedType
-
- selectNewPathForShard(NodeEnvironment, ShardId, Settings, long, Map<Path, Integer>) - Static method in class org.elasticsearch.index.shard.ShardPath
-
- sendClearAllScrollContexts(DiscoveryNode, ClearScrollRequest, ActionListener<TransportResponse>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteDfs(DiscoveryNode, ShardSearchTransportRequest, ActionListener<DfsSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteFetch(DiscoveryNode, ShardSearchTransportRequest, ActionListener<QueryFetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteFetch(DiscoveryNode, QuerySearchRequest, ActionListener<QueryFetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteFetch(DiscoveryNode, InternalScrollSearchRequest, ActionListener<ScrollQueryFetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteFetch(DiscoveryNode, ShardFetchSearchRequest, ActionListener<FetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteFetchScroll(DiscoveryNode, ShardFetchRequest, ActionListener<FetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteQuery(DiscoveryNode, ShardSearchTransportRequest, ActionListener<QuerySearchResultProvider>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteQuery(DiscoveryNode, QuerySearchRequest, ActionListener<QuerySearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteQuery(DiscoveryNode, InternalScrollSearchRequest, ActionListener<ScrollQuerySearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteScan(DiscoveryNode, ShardSearchTransportRequest, ActionListener<QuerySearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendExecuteScan(DiscoveryNode, InternalScrollSearchRequest, ActionListener<ScrollQueryFetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendFreeContext(DiscoveryNode, long, SearchRequest) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendFreeContext(DiscoveryNode, long, ClearScrollRequest, ActionListener<SearchServiceTransportAction.SearchFreeContextResponse>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
-
- sendJoinRequest(DiscoveryNode, DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction
-
- sendJoinRequestBlocking(DiscoveryNode, DiscoveryNode, TimeValue) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction
-
- sendLeaveRequest(DiscoveryNode, DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction
-
- sendLeaveRequestBlocking(DiscoveryNode, DiscoveryNode, TimeValue) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction
-
- sendRequest(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.transport.local.LocalTransport
-
- sendRequest(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- sendRequest(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in interface org.elasticsearch.transport.Transport
-
Sends the request to the node.
- sendRequest(DiscoveryNode, String, TransportRequest, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
-
- sendRequest(DiscoveryNode, 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(RestResponse) - Method in class org.elasticsearch.http.netty.NettyHttpChannel
-
- sendResponse(RestResponse) - Method in class org.elasticsearch.rest.RestChannel
-
- sendResponse(TransportResponse) - Method in class org.elasticsearch.transport.DelegatingTransportChannel
-
- sendResponse(TransportResponse, TransportResponseOptions) - Method in class org.elasticsearch.transport.DelegatingTransportChannel
-
- sendResponse(Throwable) - Method in class org.elasticsearch.transport.DelegatingTransportChannel
-
- sendResponse(TransportResponse) - Method in class org.elasticsearch.transport.local.LocalTransportChannel
-
- sendResponse(TransportResponse, TransportResponseOptions) - Method in class org.elasticsearch.transport.local.LocalTransportChannel
-
- sendResponse(Throwable) - Method in class org.elasticsearch.transport.local.LocalTransportChannel
-
- sendResponse(TransportResponse) - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
-
- sendResponse(TransportResponse, TransportResponseOptions) - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
-
- sendResponse(Throwable) - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
-
- sendResponse(TransportResponse) - Method in interface org.elasticsearch.transport.TransportChannel
-
- sendResponse(TransportResponse, TransportResponseOptions) - Method in interface org.elasticsearch.transport.TransportChannel
-
- sendResponse(Throwable) - Method in interface org.elasticsearch.transport.TransportChannel
-
- sendSnapshot(Translog.Snapshot) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
Send the given snapshot's operations to this handler's target node.
- sendSnapshot(Translog.Snapshot) - Method in class org.elasticsearch.indices.recovery.SharedFSRecoverySourceHandler
-
- sendValidateJoinRequestBlocking(DiscoveryNode, ClusterState, TimeValue) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction
-
Validates the join request, throwing a failure if it failed.
- sent(long) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- sent(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
-
- SEP_LABEL - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
Represents the separation between tokens, if
PRESERVE_SEP was specified
- SEPARATOR - Static variable in class org.elasticsearch.search.suggest.context.ContextMapping
-
Character used to separate several contexts
- 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 - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- SerbianNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
-
- SerbianNormalizationFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SerbianNormalizationFilterFactory
-
- SerialDiffBuilder - Class in org.elasticsearch.search.aggregations.pipeline.serialdiff
-
- SerialDiffBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffBuilder
-
- SerialDiffParser - Class in org.elasticsearch.search.aggregations.pipeline.serialdiff
-
- SerialDiffParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffParser
-
- SerialDiffPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.serialdiff
-
- SerialDiffPipelineAggregator() - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
-
- SerialDiffPipelineAggregator(String, String[], ValueFormatter, BucketHelpers.GapPolicy, int, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
-
- SerialDiffPipelineAggregator.Factory - Class in org.elasticsearch.search.aggregations.pipeline.serialdiff
-
- serializableCopy(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns a type that's functionally equal but not necessarily equal
according to
Object.equals
.
- SERIALIZATION_FORMAT - Static variable in class org.elasticsearch.index.translog.Translog.Create
-
- SERIALIZATION_FORMAT - Static variable in class org.elasticsearch.index.translog.Translog.Delete
-
- SERIALIZATION_FORMAT - Static variable in class org.elasticsearch.index.translog.Translog.DeleteByQuery
-
Deprecated.
- SERIALIZATION_FORMAT - Static variable in class org.elasticsearch.index.translog.Translog.Index
-
- SERIALIZE_HAS_PAYLOADS - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- SERIALIZE_PRESERVE_POSITION_INCREMENTS - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- SERIALIZE_PRESERVE_SEPARATORS - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- serializeDiffClusterState(Diff, Version) - Static method in class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
-
- serializeFullClusterState(ClusterState, Version) - Static method in class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
-
- serilaize(BloomFilter, DataOutput) - Static method in class org.elasticsearch.common.util.BloomFilter
-
- serverBootstrap - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- serverBootstraps - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- ServerChannelPipelineFactory(NettyTransport, String, Settings) - Constructor for class org.elasticsearch.transport.netty.NettyTransport.ServerChannelPipelineFactory
-
- serverChannels - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- serverChannels - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- serverOpen() - Method in class org.elasticsearch.transport.local.LocalTransport
-
- serverOpen() - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- serverOpen() - Method in interface org.elasticsearch.transport.Transport
-
Returns count of currently open connections
- serverOpen() - Method in class org.elasticsearch.transport.TransportStats
-
- set(CommonStatsFlags.Flag, boolean) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
- 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(int, E) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Sets the element at position i
to the given value.
- set(V) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Subclasses should invoke this method to set the result of the computation
to value
.
- set(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.
- setAccuracy(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.
- 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
-
- setAggregatedDfs(AggregatedDfs) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
- setAggregations(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a raw (xcontent) binary representation of addAggregation to use.
- setAggregations(byte[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a raw (xcontent) binary representation of addAggregation to use.
- setAggregations(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a raw (xcontent) binary representation of addAggregation to use.
- setAggregations(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a raw (xcontent) binary representation of addAggregation to use.
- setAggregations(Map) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a raw (xcontent) binary representation of addAggregation to use.
- 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(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(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(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(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(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(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
- 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(ImmutableOpenMap<String, AliasMetaData>) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
-
- setAllowUnmappedFields(boolean) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- 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(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(String) - Method in class org.elasticsearch.index.search.MatchQuery
-
- setAnalyzer(Analyzer) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- 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
- setAutoThrottle(boolean) - Method in class org.elasticsearch.index.shard.MergeSchedulerConfig
-
Enables / disables auto throttling on the ConcurrentMergeScheduler
- 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.
- 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
-
- 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
-
- setBucketsPaths(String...) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilder
-
Sets the paths to the buckets to use for this pipeline aggregator
- setBucketsPathsMap(Map<String, String>) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptBuilder
-
Sets the paths to the buckets to use for this pipeline aggregator
- setBucketsPathsMap(Map<String, String>) - Method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorBuilder
-
Sets the paths to the buckets to use for this pipeline aggregator.
- setBufferSize(int) - Method in class org.elasticsearch.index.translog.TranslogConfig
-
- 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.
- 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.
- setCause(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The cause for this index creation.
- setCharFilters(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets char filters that will be used before the tokenizer.
- setChronology(Chronology) - Method in class org.joda.time.base.BaseDateTime
-
Sets the chronology of the datetime.
- setClient(Client) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
-
- setClient(Client) - Method in class org.elasticsearch.index.query.TermsQueryParser
-
- setClient(Client) - Method in class org.elasticsearch.script.ScriptService
-
- setClusterService(ClusterService) - Method in class org.elasticsearch.node.settings.NodeSettingsService
-
- setCollector(InternalProfileCollector) - Method in class org.elasticsearch.search.profile.Profiler
-
Set the collector that is associated with this profiler.
- setCombineFunction(CombineFunction) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
-
- setCombineFunction(CombineFunction) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- 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
-
- setCompoundOnFlush(boolean) - Method in class org.elasticsearch.index.engine.EngineConfig
-
Sets if flushed segments should be written as compound file system.
- setCompress(byte) - Static method in class org.elasticsearch.transport.support.TransportStatus
-
- setConcurrentRequests(int) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets the number of concurrent requests allowed to be executed.
- setConsistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Sets the consistency level.
- setConsistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
Sets the consistency level of write.
- setConsistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the consistency level of write.
- setContentType(XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
The content type that will be used to generate a document from user provided objects (like Map).
- setContentType(XContentType) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
The content type that will be used to generate a document from user provided objects (like Map).
- setContextMapping(SortedMap<String, ContextMapping>) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- setContextQuery(List<ContextMapping.ContextQuery>) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- setCorsResponseHeaders(HttpRequest, HttpResponse, CorsConfig) - Static method in class org.elasticsearch.http.netty.cors.CorsHandler
-
- setCreate(boolean) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Set to true to force only creation, not an update of an index template.
- setCreate(boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
- setCreate(boolean) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
- setCreate(boolean) - Method in class org.elasticsearch.index.engine.EngineConfig
-
Iff set to true
the engine will create a new lucene index when opening the engine.
- setCurrent(SearchContext) - Static method in class org.elasticsearch.search.internal.SearchContext
-
- setCurrentReference(T) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
-
- setCurrentSnapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Makes the request to return the current snapshot
- setDateTimeFormatter(FormatDateTimeFormatter) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- setDecay(double) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
-
- setDefaultCompressor(Compressor) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
- setDefaultDistanceErrorPct(double) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- setDefaultFactory(ESLoggerFactory) - Static method in class org.elasticsearch.common.logging.ESLoggerFactory
-
Changes the default factory.
- 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.BestDocsDeferringCollector
-
Set the deferred collectors.
- setDeferredCollector(Iterable<BucketCollector>) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
Set the deferred collectors.
- setDependency(Dependency) - Method in class org.elasticsearch.common.inject.internal.InternalContext
-
- 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.
- setDfs(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to use distributed frequencies instead of shard statistics.
- setDistanceErrorPct(double) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- setDoc(BytesReference) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder.DocBuilder
-
Sets the document to be percolated.
- setDoc(String, Object) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder.DocBuilder
-
Sets the document to be percolated.
- setDoc(String) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder.DocBuilder
-
Sets the document to be percolated.
- setDoc(XContentBuilder) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder.DocBuilder
-
Sets the document to be percolated.
- setDoc(Map) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder.DocBuilder
-
Sets the document to be percolated.
- setDoc(Map, XContentType) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder.DocBuilder
-
- setDoc(PercolateSourceBuilder.DocBuilder) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
Sets the document to run the percolate queries against.
- setDoc(XContentBuilder) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the artificial document from which to generate term vectors.
- 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.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(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(byte[]) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(byte[], int, int) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(String, Object) - 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.
- setDocAsUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets whether the specified doc parameter should be used as upsert document.
- setDocIdInTerms(int) - Method in class org.elasticsearch.search.lookup.IndexField
-
- setDocs(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
- setDocument(int) - Method in class org.elasticsearch.index.fielddata.AbstractRandomAccessOrds
-
- setDocument(int) - Method in class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Sets iteration to the specified docID.
- setDocument(int) - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Positions to the specified document
- setDocument(int) - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Positions to the specified document
- setDocument(int) - Method in class org.elasticsearch.script.AbstractSearchScript
-
- setDocument(int) - Method in interface org.elasticsearch.script.LeafSearchScript
-
- setDocument(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
-
- setDocument(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
-
- setDocument(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
-
- setDocument(int) - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
-
- 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.LeafIndexLookup
-
- setDocument(int) - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
-
- setDocument(int) - Method in interface org.elasticsearch.search.MultiValueMode.UnsortedNumericDoubleValues
-
- setDocumentType(String) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
Sets the type of the document to percolate.
- 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.
- setDurabilty(Translog.Durabilty) - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Sets the current durability mode for the translog.
- setDynamicSettings(NodeSettingsService) - Method in class org.elasticsearch.transport.TransportService
-
- setEnabled(boolean) - Method in class org.elasticsearch.index.mapper.internal.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.support.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
-
- 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.support.BaseInnerHitBuilder
-
Should each
SearchHit
be returned with an
explanation of the hit (ranking).
- setExplain(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Should each
SearchHit
be returned with an
explanation of the hit (ranking).
- setExtraSource(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setExtraSource(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setExtraSource(byte[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setExtraSource(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setExtraSource(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setExtraSource(Map) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
-
- setFetchPhase(FetchPhase) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsFetchSubPhase
-
- setFetchService(ShapeFetchService) - Method in class org.elasticsearch.index.query.GeoShapeQueryParser
-
- setFetchService(MoreLikeThisFetchService) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryParser
-
- setFetchSource(boolean) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Indicates whether the response should contain the stored _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.explain.ExplainRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard
elements.
- setFetchSource(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Indicates whether the response should contain the stored _source.
- 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.get.GetRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard
elements.
- setFetchSource(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicates whether the response should contain the stored _source for every hit
- 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.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(boolean) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Indicates whether the response should contain the stored _source for every hit
- setFetchSource(String, String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
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.index.query.support.BaseInnerHitBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard
elements.
- setFetchSource(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Indicates whether the response should contain the stored _source for every hit
- setFetchSource(String, String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
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.search.aggregations.metrics.tophits.TopHitsBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard
elements.
- 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.search.suggest.SuggestionSearchContext.SuggestionContext
-
- 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
-
- setFieldDataType(FieldDataType) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- setFieldNames(String[]) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the field names that will be used when generating the 'More Like This' query.
- setFields(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
-
- setFields(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
-
Sets the fields to retrieve.
- setFields(String...) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Explicitly specify the fields that will be returned for the explained document.
- setFields(String[]) - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequest
-
- setFields(String...) - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequestBuilder
-
- setFields(String...) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Explicitly specify the fields that will be returned.
- 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
-
- setFields(String...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Explicitly specify the fields that will be returned.
- 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.
- setFilterSettings(TermVectorsRequest.FilterSettings) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the settings for filtering out terms.
- 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.
- setFollow(boolean) - Method in class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
Sets whether the appender honors reassignments of System.out
or System.err made after configuration.
- setForce(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
-
- 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.support.BaseInnerHitBuilder
-
The index to start to return hits from.
- setFrom(int) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
The index to start to return hits from.
- setFs(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node file system stats be returned.
- setFuzziness(Fuzziness) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- setFuzziness(Fuzziness) - Method in class org.elasticsearch.index.search.MatchQuery
-
- setFuzziness(Fuzziness) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
Sets the level of fuzziness used to create suggestions using a
Fuzziness
instance.
- setFuzzy(boolean) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- setFuzzyEditDistance(int) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- setFuzzyMinLength(int) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- setFuzzyMinLength(int) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
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.CompletionSuggestionContext
-
- setFuzzyPrefixLength(int) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
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
-
- setFuzzyTranspositions(boolean) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- setFuzzyTranspositions(boolean) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
Sets if transpositions (swapping one character for another) counts as one character
change or two.
- setFuzzyUnicodeAware(boolean) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
-
- setGcDeletesInMillis(long) - Method in class org.elasticsearch.index.engine.EngineConfig
-
Sets the GC deletes cycle in milliseconds.
- setGeoHashEnabled(MappedFieldType, int, boolean) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- setGet(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
- setGetRequest(GetRequest) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
Enables percolating an existing document.
- setGetResult(GetResult) - Method in class org.elasticsearch.action.update.UpdateResponse
-
- setGroups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
- 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.action.percolate.PercolateRequestBuilder
-
- setHighlightBuilder(HighlightBuilder) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
Enables highlighting for the percolate document.
- setHighlighterBoundaryChars(char[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setHighlighterBoundaryChars(char[]) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- setHighlighterBoundaryChars(char[]) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- setHighlighterBoundaryMaxScan(Integer) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setHighlighterBoundaryMaxScan(Integer) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- setHighlighterBoundaryMaxScan(Integer) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- setHighlighterEncoder(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The encoder to set for highlighting
- setHighlighterEncoder(String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
The encoder to set for highlighting
- setHighlighterEncoder(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
The encoder to set for highlighting
- setHighlighterExplicitFieldOrder(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Send the fields to be highlighted using a syntax that is specific about the order in which they should be highlighted.
- setHighlighterFilter(Boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setHighlighterFilter(Boolean) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- setHighlighterFilter(Boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- setHighlighterForceSource(Boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Forces to highlight fields based on the source even if fields are stored separately.
- setHighlighterFragmenter(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setHighlighterFragmenter(String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- setHighlighterFragmenter(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- setHighlighterFragmentSize(Integer) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setHighlighterFragmentSize(Integer) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- setHighlighterFragmentSize(Integer) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- setHighlighterNoMatchSize(Integer) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
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.
- setHighlighterNoMatchSize(Integer) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
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.
- setHighlighterNoMatchSize(Integer) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
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.
- setHighlighterNumOfFragments(Integer) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setHighlighterNumOfFragments(Integer) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- setHighlighterNumOfFragments(Integer) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- setHighlighterOptions(Map<String, Object>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setHighlighterOptions(Map<String, Object>) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- setHighlighterOptions(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- setHighlighterOrder(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The order of fragments per field.
- setHighlighterOrder(String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
The order of fragments per field.
- setHighlighterOrder(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
The order of fragments per field.
- setHighlighterPhraseLimit(Integer) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the maximum number of phrases the fvh will consider if the field doesn't also define phraseLimit.
- setHighlighterPhraseLimit(Integer) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Sets the maximum number of phrases the fvh will consider if the field doesn't also define phraseLimit.
- setHighlighterPhraseLimit(Integer) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Sets the maximum number of phrases the fvh will consider if the field doesn't also define phraseLimit.
- setHighlighterPostTags(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Explicitly set the post tags that will be used for highlighting.
- setHighlighterPostTags(String...) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Explicitly set the post tags that will be used for highlighting.
- setHighlighterPostTags(String...) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Explicitly set the post tags that will be used for highlighting.
- setHighlighterPreTags(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Explicitly set the pre tags that will be used for highlighting.
- setHighlighterPreTags(String...) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Explicitly set the pre tags that will be used for highlighting.
- setHighlighterPreTags(String...) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Explicitly set the pre tags that will be used for highlighting.
- setHighlighterQuery(QueryBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a query to be used for highlighting all fields instead of the search query.
- setHighlighterQuery(QueryBuilder) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Sets a query to be used for highlighting all fields instead of the search query.
- setHighlighterQuery(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Sets a query to be used for highlighting all fields instead of the search query.
- setHighlighterRequireFieldMatch(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setHighlighterRequireFieldMatch(boolean) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- setHighlighterRequireFieldMatch(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- setHighlighterTagsSchema(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Set a tag scheme that encapsulates a built in pre and post tags.
- setHighlighterTagsSchema(String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Set a tag scheme that encapsulates a built in pre and post tags.
- setHighlighterTagsSchema(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Set a tag scheme that encapsulates a built in pre and post tags.
- setHighlighterType(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The highlighter type to use.
- setHighlighterType(String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
The highlighter type to use.
- setHighlighterType(String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
The highlighter type to use.
- 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.
- setHttpServer(HttpServer) - Method in class org.elasticsearch.node.service.NodeService
-
- setHttpServerTransport(Class<? extends HttpServerTransport>, String) - Method in class org.elasticsearch.http.HttpServerModule
-
- 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.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.indexedscripts.delete.DeleteIndexedScriptRequestBuilder
-
Sets the id of the document to delete.
- setId(String) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequestBuilder
-
Sets the id of the document to fetch.
- setId(String) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Sets the id to index the document under.
- 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.
- setIgnoreErrorsOnGeneratedFields(Boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
- setIgnoreErrorsOnGeneratedFields(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
- 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
- setIncludeAliases(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If set to true the restore procedure will restore aliases
- setIncludeGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Set to true if snapshot should include global cluster state
- 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(Index) - Method in exception org.elasticsearch.ElasticsearchException
-
- setIndex(String) - Method in exception org.elasticsearch.ElasticsearchException
-
- setIndex(String) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- setIndexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- setIndexConstraints(IndexConstraint[]) - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequest
-
- setIndexContraints(IndexConstraint...) - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequestBuilder
-
- setIndexing(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
- setIndexingBufferSize(ByteSizeValue) - Method in class org.elasticsearch.index.engine.EngineConfig
-
Sets the indexing buffer
- 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
- setIndexSettings(String) - 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
- setIndexShard(IndexShard) - Method in class org.elasticsearch.index.termvectors.ShardTermVectorsService
-
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
- setIndices(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node indices stats be returned.
- setIndices(CommonStatsFlags) - 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.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
-
- 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.admin.indices.warmer.delete.DeleteWarmerRequestBuilder
-
- 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
-
- 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.indices.IndicesExistsRequestBuilder
-
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.admin.indices.warmer.delete.DeleteWarmerRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequestBuilder
-
Specifies how to globally ignore indices that are not available and how to deal with wildcard indices expressions.
- 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
-
- setIndicesWarmer(IndicesWarmer) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
-
- setInnerHits(InnerHitsSubSearchContext) - Method in class org.elasticsearch.index.query.NestedQueryParser.ToBlockJoinQueryBuilder
-
- setInnerHits(Map<String, InternalSearchHits>) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- setInterval(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
-
- 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.
- setLastAccessTime() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
sets the lasAccessTime flag to now
- setLatLonEnabled(MappedFieldType, MappedFieldType) - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- setLenient(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets whether format based failures will be ignored.
- setLenient(boolean) - Method in class org.elasticsearch.index.search.MatchQuery
-
- setLevel(String) - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequestBuilder
-
- setLevel(String) - Method in interface org.elasticsearch.common.logging.ESLogger
-
Allows to set the logger level
If the new level is null, the logger will inherit its level
from its nearest ancestor with a specific (non-null) level value.
- setLevel(String) - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
-
- setLevel(String) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
-
- setLevel(String) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- setLikeText(String) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- setLikeText(String...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- setLikeText(Fields...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- setLikeText(List<String>) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- setListener(BitsetFilterCache.Listener) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
-
Sets a listener that is invoked for all subsequent cache and removal events.
- setListener(IndexFieldDataCache.Listener) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
-
- 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.fd.NodesFaultDetection
-
- setLocalNode(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
-
makes the transport service aware of the local node.
- setLowFreqMinimumNumberShouldMatch(String) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
- setMapUnmappedFieldAsString(boolean) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- 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.
- 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.
- setMaxBoost(float) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- 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
-
- setMaxMergeCount(int) - Method in class org.elasticsearch.index.shard.MergeSchedulerConfig
-
Expert: set the maximum number of simultaneous merges allowed.
- 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.
- setMaxRate(ByteSizeValue) - Method in class org.apache.lucene.store.StoreRateLimiting
-
- setMaxTermFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
-
- setMaxThreadCount(int) - Method in class org.elasticsearch.index.shard.MergeSchedulerConfig
-
Expert: directly set the maximum number of merge threads and
simultaneous merges allowed.
- 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
-
- 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.AggregationBuilder
-
Sets the meta data to be included in the aggregation response
- setMetaData(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
- setMetaData(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.MetricsAggregationBuilder
-
Sets the meta data to be included in the metric aggregator's response
- setMetaData(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilder
-
Sets the meta data to be included in the pipeline aggregator's response
- setMetaData(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorFactory
-
- setMillis(long) - Method in class org.joda.time.base.BaseDateTime
-
Sets the milliseconds of the datetime.
- 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.
- setMinScore(float) - Method in class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
The minimum score of the documents to include in the count.
- 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
-
- 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
-
- setMoreLikeFields(String[]) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- setMultiValueMode(MultiValueMode) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
-
- setMultiValueMode(String) - 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.action.admin.indices.warmer.put.PutWarmerRequestBuilder
-
Sets the name of the warmer.
- setName(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets an optional name to identify this bulk processor.
- setName(String) - Method in class org.elasticsearch.index.query.support.QueryInnerHitBuilder
-
Set the key name to be used in the response.
- setNames(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
-
- setNames(String...) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequestBuilder
-
The name (or wildcard expression) of the index warmer to delete, or null
to delete all warmers.
- setNames(MappedFieldType.Names) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Sets the nested filter that the nested objects should match with in order to be taken into account
for sorting.
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Sets the nested filter that the nested objects should match with in order to be taken into account
for sorting.
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Sets the nested filter that the nested objects should match with in order to be taken into account
for sorting.
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Sets the nested path if sorting occurs on a field that is inside a nested object.
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Sets the nested path if sorting occurs on a field that is inside a nested object.
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Sets the nested path if sorting occurs on a field that is inside a nested object.
- setNext(ShapeBuilder.Edge) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
-
- 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 interface org.elasticsearch.index.fielddata.ScriptDocValues
-
Set the current doc ID.
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
-
- setNextDocIdInFields() - Method in class org.elasticsearch.search.lookup.LeafIndexLookup
-
- setNextVar(String, Object) - Method in class org.elasticsearch.script.AbstractExecutableScript
-
- setNextVar(String, Object) - Method in interface org.elasticsearch.script.ExecutableScript
-
- setNodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
- setNodeService(NodeService) - Method in interface org.elasticsearch.discovery.Discovery
-
Here as a hack to solve dep injection problem...
- setNodeService(NodeService) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
-
- setNodeService(NodeService) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- setNodeSettingsService(NodeSettingsService) - Method in class org.elasticsearch.threadpool.ThreadPool
-
- setNodesIds(String...) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
-
- setNodesIds(String...) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
- setNodesIds(String...) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
-
- setNoFields() - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets no fields to be loaded, resulting in only id and type to be returned per field.
- setNoFields() - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Sets no fields to be loaded, resulting in only id and type to be returned per field.
- setNoFields() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Sets no fields to be loaded, resulting in only id and type to be returned per field.
- setNormsLoading(MappedFieldType.Loading) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- setNullValue(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Sets the null value and initializes the string version
- setNumericType(IndexNumericFieldData.NumericType) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData.Builder
-
- 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 type
elementType
.
- setOffset(Object) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
-
- 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.
- setOnce(int, E) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
- setOnlyCount(boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
Whether only to return total count and don't keep track of the matches (Count percolation).
- setOnlyExpungeDeletes(boolean) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequestBuilder
-
Should the merge only expunge deletes from the index, without full merging.
- setOperationThreaded(boolean) - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequestBuilder
-
Controls if the operation will be executed on a separate thread when executed locally.
- setOpType(IndexRequest.OpType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the type of operation to perform.
- setOpType(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
- setOpType(IndexRequest.OpType) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Sets the type of operation to perform.
- setOpType(String) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
- 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.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- 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
-
- setParams(Map<String, Object>) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
- 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
-
- setParentTask(String, long) - Method in class org.elasticsearch.action.support.ChildTaskActionRequest
-
- setParentTask(String, long) - Method in class org.elasticsearch.action.support.ChildTaskRequest
-
- setParentTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
- setParsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
-
- 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
- setPath(String) - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
-
- setPath(String) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder.InnerHit
-
For parent/child inner hits the type to collect inner hits for.
- setPayload(BytesReference) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
-
- setPayloads(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the payloads for each term or skip.
- setPercolate(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
- setPercolateDoc(PercolateSourceBuilder.DocBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setPercolateQuery(QueryBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setPerFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the analyzer used at each field when generating term vectors.
- 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.
- setPersistentSettings(String) - 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.
- setPhase(String) - Method in class org.elasticsearch.action.support.replication.ReplicationTask
-
Set the current phase of the task.
- setPhraseSlop(int) - Method in class org.elasticsearch.index.search.MatchQuery
-
- setPingContextProvider(PingContextProvider) - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
-
- setPingContextProvider(PingContextProvider) - Method in interface org.elasticsearch.discovery.zen.ping.ZenPing
-
- setPingContextProvider(PingContextProvider) - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
-
- 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.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- 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).
- setPostFilter(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- setPostFilter(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- setPostFilter(byte[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- setPostFilter(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- setPostFilter(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- setPostFilter(Map) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a filter on the query executed that only applies to the search query
(and not aggs for example).
- setPrecisionInMeters(double) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- 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.count.CountRequestBuilder
-
Deprecated.
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
-
Deprecated.
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.percolate.PercolateRequestBuilder
-
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.suggest.SuggestRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the preference to execute the search.
- 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(Profiler) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
- setProfilers(Profilers) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- setProvider(AnalyzingCompletionLookupProvider) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- setProxyDelegates(T) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
-
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
The query source to validate.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
The query source to execute.
- setQuery(BytesReference) - Method in class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
The query binary to execute
- setQuery(XContentBuilder) - Method in class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
Constructs a new builder with a raw search query.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
-
Deprecated.
The query source to execute.
- setQuery(BytesReference) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
-
Deprecated.
The query binary to execute
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the query to get a score explanation for.
- setQuery(BytesReference) - 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(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Constructs a new search source builder with a raw search query.
- setQuery(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Constructs a new search source builder with a raw search query.
- setQuery(byte[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Constructs a new search source builder with a raw search query.
- setQuery(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Constructs a new search source builder with a raw search query.
- setQuery(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Constructs a new search source builder with a raw search query.
- setQuery(Map) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Constructs a new search source builder with a raw search query.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.support.QuerySourceBuilder
-
- setQuery(BytesReference) - Method in class org.elasticsearch.action.support.QuerySourceBuilder
-
- setQuery(QueryBuilder) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder.InnerHit
-
Sets the query to run for collecting the inner hits.
- setQueryBuilder(QueryBuilder) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
Sets a query to reduce the number of percolate queries to be evaluated and score the queries that match based
on this query.
- 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.RescoreBuilder.QueryRescorer
-
Sets the original query weight for rescoring.
- setReallocation(ClusterService, RoutingService) - Method in class org.elasticsearch.gateway.GatewayAllocator
-
- 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.
- 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.bulk.BulkRequestBuilder
-
Should a refresh be executed post this bulk operation causing the operations to
be searchable.
- setRefresh(boolean) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Should a refresh be executed post this index operation causing the operation to
be searchable.
- 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.action.index.IndexRequestBuilder
-
Should a refresh be executed post this index operation causing the operation to
be searchable.
- setRefresh(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Should a refresh be executed post this update operation causing the operation to
be searchable.
- 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.support.TransportStatus
-
- 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).
- setRequiredSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
-
- setRescoreQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
-
- setRescoreQueryWeight(float) - Method in class org.elasticsearch.search.rescore.RescoreBuilder.QueryRescorer
-
Sets the original query weight for rescoring.
- setRescorer(RescoreBuilder.Rescorer) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Clears all rescorers on the builder and sets the first one.
- setRescorer(RescoreBuilder.Rescorer, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Clears all rescorers on the builder and sets the first one.
- setRescoreWindow(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setResources(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
-
- setResponse(byte) - Static method in class org.elasticsearch.transport.support.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.
- 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
-
- setRewriteMethod(MultiTermQuery, ParseFieldMatcher, String) - 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.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.count.CountRequestBuilder
-
Deprecated.
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.count.CountRequestBuilder
-
Deprecated.
The routing values to control the shards that 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.exists.ExistsRequestBuilder
-
Deprecated.
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.exists.ExistsRequestBuilder
-
Deprecated.
The routing values to control the shards that the search will be executed on.
- 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.percolate.PercolateRequestBuilder
-
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.percolate.PercolateRequestBuilder
-
List of routing values to control the shards the search will be executed on.
- 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.search.SearchRequestBuilder
-
The routing values to control the shards that the search will be executed on.
- setRouting(String) - Method in class org.elasticsearch.action.suggest.SuggestRequestBuilder
-
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.suggest.SuggestRequestBuilder
-
The routing values to control the shards that 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.
- setRoutingService(RoutingService) - Method in interface org.elasticsearch.discovery.Discovery
-
Another hack to solve dep injection problem..., note, this will be called before
any start is called.
- setRoutingService(RoutingService) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
-
- setRoutingService(RoutingService) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- setRoutingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
- setScore(boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setScore(float) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
-
- setScore(float) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
-
- setScoreMode(ScoreMode) - Method in class org.elasticsearch.index.query.NestedQueryParser.ToBlockJoinQueryBuilder
-
- setScoreMode(QueryRescorer.ScoreMode) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
-
- setScoreMode(String) - Method in class org.elasticsearch.search.rescore.RescoreBuilder.QueryRescorer
-
Sets the original query score mode.
- setScorer(Scorer) - Method in class org.elasticsearch.common.lucene.Lucene.EarlyTerminatingCollector
-
- 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.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- setScorer(Scorer) - Method in class org.elasticsearch.script.AbstractSearchScript
-
- 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.scan.ScanContext.ScanCollector
-
- 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.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicBuilder
-
- setScriptedUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets whether the script should be run in the case of an insert
- setScriptLang(String) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequestBuilder
-
Sets the language of the script to delete.
- setScriptLang(String) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequestBuilder
-
Sets the type of the document to fetch.
- setScriptLang(String) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Sets the type to index the document to.
- setScriptService(ScriptService) - Method in class org.elasticsearch.node.service.NodeService
-
- setScroll(Scroll) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
If set, will enable scrolling of the search request.
- setScroll(TimeValue) - 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.SearchRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(Scroll) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
If set, will enable scrolling of the search request.
- setScroll(TimeValue) - 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.action.search.SearchScrollRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- 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
-
- setSearchQuoteAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- setSearchRequest(SearchRequest) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
-
Sets the search request to use to warm the index when applicable.
- setSearchRequest(SearchRequestBuilder) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
-
Sets the search request to use to warm the index when applicable.
- setSearchType(SearchType) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setSearchType(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- 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.
- setSettings(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Should the node settings be returned.
- setSettings(Settings) - 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.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings
- setSettings(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings in Json, Yaml or properties format
- setSettings(Map<String, Object>) - 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.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings.
- setSettings(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings in YAML, JSON or properties format
- setSettings(Map<String, Object>) - 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.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets repository-specific restore settings.
- setSettings(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets repository-specific restore settings in JSON, YAML or properties format
- setSettings(Map<String, Object>) - 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.Builder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with.
- setSettings(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Allows to set the settings using a json builder.
- setSettings(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with (either json/yaml/properties format)
- setSettings(Object...) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
A simplified version of settings that takes key value pairs settings.
- 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(Settings) - 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.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated
- setSettings(String) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated (either json/yaml/properties format)
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated (either json/yaml/properties format)
- 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.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to created the index template with.
- setSettings(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to crete the index template with (either json/yaml/properties format)
- 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/yaml/properties format)
- setSettings(TermVectorsRequest.FilterSettings) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
-
- setSettingsRequireUnits(boolean) - Static method in class org.elasticsearch.common.settings.Settings
-
- setShard(ShardId) - Method in exception org.elasticsearch.ElasticsearchException
-
- setShard(int) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- setShardId(ShardId) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Sets the target shard id for the request.
- setShardInfo(ActionWriteResponse.ShardInfo) - Method in class org.elasticsearch.action.ActionWriteResponse
-
- 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.
- setShortCircuitCutoff(int) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
-
Configures at what cut off point only to evaluate parent documents that contain the matching parent id terms
instead of evaluating all parent docs.
- 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.percolate.PercolateRequestBuilder
-
- setSize(int) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
Limits the maximum number of percolate query matches to be returned.
- 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.support.BaseInnerHitBuilder
-
The number of search hits to return.
- setSize(int) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
The number of search hits to return.
- setSize(int) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- setSkipTerms(Set<Term>) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets a list of terms to never select from
- setSlop(int) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Sets the phrase slop for this query.
- 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
- setSort(boolean) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
- setSortByScore(boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setSource(BytesReference) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Sets the source for the request
- setSource(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(BytesReference) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(byte[]) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(byte[], int, int) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- 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(Map) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The mapping source definition.
- setSource(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The mapping source definition.
- 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(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(Map) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(BytesReference) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(byte[]) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(byte[], int, int) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(BytesReference) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
The source to validate.
- setSource(byte[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
The source to validate.
- setSource(BytesReference) - Method in class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
The source to execute.
- setSource(byte[]) - Method in class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
The query source to execute.
- setSource(BytesReference) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
-
Deprecated.
The source to execute.
- setSource(byte[]) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
-
Deprecated.
The query source to execute.
- setSource(BytesReference) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the full source of the explain request (for example, wrapping an actual query).
- setSource(BytesReference) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the 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(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the document source to index.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the content source to index.
- setSource(byte[]) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the document to index in bytes form.
- setSource(byte[], int, int) - 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(String, Object) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field and a value.
- setSource(String, Object, String, Object) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field and value pairs.
- setSource(String, Object, String, Object, String, Object) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field and value pairs.
- setSource(String, Object, String, Object, String, Object, String, Object) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field and value pairs.
- setSource(Object...) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field name and value pairs.
- setSource(BytesReference) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Sets the source.
- setSource(Map<String, Object>) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Index the Map as a JSON.
- setSource(Map<String, Object>, XContentType) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Index the Map as the provided content type.
- setSource(String) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Sets the document source to index.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Sets the content source to index.
- setSource(byte[]) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Sets the document to index in bytes form.
- setSource(byte[], int, int) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Sets the document to index in bytes form (assumed to be safe to be used from different
threads).
- setSource(Object...) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
Constructs a simple document with a field name and value pairs.
- setSource(PercolateSourceBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
Sets the percolate request definition directly on the request.
- setSource(Map<String, Object>) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setSource(Map<String, Object>, XContentType) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setSource(String) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setSource(BytesReference) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setSource(byte[]) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setSource(byte[], int, int) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
-
- setSource(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setSource(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setSource(byte[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setSource(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a json string.
- setSource(Map) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a map.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
- setSource(byte[]) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
- setSource(byte[], int, int) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
- setSource(BytesReference) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
- setSource(BytesReference) - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- setSource(Map<String, Object>) - Method in class org.elasticsearch.script.AbstractSearchScript
-
- setSource(Map<String, Object>) - Method in interface org.elasticsearch.script.LeafSearchScript
-
- setSource(BytesReference) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- setSource(Map<String, Object>) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- setSourceClassName(String) - Method in class org.elasticsearch.common.logging.jdk.ESLogRecord
-
- setSourceContentType(XContentType) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- setSourceMethodName(String) - Method in class org.elasticsearch.common.logging.jdk.ESLogRecord
-
- setStage(RecoveryState.Stage) - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
- setStats(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.
- setStatus(ClusterHealthStatus) - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
-
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
-
- setStrategyName(String) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- setSuggest(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
- setSuggestText(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setSuggestText(String) - Method in class org.elasticsearch.action.suggest.SuggestRequestBuilder
-
- setTarget(String) - Method in class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
Sets the value of the Target option.
- setTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
- setTemplate(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the template match expression that will be used to match on indices created.
- setTemplate(Template) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
template stuff
- setTemplateName(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setTemplateParams(Map<String, Object>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setTemplateSource(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setTemplateSource(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setTemplateType(ScriptService.ScriptType) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
- setTerminateAfter(int) - Method in class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
- 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.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets texts to analyze
- setText(String) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Sets the text to provide suggestions for.
- setText(BytesRef) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
-
- 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
-
- setTieBreaker(float) - Method in class org.elasticsearch.index.search.MultiMatchQuery
-
- setTimedOut(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
- setTimeout(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
-
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
- setTimeout(String) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
-
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
- setTimeout(TimeValue) - 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.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(String) - 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(String) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequestBuilder
-
Timeout to wait for the operation to be acknowledged by current cluster nodes.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
-
- setTimeout(String) - 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(String) - 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(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(TimeValue) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
- setTimeout(String) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
-
- setTimestamp(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the timestamp either as millis since the epoch, or, in the configured date format.
- setTimeUnit(TimeUnit) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- SETTING - Static variable in class org.elasticsearch.cluster.ClusterName
-
- 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_INDICES_CLOSE_ENABLE - Static variable in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
-
- SETTING_CLUSTER_SERVICE_RECONNECT_INTERVAL - Static variable in class org.elasticsearch.cluster.service.InternalClusterService
-
- SETTING_CLUSTER_SERVICE_SLOW_TASK_LOGGING_THRESHOLD - Static variable in class org.elasticsearch.cluster.service.InternalClusterService
-
- SETTING_CONNECT_ON_NETWORK_DISCONNECT - Static variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- SETTING_CORS_ALLOW_CREDENTIALS - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_CORS_ALLOW_HEADERS - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_CORS_ALLOW_METHODS - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_CORS_ALLOW_ORIGIN - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_CORS_ENABLED - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_CORS_MAX_AGE - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- 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_DISCOVERY_SEED - Static variable in class org.elasticsearch.discovery.DiscoveryService
-
- SETTING_ENABLE_LUCENE_SEGMENT_INFOS_TRACE - Static variable in class org.elasticsearch.env.NodeEnvironment
-
- SETTING_HTTP_COMPRESSION - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_HTTP_COMPRESSION_LEVEL - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_HTTP_DETAILED_ERRORS_ENABLED - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_INDEX_BALANCE_FACTOR - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
- SETTING_INDEX_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- SETTING_INITIAL_STATE_TIMEOUT - Static variable in class org.elasticsearch.discovery.DiscoveryService
-
- SETTING_JOIN_RETRY_ATTEMPTS - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_JOIN_RETRY_DELAY - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_JOIN_TIMEOUT - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_LEGACY_ROUTING_HASH_FUNCTION - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- SETTING_LEGACY_ROUTING_USE_TYPE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- SETTING_MASTER_ELECTION_FILTER_CLIENT - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_MASTER_ELECTION_FILTER_DATA - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_MASTER_ELECTION_WAIT_FOR_JOINS_TIMEOUT - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_MAX_PINGS_FROM_ANOTHER_MASTER - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_MEMORY_STORAGE_HINT - Static variable in class org.elasticsearch.index.fielddata.IndexFieldData.CommonSettings
-
- 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_PING_INTERVAL - Static variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- SETTING_PING_RETRIES - Static variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- SETTING_PING_TIMEOUT - Static variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- SETTING_PING_TIMEOUT - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_PIPELINING - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- SETTING_PIPELINING_MAX_EVENTS - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- 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 - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
- SETTING_REGISTER_CONNECTION_LISTENER - Static variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- SETTING_SEND_LEAVE_REQUEST - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- SETTING_SHADOW_REPLICAS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- SETTING_SHARD_BALANCE_FACTOR - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
- SETTING_SHARED_FILESYSTEM - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- SETTING_SHARED_FS_ALLOW_RECOVERY_ON_ANY_NODE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- SETTING_THRESHOLD - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
- SETTING_TRACE_LOG_EXCLUDE - Static variable in class org.elasticsearch.transport.TransportService
-
- SETTING_TRACE_LOG_INCLUDE - Static variable in class org.elasticsearch.transport.TransportService
-
- 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_MINIMUM_COMPATIBLE - 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
-
- settings() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node settings be returned.
- settings(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Should the node settings be returned.
- settings(Settings) - 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.repositories.put.PutRepositoryRequest
-
Sets the repository settings
- settings(String) - 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.repositories.put.PutRepositoryRequest
-
Sets the repository settings.
- settings() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Returns repository settings
- settings(Settings) - 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.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings.
- settings(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings in JSON, YAML or properties format
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings.
- settings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns repository-specific snapshot settings
- settings(Settings) - 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.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository-specific restore settings.
- settings(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository-specific restore settings in JSON, YAML or properties format
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository-specific restore settings
- settings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns repository-specific restore settings
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
- 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(Object...) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
A simplified version of settings that takes key value pairs settings.
- settings(Settings) - 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.create.CreateIndexRequest
-
The settings to create the index with.
- settings(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with (either json/yaml/properties format)
- settings(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Allows to set the settings using a json builder.
- 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() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
-
- settings() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
- settings(Settings) - 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.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated
- settings(String) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated (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/yaml/properties format)
- settings(Settings) - 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.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with.
- settings(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with (either json/yaml/properties format).
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to crete the index template with (either json/yaml/properties format).
- settings() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- settings() - Method in interface org.elasticsearch.client.Client
-
Returns this clients settings
- settings() - Method in class org.elasticsearch.client.support.AbstractClient
-
- settings(Settings.Builder) - Method in class org.elasticsearch.client.transport.TransportClient.Builder
-
The settings to configure the transport client with.
- settings(Settings) - Method in class org.elasticsearch.client.transport.TransportClient.Builder
-
The settings to configure the transport client with.
- settings(Settings.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- settings(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- settings(Settings.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- settings(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- 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(Settings) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
-
- settings() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
-
Returns repository settings
- settings - Variable in class org.elasticsearch.common.cli.CliTool
-
- settings - Variable in class org.elasticsearch.common.component.AbstractComponent
-
- Settings - Class in org.elasticsearch.common.settings
-
An immutable settings implementation.
- settings() - Method in class org.elasticsearch.env.Environment
-
The settings used to build this environment.
- settings() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- Settings() - Constructor for class org.elasticsearch.index.query.SimpleQueryParser.Settings
-
- settings() - Method in class org.elasticsearch.node.Node
-
The settings that were used to create the node.
- settings() - Method in class org.elasticsearch.node.NodeBuilder
-
Set addition settings simply by working directly against the settings builder.
- settings(Settings.Builder) - Method in class org.elasticsearch.node.NodeBuilder
-
Explicit node settings to set.
- settings(Settings) - Method in class org.elasticsearch.node.NodeBuilder
-
Explicit node settings to set.
- settings(Settings) - Method in class org.elasticsearch.repositories.RepositoriesService.RegisterRepositoryRequest
-
Sets repository settings
- settings() - Method in class org.elasticsearch.repositories.RepositorySettings
-
- settings(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgBuilder
-
The hash of settings that should be provided to the model when it is
instantiated
- SETTINGS - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgParser
-
- settings() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
-
Returns repository-specific restore settings
- settings(Settings) - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Sets repository-specific snapshot settings
- settings() - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Returns repository-specific settings for the snapshot operation
- settings - Variable in class org.elasticsearch.transport.netty.NettyTransport.ServerChannelPipelineFactory
-
- settings() - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- Settings.Builder - Class in org.elasticsearch.common.settings
-
- 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_REQUIRE_UNITS - Static variable in class org.elasticsearch.common.settings.Settings
-
Name of the setting to use to disable required units for byte size, time settings.
- settingsBuilder() - Static method in class org.elasticsearch.common.settings.Settings
-
Returns a builder to be used in order to build settings.
- 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, 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
-
- SettingsFilter(Settings) - Constructor for class org.elasticsearch.common.settings.SettingsFilter
-
- SettingsLoader - Interface in org.elasticsearch.common.settings.loader
-
Provides the ability to load settings (in the form of a simple Map) from
the actual source content that represents them.
- SettingsLoader.Helper - Class in org.elasticsearch.common.settings.loader
-
- SettingsLoaderFactory - Class in org.elasticsearch.common.settings.loader
-
A settings loader factory automatically trying to identify what type of
SettingsLoader
to use.
- SettingsModule - Class in org.elasticsearch.common.settings
-
A module that binds the provided settings to the
Settings
interface.
- SettingsModule(Settings) - Constructor for class org.elasticsearch.common.settings.SettingsModule
-
- settingsService() - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- settingsService() - Method in class org.elasticsearch.index.IndexService
-
- setTokenFilters(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets token filters that will be used on top of a tokenizer provided.
- setTokenizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Instead of setting the analyzer, sets the tokenizer that will be used as part of a custom
analyzer.
- setTrackScores(boolean) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
Whether to compute a score for each match and include it in the response.
- 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.support.BaseInnerHitBuilder
-
Applies when sorting, and controls if scores will be tracked as well.
- setTrackScores(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Applies when sorting, and controls if scores will be tracked as well.
- setTransformSource(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Should the source be transformed using the script to used at index time
(if any)? Note that calling this without having called setFetchSource
will automatically turn on source fetching.
- 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.
- setTransientSettings(String) - 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.
- setTranslog(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
- setTranslogGeneration(Translog.TranslogGeneration) - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Set the generation to be opened.
- setTranslogLocation(Translog.Location) - Method in class org.elasticsearch.index.engine.Engine.Delete
-
- setTranslogLocation(Translog.Location) - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- 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.
- setTransport(Class<? extends Transport>, String) - Method in class org.elasticsearch.transport.TransportModule
-
- setTransportService(Class<? extends TransportService>, String) - Method in class org.elasticsearch.transport.TransportModule
-
- setTranspositions(boolean) - Method in class org.elasticsearch.index.search.MatchQuery
-
- setTree(String) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- setTreeLevels(int) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- setTTL(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the ttl value as a time value expression.
- setTTL(long) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the relative ttl value in milliseconds.
- setTTL(TimeValue) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
- setTtl(Long) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Set the new ttl of the document as a long.
- setTtl(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Set the new ttl of the document as a time value expression.
- setTtl(TimeValue) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Set the new ttl of the document as a
TimeValue
instance.
- setType(StoreRateLimiting.Type) - Method in class org.apache.lucene.store.StoreRateLimiting
-
- setType(String) - Method in class org.apache.lucene.store.StoreRateLimiting
-
- 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.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(TranslogWriter.Type) - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Sets the TranslogType for this Translog.
- setType(String) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder.InnerHit
-
For nested inner hits the path to collect child nested docs for.
- setTypes(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
The document types to execute the search against.
- 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.count.CountRequestBuilder
-
Deprecated.
The types of documents the query will run against.
- setTypes(String...) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
-
Deprecated.
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[]) - Static method in class org.elasticsearch.index.query.QueryParseContext
-
- setTypesWithPrevious(String[]) - Static method in class org.elasticsearch.index.query.QueryParseContext
-
- setUnicodeAware(boolean) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionFuzzyBuilder
-
Set to true if all measurements (like edit distance, transpositions and lengths) are in unicode
code points (actual letters) instead of bytes.
- setUnlikeText(Fields...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- setUnlikeText(List<String>) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- setup() - Static method in class org.elasticsearch.common.netty.NettyUtils
-
- setUpdateAllTypes(boolean) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
True if all fields that span multiple types should be updated, false otherwise
- setUpdateAllTypes(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
True if all fields that span multiple types should be updated, false otherwise
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
-
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
-
- setupFieldType(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.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?
- 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(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(String) - 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[]) - 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[], int, int) - 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.
- setValue(NumericTokenStream, String) - Method in class org.elasticsearch.index.analysis.NumericDateTokenizer
-
- setValue(NumericTokenStream, String) - Method in class org.elasticsearch.index.analysis.NumericDoubleTokenizer
-
- setValue(NumericTokenStream, String) - Method in class org.elasticsearch.index.analysis.NumericFloatTokenizer
-
- setValue(NumericTokenStream, String) - Method in class org.elasticsearch.index.analysis.NumericIntegerTokenizer
-
- setValue(NumericTokenStream, String) - Method in class org.elasticsearch.index.analysis.NumericLongTokenizer
-
- setValue(NumericTokenStream, String) - Method in class org.elasticsearch.index.analysis.NumericTokenizer
-
- setValue(NumericTokenStream, String) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.NumericIpTokenizer
-
- setVerbose(boolean) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
-
- setVerify(boolean) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets whether or not repository should be verified after creation
- 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.indexedscripts.get.GetIndexedScriptRequestBuilder
-
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.indexedscripts.put.PutIndexedScriptRequestBuilder
-
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(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should each
SearchHit
be returned with its
version.
- 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(Version) - Method in class org.elasticsearch.common.compress.CompressedStreamInput
-
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
-
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
- setVersion(boolean) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
Should each
SearchHit
be returned with its
version.
- setVersion(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Should each
SearchHit
be returned with its
version.
- setVersionMapSizeSetting(String) - Method in class org.elasticsearch.index.engine.EngineConfig
-
Settings the version map size that should trigger a refresh.
- 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.indexedscripts.delete.DeleteIndexedScriptRequestBuilder
-
Sets the type of versioning to use.
- setVersionType(VersionType) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequestBuilder
-
Sets the versioning type.
- setVersionType(VersionType) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
-
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
-
- 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.
- setWaitForRelocatingShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
- 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
-
- setWarmers(String...) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequestBuilder
-
- setWeight(float) - Method in class org.elasticsearch.index.query.functionscore.factor.FactorBuilder
-
Deprecated.
- setWeight(float) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
- setWindowSize(int) - Method in class org.elasticsearch.search.rescore.RescoreSearchContext
-
- setZeroTermsQuery(MatchQuery.ZeroTermsQuery) - Method in class org.elasticsearch.index.search.MatchQuery
-
- sha1() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
- SHA1_CHECKSUM - Static variable in class org.elasticsearch.common.http.client.HttpDownloadHelper
-
Checksummer for SHA1
- sha256() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
- ShadowEngine - Class in org.elasticsearch.index.engine
-
ShadowEngine is a specialized engine that only allows read-only operations
on the underlying Lucene index.
- ShadowEngine(EngineConfig) - Constructor for class org.elasticsearch.index.engine.ShadowEngine
-
- ShadowIndexShard - Class in org.elasticsearch.index.shard
-
ShadowIndexShard extends
IndexShard
to add file synchronization
from the primary when a flush happens.
- ShadowIndexShard(ShardId, IndexSettingsService, IndicesLifecycle, Store, StoreRecoveryService, ThreadPool, MapperService, IndexQueryParserService, IndexCache, IndexAliasesService, IndicesQueryCache, ShardPercolateService, CodecService, ShardTermVectorsService, IndexFieldDataService, IndexService, IndicesWarmer, SnapshotDeletionPolicy, SimilarityService, EngineFactory, ClusterService, ShardPath, BigArrays, IndexSearcherWrappingService, IndexingMemoryController) - Constructor for class org.elasticsearch.index.shard.ShadowIndexShard
-
- shape(ShapeBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- SHAPE_FIELD_NAME - Static variable in class org.elasticsearch.index.query.GeoShapeQueryParser.DEFAULTS
-
- ShapeBuilder - 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
-
- ShapeBuilder(ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- ShapeBuilder.CoordinateNode - Class in org.elasticsearch.common.geo.builders
-
Node used to represent a tree of coordinates.
- ShapeBuilder.Edge - Class in org.elasticsearch.common.geo.builders
-
This helper class implements a linked list for Coordinate
.
- ShapeBuilder.GeoShapeType - Enum in org.elasticsearch.common.geo.builders
-
- ShapeBuilder.Orientation - Enum in org.elasticsearch.common.geo.builders
-
- ShapeFetchService - Class in org.elasticsearch.index.search.shape
-
Service which retrieves pre-indexed Shapes from another index
- ShapeFetchService(Client, Settings) - Constructor for class org.elasticsearch.index.search.shape.ShapeFetchService
-
- ShapeModule - Class in org.elasticsearch.index.search.shape
-
- ShapeModule() - Constructor for class org.elasticsearch.index.search.shape.ShapeModule
-
- shapename - Variable in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- 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
- shapes - Variable in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- ShapesAvailability - Class in org.elasticsearch.common.geo
-
- shard() - Method in class org.elasticsearch.action.search.ShardSearchFailure
-
The search shard target the failure occurred on.
- shard - Variable in class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation.FailedShard
-
- shard() - Method in exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
-
Returns the shard instance referenced by this exception
- shard(int) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
- shard(int) - Method in class org.elasticsearch.index.IndexService
-
Return the shard with the provided id, or null if there is no such shard.
- shard - Variable in class org.elasticsearch.indices.cache.request.IndicesRequestCache.Key
-
- shard() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- shard(SearchShardTarget) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- shard() - Method in exception org.elasticsearch.search.SearchException
-
- shard() - Method in interface org.elasticsearch.search.SearchHit
-
The shard of the search hit.
- SHARD_FAILED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
- SHARD_INACTIVE_INTERVAL_TIME_SETTING - Static variable in class org.elasticsearch.indices.memory.IndexingMemoryController
-
How frequently we check shards to find inactive ones (default: 30 seconds).
- SHARD_INACTIVE_TIME_SETTING - Static variable in class org.elasticsearch.indices.memory.IndexingMemoryController
-
If we see no indexing operations after this much time for a given shard, we consider that shard inactive (default: 5 minutes).
- SHARD_MIN_DOC_COUNT_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- SHARD_SIZE - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
-
- SHARD_SIZE_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerParser
-
- SHARD_SIZE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- SHARD_STARTED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
- ShardActiveRequest() - Constructor for class org.elasticsearch.indices.store.IndicesStore.ShardActiveRequest
-
- shardAvailable(IndexShard) - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
-
returns true if shard exists and is availabe for updates
- ShardBitsetFilterCache - Class in org.elasticsearch.index.cache.bitset
-
- ShardBitsetFilterCache(ShardId, Settings) - Constructor for class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
-
- shardBitsetFilterCache() - Method in class org.elasticsearch.index.shard.IndexShard
-
- 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
-
- ShardDfsOnlyRequest - Class in org.elasticsearch.action.termvectors.dfs
-
- ShardDfsOnlyRequest() - Constructor for class org.elasticsearch.action.termvectors.dfs.ShardDfsOnlyRequest
-
- shardDirectory() - Method in class org.elasticsearch.index.store.IndexStore
-
The shard store class that should be used for each shard.
- shardExecute(Task, Request, ShardId, ActionListener<ShardResponse>) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
-
- ShardExistsRequest - Class in org.elasticsearch.action.exists
-
- ShardExistsRequest() - Constructor for class org.elasticsearch.action.exists.ShardExistsRequest
-
- shardFailed(ShardRouting, String, String, Throwable) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
- shardFailures() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
-
- shardFailures() - Method in class org.elasticsearch.snapshots.Snapshot
-
Returns shard failures
- shardFailures() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns shard failures
- ShardFetchRequest - Class in org.elasticsearch.search.fetch
-
Shard level fetch base request.
- ShardFetchRequest() - Constructor for class org.elasticsearch.search.fetch.ShardFetchRequest
-
- ShardFetchRequest(SearchScrollRequest, long, IntArrayList, ScoreDoc) - Constructor for class org.elasticsearch.search.fetch.ShardFetchRequest
-
- ShardFetchRequest(TransportRequest, 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(SearchRequest, long, IntArrayList) - Constructor for class org.elasticsearch.search.fetch.ShardFetchSearchRequest
-
- ShardFetchSearchRequest(SearchRequest, 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(FlushRequest, ShardId) - Constructor for class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
-
- ShardFlushRequest() - Constructor for class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
-
- ShardGetService - Class in org.elasticsearch.index.get
-
- ShardGetService(IndexShard, MapperService) - Constructor for class org.elasticsearch.index.get.ShardGetService
-
- shardHandleLookup() - Method in class org.elasticsearch.search.internal.InternalSearchHits.StreamContext
-
- shardId() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- shardId() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
- shardId() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Request
-
- shardId() - Method in class org.elasticsearch.action.search.ShardSearchFailure
-
The shard id the search failed on.
- shardId() - Method in interface org.elasticsearch.action.ShardOperationFailedException
-
The shard the operation failed on.
- shardId() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
-
- shardId() - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
-
- shardId - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Target shard the request should execute on.
- shardId() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
- shardId - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
-
- shardId() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
-
- shardId() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand
-
Get the shards 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(ClusterState, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
-
- 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 - Variable in class org.elasticsearch.index.engine.Engine
-
- shardId - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
-
- shardId() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
-
- shardId() - Method in interface org.elasticsearch.index.shard.IndexShardComponent
-
- ShardId - Class in org.elasticsearch.index.shard
-
Allows for shard level components to be injected with the shard id.
- ShardId(String, int) - Constructor for class org.elasticsearch.index.shard.ShardId
-
- ShardId(Index, int) - Constructor for class org.elasticsearch.index.shard.ShardId
-
- shardId - Variable in class org.elasticsearch.index.translog.TranslogWriter
-
- shardId - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
-
- 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.IndicesWarmer.WarmerContext
-
- 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.RecoveryPrepareForTranslogOperationsRequest
-
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
-
- 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.search.SearchShardTarget
-
- shardId() - Method in class org.elasticsearch.snapshots.RestoreService.UpdateIndexShardRestoreStatusRequest
-
- shardId() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
Returns shard id where failure occurred
- shardId() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
-
- shardIds() - Method in class org.elasticsearch.index.IndexService
-
- ShardIndexingService - Class in org.elasticsearch.index.indexing
-
- ShardIndexingService(ShardId, Settings) - Constructor for class org.elasticsearch.index.indexing.ShardIndexingService
-
- ShardIndexWarmerService - Class in org.elasticsearch.index.warmer
-
- ShardIndexWarmerService(ShardId, Settings) - Constructor for class org.elasticsearch.index.warmer.ShardIndexWarmerService
-
- ShardInfo() - Constructor for class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- ShardInfo(int, int, ActionWriteResponse.ShardInfo.Failure...) - Constructor for class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- shardInjectorSafe(int) - Method in class org.elasticsearch.index.IndexService
-
Return the shard injector for the provided id, or throw an exception if there is no such shard.
- 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
-
- shardMinDocCount(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Expert: set the minimum number of documents that a term should match to
be retrieved from a shard.
- shardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Set the minimum document count terms should have on the shard in order to appear in the response.
- shardModules(Settings) - Method in class org.elasticsearch.plugins.Plugin
-
Per index shard module.
- shardModules(Settings) - Method in class org.elasticsearch.plugins.PluginsService
-
- ShardNotFoundException - Exception in org.elasticsearch.index.shard
-
- ShardNotFoundException(ShardId) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
-
- ShardNotFoundException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
-
- ShardNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
-
- 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) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
-
- shardOperation(ShardExistsRequest) - Method in class org.elasticsearch.action.exists.TransportExistsAction
-
- shardOperation(ExplainRequest, ShardId) - Method in class org.elasticsearch.action.explain.TransportExplainAction
-
- shardOperation(FieldStatsShardRequest) - Method in class org.elasticsearch.action.fieldstats.TransportFieldStatsTransportAction
-
- shardOperation(GetRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportGetAction
-
- shardOperation(MultiGetShardRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
-
- shardOperation(PercolateShardRequest) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
-
- shardOperation(TransportShardMultiPercolateAction.Request, ShardId) - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
-
- shardOperation(ShardSuggestRequest) - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
-
- shardOperation(Request, ShardRouting) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Executes the shard-level operation.
- shardOperation(ShardRequest) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
-
- shardOperation(ShardRequest, Task) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
-
- shardOperation(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
- shardOperation(Request, ShardId) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
- shardOperation(ShardDfsOnlyRequest) - Method in class org.elasticsearch.action.termvectors.dfs.TransportDfsOnlyAction
-
- 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
-
- ShardOperationFailedException - Interface in org.elasticsearch.action
-
An exception indicating that a failure occurred performing an operation on the shard.
- shardOperationOnPrimary(MetaData, ShardFlushRequest) - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
-
- shardOperationOnPrimary(MetaData, ReplicationRequest) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
-
- shardOperationOnPrimary(MetaData, BulkShardRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
-
- shardOperationOnPrimary(MetaData, DeleteRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
-
- shardOperationOnPrimary(MetaData, IndexRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
-
- shardOperationOnPrimary(MetaData, Request) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Primary operation on node with primary copy, the provided metadata should be used for request validation if needed
- shardOperationOnReplica(ShardFlushRequest) - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
-
- shardOperationOnReplica(ReplicationRequest) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
-
- shardOperationOnReplica(BulkShardRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
-
- shardOperationOnReplica(DeleteRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
-
- shardOperationOnReplica(IndexRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
-
- shardOperationOnReplica(ReplicaRequest) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Replica operation on nodes with replica copies
- shardPath() - Method in class org.elasticsearch.index.shard.IndexShard
-
- ShardPath - Class in org.elasticsearch.index.shard
-
- ShardPath(boolean, Path, Path, String, ShardId) - Constructor for class org.elasticsearch.index.shard.ShardPath
-
- ShardPercolateService - Class in org.elasticsearch.index.percolator.stats
-
Shard level percolator service that maintains percolator metrics:
total time spent in percolate api
the current number of percolate requests
number of registered percolate queries
- ShardPercolateService(ShardId, IndexSettingsService) - Constructor for class org.elasticsearch.index.percolator.stats.ShardPercolateService
-
- shardPercolateService() - Method in class org.elasticsearch.index.shard.IndexShard
-
- shardRecoveryStates() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
-
- ShardRequestCache - Class in org.elasticsearch.index.cache.request
-
- ShardRequestCache(ShardId, Settings) - 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 - Class in org.elasticsearch.cluster.routing
-
ShardRouting
immutably encapsulates information about shard
routings like id, state, version, etc.
- ShardRouting(ShardRouting) - Constructor for class org.elasticsearch.cluster.routing.ShardRouting
-
- ShardRouting(ShardRouting, long) - Constructor for class org.elasticsearch.cluster.routing.ShardRouting
-
- shardRouting - Variable in class org.elasticsearch.index.shard.IndexShard
-
- shardRoutingChanged(IndexShard, ShardRouting, ShardRouting) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
-
Called when the shard routing has changed state.
- shardRoutingChanged(IndexShard, ShardRouting, ShardRouting) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
-
- ShardRoutingEntry() - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardRoutingEntry
-
- 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
- shards(ClusterState, TransportSingleShardAction<AnalyzeRequest, AnalyzeResponse>.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
-
- 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, TransportSingleShardAction<GetFieldMappingsIndexRequest, GetFieldMappingsResponse>.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
-
- 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, ExistsRequest, String[]) - Method in class org.elasticsearch.action.exists.TransportExistsAction
-
- shards(ClusterState, TransportSingleShardAction<ExplainRequest, ExplainResponse>.InternalRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
-
- shards(ClusterState, FieldStatsRequest, String[]) - Method in class org.elasticsearch.action.fieldstats.TransportFieldStatsTransportAction
-
- shards(ClusterState, TransportSingleShardAction<GetRequest, GetResponse>.InternalRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
-
- shards(ClusterState, TransportSingleShardAction<MultiGetShardRequest, MultiGetShardResponse>.InternalRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
-
- shards(ClusterState, PercolateRequest, String[]) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
-
- shards(ClusterState, TransportSingleShardAction<TransportShardMultiPercolateAction.Request, TransportShardMultiPercolateAction.Response>.InternalRequest) - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
-
- shards(ClusterState, SuggestRequest, String[]) - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
-
- 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(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
Should return an iterator with a single shard!
- shards(ClusterState, TransportSingleShardAction<Request, Response>.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, DfsOnlyRequest, String[]) - Method in class org.elasticsearch.action.termvectors.dfs.TransportDfsOnlyAction
-
- shards(ClusterState, TransportSingleShardAction<MultiTermVectorsShardRequest, MultiTermVectorsShardResponse>.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
-
- shards(ClusterState, TransportSingleShardAction<TermVectorsRequest, TermVectorsResponse>.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
-
- shards(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
-
- 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
-
- shards(ClusterState, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
-
- shards(Predicate<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- shards() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
-
- SHARDS_ALLOCATOR_TYPE_KEY - Static variable in class org.elasticsearch.cluster.ClusterModule
-
- shardSafe(int) - Method in class org.elasticsearch.index.IndexService
-
Return the shard with the provided id, or throw an exception if it doesn't exist.
- ShardsAllocator - Interface in org.elasticsearch.cluster.routing.allocation.allocator
-
A
ShardsAllocator
is the main entry point for shard allocation on nodes in the cluster.
- ShardsAllocators - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
The
ShardsAllocator
class offers methods for allocating shard within a cluster.
- ShardsAllocators(GatewayAllocator) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
-
- ShardsAllocators(Settings, GatewayAllocator) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
-
- ShardsAllocators(Settings, GatewayAllocator, ShardsAllocator) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
-
- ShardSearchFailure - Class in org.elasticsearch.action.search
-
Represents a failure to search on a specific shard.
- ShardSearchFailure(Throwable) - Constructor for class org.elasticsearch.action.search.ShardSearchFailure
-
- ShardSearchFailure(Throwable, SearchShardTarget) - Constructor for class org.elasticsearch.action.search.ShardSearchFailure
-
- ShardSearchFailure(String, SearchShardTarget) - Constructor for class org.elasticsearch.action.search.ShardSearchFailure
-
- ShardSearchFailure(String, SearchShardTarget, RestStatus) - 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(String[], long) - Constructor for class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- ShardSearchLocalRequest(String[], long, String[]) - Constructor for class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- ShardSearchLocalRequest(ShardId, int, SearchType, BytesReference, String[], Boolean) - 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(Settings) - 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(SearchRequest, ShardRouting, int, String[], long) - Constructor for class org.elasticsearch.search.internal.ShardSearchTransportRequest
-
- ShardSegments - Class in org.elasticsearch.action.admin.indices.segments
-
- shardServices() - Method in class org.elasticsearch.plugins.Plugin
-
Per index shard service that will be automatically closed.
- shardServices() - Method in class org.elasticsearch.plugins.PluginsService
-
- 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(int) - 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.
- ShardsIterator - Interface in org.elasticsearch.cluster.routing
-
Allows to iterate over unrelated shards.
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridBuilder
-
Expert: Set the number of buckets to get on each shard to improve
accuracy.
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
-
Set the max num docs to be returned from each shard.
- shardSize - Variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
-
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Expert: Set the number of significant terms to retrieve on each shard.
- shardSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
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.SuggestBuilder.SuggestionBuilder
-
Sets the maximum number of suggested term to be retrieved from each
individual shard.
- 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, NodeSettingsService) - 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
-
- 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, String, String) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
- shardStarted(ShardRouting, String, String, DiscoveryNode) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
- shardStateAction - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- ShardStateAction - Class in org.elasticsearch.cluster.action.shard
-
- ShardStateAction(Settings, ClusterService, TransportService, AllocationService, RoutingService) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction
-
- ShardStateAction.ShardRoutingEntry - Class in org.elasticsearch.cluster.action.shard
-
- ShardStateMetaData - Class in org.elasticsearch.index.shard
-
- ShardStateMetaData(long, boolean, String) - 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() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
- ShardStats - Class in org.elasticsearch.action.admin.indices.stats
-
- ShardStats(ShardRouting, ShardPath, CommonStats, CommitStats) - Constructor for class org.elasticsearch.action.admin.indices.stats.ShardStats
-
- shardStatuses(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Set statuses to filter shards to get stores info on.
- shardStatuses() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Returns the shard criteria to get store information on
- 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.
- ShardSuggestMetric - Class in org.elasticsearch.index.suggest.stats
-
- ShardSuggestMetric() - Constructor for class org.elasticsearch.index.suggest.stats.ShardSuggestMetric
-
- ShardSuggestRequest - Class in org.elasticsearch.action.suggest
-
Internal suggest request executed directly against a specific index shard.
- ShardSuggestRequest() - Constructor for class org.elasticsearch.action.suggest.ShardSuggestRequest
-
- shardsWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Returns a
List
of shards that match one of the states listed in
states
- shardsWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
- shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Determine the shards with a specific state
- shardsWithState(String, ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Determine the shards of an index with a specific state
- shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- shardsWithState(String, ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- shardsWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- 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.percolator.PercolateContext
-
- shardTarget() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- shardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- shardTarget() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
-
- shardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.fetch.FetchSearchResult
-
- shardTarget() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
-
- shardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
-
- shardTarget() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
-
- shardTarget() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- shardTarget() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- shardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- shardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- shardTarget() - Method in class org.elasticsearch.search.internal.SearchContext
-
- shardTarget() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- shardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- shardTarget() - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
-
- shardTarget() - Method in interface org.elasticsearch.search.SearchPhaseResult
-
- shardTarget(SearchShardTarget) - Method in interface org.elasticsearch.search.SearchPhaseResult
-
- ShardTermVectorsService - Class in org.elasticsearch.index.termvectors
-
- ShardTermVectorsService(ShardId, IndexSettingsService, MappingUpdatedAction, TransportDfsOnlyAction) - Constructor for class org.elasticsearch.index.termvectors.ShardTermVectorsService
-
- 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
-
- sharedDataFile() - Method in class org.elasticsearch.env.Environment
-
The shared data location
- SharedFSRecoverySourceHandler - Class in org.elasticsearch.indices.recovery
-
A recovery handler that skips phase 1 as well as sending the snapshot.
- SharedFSRecoverySourceHandler(IndexShard, StartRecoveryRequest, RecoverySettings, TransportService, ESLogger) - Constructor for class org.elasticsearch.indices.recovery.SharedFSRecoverySourceHandler
-
- shell - Variable in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- shift(Coordinate, double) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- ShingleTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- ShingleTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
-
- ShingleTokenFilterFactory.Factory - Class in org.elasticsearch.index.analysis
-
- shortCircuit() - Method in class org.elasticsearch.http.netty.cors.CorsConfigBuilder
-
Specifies that a CORS request should be rejected if it's invalid before being
further processing.
- shortCircuitParentDocSet - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- shortField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- ShortFieldMapper - Class in org.elasticsearch.index.mapper.core
-
- ShortFieldMapper(String, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper
-
- ShortFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
-
- ShortFieldMapper.CustomShortNumericField - Class in org.elasticsearch.index.mapper.core
-
- ShortFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
-
- ShortFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
-
- shortName() - Method in enum org.elasticsearch.common.xcontent.XContentType
-
- 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.
- shortValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- shortValue(boolean) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- shortValue(boolean) - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- shortValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- should(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Adds a query that should appear in the matching documents.
- shouldAutoCreate(String, ClusterState) - Method in class org.elasticsearch.action.support.AutoCreateIndex
-
Should the index be auto created?
- shouldCache(Query, LeafReaderContext) - Method in class org.apache.lucene.search.XUsageTrackingQueryCachingPolicy
-
- shouldConnectTo(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Should this node form a connection to the provided node.
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
This method should be overidden 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
-
- shouldExecuteReplication(Settings) - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
-
- shouldExecuteReplication(Settings) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
-
- shouldExecuteReplication(Settings) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Indicated whether this operation should be replicated to shadow replicas or not.
- shouldGetFromSource(boolean, DocumentMapper, FieldMapper) - Method in class org.elasticsearch.index.get.ShardGetService
-
- shouldIgnoreMissing(String) - Method in interface org.elasticsearch.common.property.PropertyPlaceholder.PlaceholderResolver
-
- shouldIgnoreShardForNode(ShardId, String) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
- shouldParse() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Do we really need parsing?
- shouldParseId() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Does id parsing really needed at all?
- shouldParseRouting() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Does routing parsing really needed at all?
- shouldParseTimestamp() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Does timestamp parsing really needed at all?
- shouldRemoveMissingPlaceholder(String) - Method in interface org.elasticsearch.common.property.PropertyPlaceholder.PlaceholderResolver
-
Allows for special handling for ignored missing placeholders that may be resolved elsewhere
- SHOW_TERM_DOC_COUNT_ERROR - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
-
- showDocCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
-
- showTermDocCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- showTermDocCountError(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Expert: return document count errors per term in the response.
- showTermDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsParametersParser
-
- shuffle(List<ShardRouting>, int) - Method in class org.elasticsearch.cluster.routing.RotationShardShuffler
-
- shuffle() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
- shuffle(List<ShardRouting>, int) - Method in class org.elasticsearch.cluster.routing.ShardShuffler
-
Return a shuffled view over the list of shards.
- shuffle(List<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.ShardShuffler
-
Equivalent to calling shuffle(shards, nextSeed())
.
- shutdown(EsThreadPoolExecutor.ShutdownListener) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
-
- shutdown() - Method in class org.elasticsearch.threadpool.ThreadPool
-
- shutdownNow() - Method in class org.elasticsearch.threadpool.ThreadPool
-
- SiblingPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
-
- SiblingPipelineAggregator() - Constructor for class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
-
- SiblingPipelineAggregator(String, String[], Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
-
- SIDE_BACK - Static variable in class org.elasticsearch.index.analysis.EdgeNGramTokenFilterFactory
-
- SIDE_FRONT - Static variable in class org.elasticsearch.index.analysis.EdgeNGramTokenFilterFactory
-
- sigma(double) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsBuilder
-
- sigma(Double) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketBuilder
-
- SignificanceHeuristic - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- SignificanceHeuristic() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristic
-
- significanceHeuristic - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
- significanceHeuristic(SignificanceHeuristicBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
- SignificanceHeuristicBuilder - Interface in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- SignificanceHeuristicParser - Interface in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- SignificanceHeuristicParserMapper - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
- SignificanceHeuristicParserMapper(Set<SignificanceHeuristicParser>, ScriptService) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicParserMapper
-
- significanceHeuristicParsers - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicParserMapper
-
- SignificanceHeuristicStreams - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
A registry for all significance heuristics.
- SignificanceHeuristicStreams() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicStreams
-
- SignificanceHeuristicStreams.Stream - Interface in org.elasticsearch.search.aggregations.bucket.significant.heuristics
-
A stream that knows how to read an heuristic from the input.
- SignificantLongTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- SignificantLongTerms(long, long, String, ValueFormatter, int, long, SignificanceHeuristic, List<? extends InternalSignificantTerms.Bucket>, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
-
- SignificantLongTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- SignificantLongTermsAggregator(String, AggregatorFactories, ValuesSource.Numeric, ValueFormat, TermsAggregator.BucketCountThresholds, AggregationContext, Aggregator, 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
-
- SignificantStringTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- SignificantStringTerms(long, long, String, int, long, SignificanceHeuristic, List<? extends InternalSignificantTerms.Bucket>, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
-
- 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, TermsAggregator.BucketCountThresholds, IncludeExclude.StringFilter, AggregationContext, Aggregator, 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
-
- SignificantTerms - Interface in org.elasticsearch.search.aggregations.bucket.significant
-
An aggregation that collects significant terms in comparison to a background set.
- SignificantTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- SignificantTermsAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- SignificantTermsAggregatorFactory(String, ValuesSourceConfig, TermsAggregator.BucketCountThresholds, IncludeExclude, String, Query, SignificanceHeuristic) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
-
- SignificantTermsAggregatorFactory.ExecutionMode - Enum in org.elasticsearch.search.aggregations.bucket.significant
-
- SignificantTermsBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant
-
Creates an aggregation that finds interesting or unusual occurrences of terms in a result set.
- SignificantTermsBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Sole constructor.
- SignificantTermsParametersParser - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- SignificantTermsParametersParser(SignificanceHeuristicParserMapper) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParametersParser
-
- SignificantTermsParser - Class in org.elasticsearch.search.aggregations.bucket.significant
-
- SignificantTermsParser(SignificanceHeuristicParserMapper) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParser
-
- signum(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- signum(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- Similarities - Class in org.elasticsearch.index.similarity
-
Cache of pre-defined Similarities
- similarity(SimilarityProvider) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- similarity() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- similarity(String) - Method in class org.elasticsearch.index.similarity.SimilarityLookupService
-
- similarity() - Method in class org.elasticsearch.index.similarity.SimilarityService
-
- SIMILARITY_SETTINGS_PREFIX - Static variable in class org.elasticsearch.index.similarity.SimilarityModule
-
- similarityLookupService() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
-
- SimilarityLookupService - Class in org.elasticsearch.index.similarity
-
- SimilarityLookupService(Index, Settings) - Constructor for class org.elasticsearch.index.similarity.SimilarityLookupService
-
- SimilarityLookupService(Index, IndexSettingsService, Map<String, SimilarityProvider.Factory>) - Constructor for class org.elasticsearch.index.similarity.SimilarityLookupService
-
- similarityLookupService() - Method in class org.elasticsearch.index.similarity.SimilarityService
-
- SimilarityModule - Class in org.elasticsearch.index.similarity
-
- SimilarityModule(Settings) - Constructor for class org.elasticsearch.index.similarity.SimilarityModule
-
- SimilarityProvider - Interface in org.elasticsearch.index.similarity
-
Provider for Similarity
instances
- SimilarityProvider.Factory - Interface in org.elasticsearch.index.similarity
-
- similarityService() - Method in class org.elasticsearch.index.IndexService
-
- similarityService() - Method in class org.elasticsearch.index.query.QueryParseContext
-
- SimilarityService - Class in org.elasticsearch.index.similarity
-
- SimilarityService(Index, IndexSettingsService, SimilarityLookupService, MapperService) - Constructor for class org.elasticsearch.index.similarity.SimilarityService
-
- similarityService() - Method in class org.elasticsearch.percolator.PercolateContext
-
- similarityService() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- similarityService() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- similarityService() - Method in class org.elasticsearch.search.internal.SearchContext
-
- Simple(Settings) - Constructor for class org.elasticsearch.action.support.ActionFilter.Simple
-
- SimpleAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- SimpleAnalyzerProvider(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SimpleAnalyzerProvider
-
- SimpleDistanceBoundingCheck(GeoPoint, GeoPoint) - Constructor for class org.elasticsearch.common.geo.GeoDistance.SimpleDistanceBoundingCheck
-
- SimpleFragmentsBuilder - Class in org.elasticsearch.search.highlight.vectorhighlight
-
Direct Subclass of Lucene's org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder
that corrects offsets for broken analysis chains.
- SimpleFragmentsBuilder(FieldMapper, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.highlight.vectorhighlight.SimpleFragmentsBuilder
-
- SimpleHashFunction - Class in org.elasticsearch.cluster.routing
-
This class implements a simple hash function based on Java Build-In
Object.hashCode()
- SimpleHashFunction() - Constructor for class org.elasticsearch.cluster.routing.SimpleHashFunction
-
- simpleMatch(String, String) - Static method in class org.elasticsearch.common.regex.Regex
-
Match a String against the given pattern, supporting the following simple
pattern styles: "xxx*", "*xxx", "*xxx*" and "xxx*yyy" matches (with an
arbitrary number of pattern parts), as well as direct equality.
- simpleMatch(String[], String) - 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
-
- simpleMatchToFullName(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
-
- simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Returns all the fields that match the given pattern.
- simpleMatchToIndexNames(String, String[]) - Method in class org.elasticsearch.index.mapper.MapperService
-
- simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.query.QueryParseContext
-
- 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.SimpleModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
-
- SimpleModel.SimpleModelParser - Class in org.elasticsearch.search.aggregations.pipeline.movavg.models
-
- SimpleModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel.SimpleModelBuilder
-
- SimpleModelParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel.SimpleModelParser
-
- 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
- SimpleQueryParser - Class in org.elasticsearch.index.query
-
Wrapper class for Lucene's SimpleQueryParser that allows us to redefine
different types of queries.
- SimpleQueryParser(Analyzer, Map<String, Float>, int, SimpleQueryParser.Settings) - Constructor for class org.elasticsearch.index.query.SimpleQueryParser
-
Creates a new parser with custom flags used to enable/disable certain features.
- SimpleQueryParser.Settings - Class in org.elasticsearch.index.query
-
Class encapsulating the settings for the SimpleQueryString query, with
their default values
- 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 the given text
- SimpleQueryStringBuilder.Operator - Enum in org.elasticsearch.index.query
-
Operators for the default_operator
- SimpleQueryStringFlag - Enum in org.elasticsearch.index.query
-
Flags for the XSimpleQueryString parser
- SimpleQueryStringParser - Class in org.elasticsearch.index.query
-
SimpleQueryStringParser is a query parser that acts similar to a query_string
query, but won't throw exceptions for any weird string syntax.
- SimpleQueryStringParser() - Constructor for class org.elasticsearch.index.query.SimpleQueryStringParser
-
- 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.
- SimpleValue - Interface in org.elasticsearch.search.aggregations.pipeline
-
- 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
-
- sin(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- sin(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- sin(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- sin(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- sin(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- 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
-
- Single(Decision.Type, String, String, Object...) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
-
- single() - Method in class org.elasticsearch.common.cli.CliToolConfig
-
- Single(LongArray, BitSet) - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointArrayAtomicFieldData.Single
-
- Single(DoubleArray, DoubleArray, BitSet) - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointArrayLegacyAtomicFieldData.Single
-
- SINGLE_INSTANCE_AND_SCOPE - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
- SingleBucketAggregation - Interface in org.elasticsearch.search.aggregations.bucket
-
A single bucket aggregation
- SingleBucketAggregator - Class in org.elasticsearch.search.aggregations.bucket
-
A bucket aggregator that doesn't create new buckets.
- SingleBucketAggregator(String, AggregatorFactories, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.SingleBucketAggregator
-
- SingleExpModelParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel.SingleExpModelParser
-
- SingleFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
-
- SingleFieldsVisitor(String) - Constructor for class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
-
- 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<T extends SingleShardRequest> - Class in org.elasticsearch.action.support.single.shard
-
- SingleShardRequest() - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
- SingleShardRequest(String) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
- SingleShardRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
- SingleShardRequest(ActionRequest, String) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
- SINGLETON - Static variable in class org.elasticsearch.common.inject.Scopes
-
- 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(NumericDoubleValues, Bits) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
- singleton(GeoPointValues, Bits) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
- singleton(BinaryDocValues, Bits) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Returns a multi-valued view over the provided BinaryDocValues
.
- SINGLETON_ANNOTATION - Static variable in class org.elasticsearch.common.inject.internal.Scoping
-
- SINGLETON_INSTANCE - Static variable in class org.elasticsearch.common.inject.internal.Scoping
-
- singletons - Variable in class org.elasticsearch.common.util.ExtensionPoint
-
- SingleValue() - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
-
- SingleValue(String, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
-
- SingleValue(String, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.SingleValue
-
- sinh(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- size() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
-
- size() - Method in class org.elasticsearch.action.termvectors.TermVectorsFields
-
- size(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
-
- size() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the number of known nodes
- 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.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.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.FastCharArrayWriter
-
Returns the current size of the buffer.
- 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 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.common.util.MinimalMap
-
- size() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingCollection
-
the number of nodes for which there are known pings
- size() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
-
Deprecated.
- size() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommits
-
- 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.fielddata.ScriptDocValues.Strings
-
- 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 - Variable in class org.elasticsearch.index.translog.Translog.Location
-
- size() - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
the number of ongoing recoveries
- size() - Method in class org.elasticsearch.percolator.PercolateContext
-
- size(int) - Method in class org.elasticsearch.percolator.PercolateContext
-
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridBuilder
-
Set the number of buckets to return.
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
-
Set the number of significant terms to retrieve.
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Sets the size - indicating how many term buckets should be returned (defaults to 10)
- size(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The number of search hits to return.
- size() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- size(int) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- size() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- size(int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- size() - Method in class org.elasticsearch.search.internal.SearchContext
-
- size(int) - Method in class org.elasticsearch.search.internal.SearchContext
-
- size() - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- size(int) - 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
-
- size(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- size(int) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
Sets the maximum suggestions to be returned per suggest text term.
- size() - Method in class org.elasticsearch.search.suggest.Suggest
-
The number of suggestions in this
Suggest
result
- size - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
- size(int) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
Sets the maximum suggestions to be returned per suggest text term.
- 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
-
- SizeHeaderFrameDecoder - Class in org.elasticsearch.transport.netty
-
- SizeHeaderFrameDecoder() - Constructor for class org.elasticsearch.transport.netty.SizeHeaderFrameDecoder
-
- SizeHeaderFrameDecoder.HttpOnTransportException - Exception in org.elasticsearch.transport.netty
-
A helper exception to mark an incoming connection as potentially being HTTP
so an appropriate error code can be returned
- sizeInBytes - Variable in class org.elasticsearch.index.cache.query.QueryCache.EntriesStats
-
- 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.BufferingTranslogWriter
-
- sizeInBytes() - Method in class org.elasticsearch.index.translog.ImmutableTranslogReader
-
- sizeInBytes() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the size in bytes of the translog files that aren't committed to lucene.
- sizeInBytes() - Method in class org.elasticsearch.index.translog.Translog.View
-
Returns the size in bytes of the files behind the view.
- sizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogReader
-
- sizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
- sizeOfRelocatingShards(RoutingNode, ClusterInfo, boolean, String) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Returns the size of all shards that are currently being relocated to
the node, but may not be finished transfering yet.
- SizeParseElement - Class in org.elasticsearch.search.query
-
- SizeParseElement() - Constructor for class org.elasticsearch.search.query.SizeParseElement
-
- 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
-
- sizing(Recycler<T>, Recycler<T>, int) - Static method in enum org.elasticsearch.common.recycler.Recyclers
-
Wrap two recyclers and forward to calls to smallObjectRecycler
when size < minSize
and to
defaultRecycler
otherwise.
- skip(long) - Method in class org.elasticsearch.common.io.FastCharArrayReader
-
Skips characters.
- skip(long) - Method in class org.elasticsearch.common.io.FastStringReader
-
Skips the specified number of characters in the stream.
- skip(long) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
-
- skip(int) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
-
- skip(long) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
-
- skip(long) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
-
- skip(long) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- skipBloom(IndexInput) - Static method in class org.elasticsearch.common.util.BloomFilter
-
- skipBytes(int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
-
- skipChildren() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- skipChildren() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- 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.shard.IndexShard
-
After the store has been recovered, we need to start the engine.
- Slf4jESLogger - Class in org.elasticsearch.common.logging.slf4j
-
- Slf4jESLogger(String, Logger) - Constructor for class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
-
- Slf4jESLoggerFactory - Class in org.elasticsearch.common.logging.slf4j
-
- Slf4jESLoggerFactory() - Constructor for class org.elasticsearch.common.logging.slf4j.Slf4jESLoggerFactory
-
- slice(int, int) - Method in class org.elasticsearch.common.bytes.BytesArray
-
- slice(int, int) - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Slice the bytes from the from index up to length.
- slice(int, int) - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- slice(int, int) - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- slice(String, long, long) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
-
Deprecated.
- slice(String, long, long) - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
-
- SlicedInputStream - Class in org.elasticsearch.index.snapshots.blobstore
-
- SlicedInputStream(long) - Constructor for class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
Creates a new SlicedInputStream
- slop(int) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Set the phrase slop if evaluated to a phrase query type.
- slop(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Set the phrase slop if evaluated to a phrase query type.
- slop(int) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
- SloppyArcFixedSourceDistance(double, double, DistanceUnit) - Constructor for class org.elasticsearch.common.geo.GeoDistance.SloppyArcFixedSourceDistance
-
- slot() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response.Item
-
- SMALL_FILE_CUTOFF_BYTES - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
- smallest(Version, Version) - Static method in class org.elasticsearch.Version
-
Returns the smallest version between the 2.
- smallestNonClientNodeVersion() - 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
- smallestVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the oldest version in the cluster
- smartNameFieldMapper(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
-
- smartNameFieldType(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
- smartNameFieldType(String, String[]) - Method in class org.elasticsearch.index.mapper.MapperService
-
- smartNameFieldType(String) - Method in class org.elasticsearch.percolator.PercolateContext
-
- smartNameFieldType(String) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- smartNameFieldType(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- smartNameFieldType(String) - Method in class org.elasticsearch.search.internal.SearchContext
-
- smartNameFieldTypeFromAnyType(String) - Method in class org.elasticsearch.percolator.PercolateContext
-
- smartNameFieldTypeFromAnyType(String) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- smartNameFieldTypeFromAnyType(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- smartNameFieldTypeFromAnyType(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.
- smileBuilder() - Static method in class org.elasticsearch.common.xcontent.XContentFactory
-
- smileBuilder(OutputStream) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
-
Constructs a new json builder that will output the result into the provided output stream.
- SmileXContent - Class in org.elasticsearch.common.xcontent.smile
-
A Smile based content implementation using Jackson.
- smileXContent - Static variable in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- SmileXContentGenerator - Class in org.elasticsearch.common.xcontent.smile
-
- SmileXContentGenerator(JsonGenerator, OutputStream, String...) - Constructor for class org.elasticsearch.common.xcontent.smile.SmileXContentGenerator
-
- SmileXContentParser - Class in org.elasticsearch.common.xcontent.smile
-
- SmileXContentParser(JsonParser) - Constructor for class org.elasticsearch.common.xcontent.smile.SmileXContentParser
-
- smoothingModel(PhraseSuggestionBuilder.SmoothingModel) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets an explicit smoothing model used for this suggester.
- SmoothingModel(String) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.SmoothingModel
-
- snapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets the snapshot name
- 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(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() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns the name of the snapshot.
- snapshot(SnapshotId) - Method in class org.elasticsearch.cluster.RestoreInProgress
-
Returns currently running restore process with corresponding snapshot id or null if this snapshot is not being
restored
- snapshot(SnapshotId) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
-
- snapshot() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
-
Returns a snapshot of the index (for the last commit point).
- snapshot(SnapshotId, ShardId, SnapshotIndexCommit, IndexShardSnapshotStatus) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
Creates a snapshot of the shard based on the index commit point.
- snapshot() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot id
- snapshot() - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
- snapshot(SnapshotId, ShardId, SnapshotIndexCommit, IndexShardSnapshotStatus) - Method in interface org.elasticsearch.index.snapshots.IndexShardRepository
-
Creates a snapshot of the shard based on the index commit point.
- snapshot() - Method in class org.elasticsearch.index.translog.Translog.View
-
create a snapshot from this view
- Snapshot - Class in org.elasticsearch.snapshots
-
Represent information about snapshot
- Snapshot(String, List<String>, long) - Constructor for class org.elasticsearch.snapshots.Snapshot
-
- Snapshot(String, List<String>, long, String, long, int, List<SnapshotShardFailure>) - Constructor for class org.elasticsearch.snapshots.Snapshot
-
- snapshot() - Method in exception org.elasticsearch.snapshots.SnapshotException
-
- snapshot(SnapshotId) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Retrieves snapshot from repository
- SNAPSHOT - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- snapshot - Variable in class org.elasticsearch.Version
-
- snapshot() - Method in class org.elasticsearch.Version
-
- SNAPSHOT_CODEC - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
- SNAPSHOT_INDEX_CODEC - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
- SNAPSHOT_INDEX_NAME_FORMAT - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
- SNAPSHOT_INDEX_PREFIX - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
- SNAPSHOT_NAME_FORMAT - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
- SNAPSHOT_ONLY_FORMAT_PARAMS - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreFormat
-
- SNAPSHOT_PREFIX - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
- SnapshotCreationException - Exception in org.elasticsearch.snapshots
-
Thrown when snapshot creation fails completely
- SnapshotCreationException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotCreationException
-
- SnapshotCreationException(SnapshotId, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotCreationException
-
- SnapshotDeletionPolicy - Class in org.elasticsearch.index.deletionpolicy
-
Snapshot deletion policy allows to get snapshots of an index state (last commit or all commits)
and if the deletion policy is used with all open index writers (JVM level) then the snapshot
state will not be deleted until it will be released.
- SnapshotDeletionPolicy(IndexDeletionPolicy) - Constructor for class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
-
Constructs a new snapshot deletion policy that wraps the provided deletion policy.
- SnapshotException - Exception in org.elasticsearch.snapshots
-
Generic snapshot exception
- SnapshotException(SnapshotId, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
-
- SnapshotException(SnapshotId, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
-
- SnapshotException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
-
- SnapshotFailedEngineException - Exception in org.elasticsearch.index.engine
-
- SnapshotFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.SnapshotFailedEngineException
-
- SnapshotFailedEngineException(StreamInput) - 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 - Class in org.elasticsearch.cluster.metadata
-
Snapshot ID - repository name + snapshot name
- SnapshotId(String, String) - Constructor for class org.elasticsearch.cluster.metadata.SnapshotId
-
Constructs new snapshot id
- snapshotId() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns snapshot id
- snapshotId() - Method in class org.elasticsearch.cluster.routing.RestoreSource
-
- snapshotId() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
-
- snapshotId() - Method in class org.elasticsearch.snapshots.RestoreService.UpdateIndexShardRestoreStatusRequest
-
- snapshotId() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
-
- snapshotIds(SnapshotId[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
-
- snapshotIndex(boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Snapshots the index and returns a handle to it.
- snapshotIndex(boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
-
- snapshotIndex(boolean) - Method in class org.elasticsearch.index.engine.ShadowEngine
-
- snapshotIndex(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
- SnapshotIndexCommit - Class in org.elasticsearch.index.deletionpolicy
-
A snapshot index commit point.
- SnapshotIndexCommits - Class in org.elasticsearch.index.deletionpolicy
-
Represents a snapshot view of several commits.
- SnapshotIndexCommits(List<SnapshotIndexCommit>) - Constructor for class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommits
-
- 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
- SnapshotInfo - Class in org.elasticsearch.snapshots
-
Information about snapshot
- SnapshotInfo(Snapshot) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
-
Creates a new snapshot information from a
Snapshot
- 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
-
- SnapshotInProgressAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
-
- SnapshotInProgressAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
-
- SnapshotMissingException - Exception in org.elasticsearch.snapshots
-
Thrown if requested snapshot doesn't exist
- SnapshotMissingException(SnapshotId, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
-
- SnapshotMissingException(SnapshotId) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
-
- SnapshotMissingException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
-
- SnapshotRequest(String, String, String) - Constructor for class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
-
Constructs new snapshot creation request
- SnapshotRestoreException - Exception in org.elasticsearch.snapshots
-
Snapshot restore exception
- SnapshotRestoreException(SnapshotId, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
-
- SnapshotRestoreException(SnapshotId, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
-
- SnapshotRestoreException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
-
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
-
- snapshots(int) - 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(String[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Sets the list of snapshots to be returned
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Returns the names of the snapshots.
- snapshots(String[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Sets the list of snapshots to be returned
- snapshots() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
-
Snapshots all the current commits in the index.
- snapshots() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Returns list of snapshots
- snapshots() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns the list of snapshots currently stored in the repository
- snapshots() - Method in interface org.elasticsearch.repositories.Repository
-
Returns the list of snapshots currently stored in the repository
- snapshots() - Method in class org.elasticsearch.repositories.uri.URLRepository
-
- snapshots(String, boolean) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Returns a list of snapshots from repository sorted by snapshot creation date
- SnapshotShardFailure - Class in org.elasticsearch.snapshots
-
Stores information about failures that occurred during shard snapshotting process
- SnapshotShardFailure(String, String, int, String) - Constructor for class org.elasticsearch.snapshots.SnapshotShardFailure
-
Constructs new snapshot shard failure object
- snapshotShards(SnapshotId) - 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) - 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
- 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.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
-
- SnapshotsService.CreateSnapshotListener - Interface in org.elasticsearch.snapshots
-
Listener for create snapshot operation
- SnapshotsService.DeleteSnapshotListener - Interface in org.elasticsearch.snapshots
-
Listener for delete snapshot operation
- SnapshotsService.SnapshotCompletionListener - Interface in org.elasticsearch.snapshots
-
- SnapshotsService.SnapshotRequest - Class in org.elasticsearch.snapshots
-
Snapshot creation request
- 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 - 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, String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Constructs a new get snapshots request with given repository name and list of snapshots
- SnapshotsStatusRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Constructs a new get snapshots request with given repository name
- snapshotsStatusRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Get status 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 snapshotstatus 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
- SnapshotStatus - Class in org.elasticsearch.index.shard
-
- SnapshotStatus() - Constructor for class org.elasticsearch.index.shard.SnapshotStatus
-
- snapshotStatus(SnapshotId, Version, ShardId) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
Retrieve shard snapshot status for the stored snapshot
- snapshotStatus(SnapshotId, Version, ShardId) - Method in interface org.elasticsearch.index.snapshots.IndexShardRepository
-
Retrieve shard snapshot status for the stored snapshot
- SnapshotStatus.Index - Class in org.elasticsearch.index.shard
-
- SnapshotStatus.Stage - Enum in org.elasticsearch.index.shard
-
- SnapshotStatus.Translog - Class in org.elasticsearch.index.shard
-
- snapshotThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
- snapshotThrottleTimeInNanos() - Method in interface org.elasticsearch.repositories.Repository
-
Returns snapshot throttle time in nanoseconds
- SnapshotUtils - Class in org.elasticsearch.snapshots
-
Snapshot utilities
- SnapshotUtils() - Constructor for class org.elasticsearch.snapshots.SnapshotUtils
-
- Snippet - Class in org.apache.lucene.search.postingshighlight
-
Represents a scored highlighted snippet.
- Snippet(String, float, boolean) - Constructor for class org.apache.lucene.search.postingshighlight.Snippet
-
- SnowballAnalyzer - Class in org.elasticsearch.index.analysis
-
- SnowballAnalyzer(String) - Constructor for class org.elasticsearch.index.analysis.SnowballAnalyzer
-
Deprecated.
Builds the named analyzer with no stop words.
- SnowballAnalyzer(String, CharArraySet) - Constructor for class org.elasticsearch.index.analysis.SnowballAnalyzer
-
Deprecated.
Builds the named analyzer with the given stop words.
- SnowballAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
Creates a SnowballAnalyzer initialized with stopwords and Snowball filter.
- SnowballAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SnowballAnalyzerProvider
-
- SnowballTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
Real work actually done here by Sebastian on the Elasticsearch mailing list
http://elasticsearch-users.115913.n3.nabble.com/Using-the-Snowball-stemmers-tp2126106p2127111.html
- SnowballTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SnowballTokenFilterFactory
-
- SoraniAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
Provider for SoraniAnalyzer
- SoraniAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SoraniAnalyzerProvider
-
- SoraniNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
-
Factory for SoraniNormalizationFilter
- SoraniNormalizationFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SoraniNormalizationFilterFactory
-
- sort(Comparator<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
- sort(LongArrayList) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sort(long[], int) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sort(FloatArrayList) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sort(float[], int) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sort(DoubleArrayList) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sort(double[], int) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sort(ObjectArrayList<byte[]>) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sort(BytesRefArray, int[]) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sort() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
- sort() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
- sort() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
-
- sort(Sort) - Method in class org.elasticsearch.percolator.PercolateContext
-
- sort() - Method in class org.elasticsearch.percolator.PercolateContext
-
- sort(String, SortOrder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a sort against the given field name and the sort ordering.
- sort(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Add a sort against the given field name.
- sort(SortBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a sort builder.
- sort(Sort) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- sort() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- sort(Sort) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- sort() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- sort(Sort) - Method in class org.elasticsearch.search.internal.SearchContext
-
- sort() - Method in class org.elasticsearch.search.internal.SearchContext
-
- sort(Sort) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- sort() - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- sort() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- sort(Suggest.Suggestion.Sort) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- sort(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
Sets how to sort the suggest terms per suggest text token.
- sort(Comparator<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
-
- sort(String) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets how to sort the suggest terms per suggest text token.
- SORT_SCORE - Static variable in class org.elasticsearch.search.sort.SortParseElement
-
- sortableLongBitsToDoubles(SortedNumericDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Given a
SortedNumericDocValues
, return a
SortedNumericDoubleValues
instance that will translate long values to doubles using
NumericUtils.sortableLongToDouble(long)
.
- sortAddresses(List<InetAddress>) - Static method in class org.elasticsearch.common.network.NetworkUtils
-
- sortAndDedup(LongArrayList) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sortAndDedup(long[], int) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
Sort and deduplicate values in-place, then return the unique element count.
- sortAndDedup(FloatArrayList) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sortAndDedup(float[], int) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
Sort and deduplicate values in-place, then return the unique element count.
- sortAndDedup(DoubleArrayList) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sortAndDedup(double[], int) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
Sort and deduplicate values in-place, then return the unique element count.
- sortAndDedup(ObjectArrayList<byte[]>) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- sortAndDedup(BytesRefArray, int[]) - Static method in enum org.elasticsearch.common.util.CollectionUtils
-
- SortBuilder - Class in org.elasticsearch.search.sort
-
- SortBuilder() - Constructor for class org.elasticsearch.search.sort.SortBuilder
-
- SortBuilders - Class in org.elasticsearch.search.sort
-
- SortBuilders() - Constructor for class org.elasticsearch.search.sort.SortBuilders
-
- sortByMasterLikelihood(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.elect.ElectMasterService
-
Returns the given nodes sorted by likelyhood of being elected as master, most likely first.
- sortComparator() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
- sortComparator() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
-
- sortDocs(boolean, AtomicArray<? extends QuerySearchResultProvider>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
-
- SortedBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
A list of per-document binary values, sorted
according to BytesRef.getUTF8SortedAsUnicodeComparator()
.
- SortedBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
- 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, MappedFieldType.Names, IndexNumericFieldData.NumericType, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
-
- SortedSetDVBytesAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- SortedSetDVOrdinalsIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
- SortedSetDVOrdinalsIndexFieldData(Index, IndexFieldDataCache, Settings, MappedFieldType.Names, CircuitBreakerService, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
-
- sortFieldType() - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
- SortingBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
- 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
-
- 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(String) - 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(String) - 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(String) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Defines which distance to use for sorting in the case a document contains multiple geo points.
- SortOrder - Enum in org.elasticsearch.search.sort
-
A sorting order.
- SortParseElement - Class in org.elasticsearch.search.sort
-
- SortParseElement() - Constructor for class org.elasticsearch.search.sort.SortParseElement
-
- SortParser - Interface in org.elasticsearch.search.sort
-
- sortValues(Object[]) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- sortValues() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- sortValues() - Method in interface org.elasticsearch.search.SearchHit
-
An array of the sort values used.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Parses repository definition.
- source(Map) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Parses repository definition.
- source(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Parses repository definition.
- source(byte[]) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Parses repository definition.
- source(byte[], int, int) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Parses repository definition.
- source(BytesReference) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Parses repository definition.
- source(BytesReference) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Sets the source for the request.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Parses snapshot definition.
- source(Map) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Parses snapshot definition.
- source(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Parses snapshot definition.
- source(byte[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Parses snapshot definition.
- source(byte[], int, int) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Parses snapshot definition.
- source(BytesReference) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Parses snapshot definition.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Parses restore definition
- source(Map) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Parses restore definition
- source(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Parses restore definition
- source(byte[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Parses restore definition
- source(byte[], int, int) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Parses restore definition
- source(BytesReference) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Parses restore definition
- source() - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateResponse
-
- source(BytesReference) - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateResponse
-
- source(String) - 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.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(byte[]) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(byte[], int, int) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(BytesReference) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
-
- source(String) - 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(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(XContentBuilder) - 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.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(String) - 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(Map) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(byte[]) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(byte[], int, int) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(BytesReference) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
-
- source() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The source to execute.
- source(QuerySourceBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
- source(Map) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The source to execute in the form of a map.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
- source(String) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The query source to validate.
- source(byte[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The source to validate.
- source(byte[], int, int) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The source to validate.
- source(BytesReference) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The source to validate.
- source() - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
The source to execute.
- source(QuerySourceBuilder) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
The source to execute.
- source(Map) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
The source to execute in the form of a map.
- source(XContentBuilder) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
- source(String) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
The source to execute.
- source(byte[]) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
The source to execute.
- source(byte[], int, int) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
The source to execute.
- source(BytesReference) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
- source() - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
The source to execute.
- source(QuerySourceBuilder) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
The source to execute.
- source(Map) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
The source to execute in the form of a map.
- source(XContentBuilder) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
- source(String) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
The source to execute.
- source(byte[]) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
The source to execute.
- source(byte[], int, int) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
The source to execute.
- source(BytesReference) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
- source() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- source(QuerySourceBuilder) - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- source(BytesReference) - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- source(BytesReference) - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequest
-
- source() - Method in class org.elasticsearch.action.index.IndexRequest
-
The source of the document to index, recopied to a new array if it is unsage.
- source(Map) - Method in class org.elasticsearch.action.index.IndexRequest
-
- source(Map, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Index the Map as the provided content type.
- source(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document source to index.
- source(XContentBuilder) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the content source to index.
- source(String, Object) - Method in class org.elasticsearch.action.index.IndexRequest
-
- source(String, Object, String, Object) - Method in class org.elasticsearch.action.index.IndexRequest
-
- source(String, Object, String, Object, String, Object) - Method in class org.elasticsearch.action.index.IndexRequest
-
- source(String, Object, String, Object, String, Object, String, Object) - Method in class org.elasticsearch.action.index.IndexRequest
-
- source(Object...) - Method in class org.elasticsearch.action.index.IndexRequest
-
- source(BytesReference) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document to index in bytes form.
- source(byte[]) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document to index in bytes form.
- source(byte[], int, int) - 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() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
The source of the document to index, recopied to a new array if it is unsage.
- source(Map) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- source(Map, XContentType) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Index the Map as the provided content type.
- source(String) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets the document source to index.
- source(XContentBuilder) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets the content source to index.
- source(Object...) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- source(BytesReference) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets the document to index in bytes form.
- source(byte[]) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets the document to index in bytes form.
- source(byte[], int, int) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets the document to index in bytes form (assumed to be safe to be used from different
threads).
- source() - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- source(Map) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- source(Map, XContentType) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- source(String) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- source(XContentBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- source(byte[]) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- source(byte[], int, int) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- source(BytesReference) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- source(PercolateSourceBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
Sets the request body definition for this percolate request as raw bytes.
- source() - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
-
- source(SearchSourceBuilder) - Method in class org.elasticsearch.action.search.SearchRequest
-
The source of the search request.
- source(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
The source of the search request.
- source(Map) - Method in class org.elasticsearch.action.search.SearchRequest
-
The source of the search request in the form of a map.
- source(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequest
-
- source(byte[]) - Method in class org.elasticsearch.action.search.SearchRequest
-
The search source to execute.
- source(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequest
-
The search source to execute.
- source(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequest
-
The search source to execute.
- source() - Method in class org.elasticsearch.action.search.SearchRequest
-
The search source to execute.
- source(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- source(byte[]) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- source(byte[], int, int) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- source(BytesReference) - Method in class org.elasticsearch.action.update.UpdateRequest
-
- 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.index.engine.Engine.DeleteByQuery
-
- source() - Method in class org.elasticsearch.index.engine.Engine.GetResult
-
- source() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- source() - Method in class org.elasticsearch.index.engine.Engine.Searcher
-
The source that caused this searcher to be acquired.
- source - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
-
- 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.ParseContext.InternalParseContext
-
- source(BytesReference) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- source() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- source(BytesReference) - Method in class org.elasticsearch.index.mapper.ParseContext
-
- source() - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- source(XContentParser) - Static method in class org.elasticsearch.index.mapper.SourceToParse
-
- source(BytesReference) - Static method in class org.elasticsearch.index.mapper.SourceToParse
-
- source(SourceToParse.Origin, BytesReference) - Static method in class org.elasticsearch.index.mapper.SourceToParse
-
- source() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- source() - Method in class org.elasticsearch.index.translog.Translog.Create
-
- source() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
-
Deprecated.
- source() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- Source(BytesReference, String, String, long, long) - Constructor for class org.elasticsearch.index.translog.Translog.Source
-
- source - Variable in class org.elasticsearch.index.translog.Translog.Source
-
- source() - Method in class org.elasticsearch.percolator.PercolateContext
-
- source() - Method in class org.elasticsearch.script.AbstractSearchScript
-
Allows to access the actual source (loaded and parsed).
- source() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- source() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- source() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- source() - Method in class org.elasticsearch.search.internal.SearchContext
-
- source() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- source(BytesReference) - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- source() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
- source(BytesReference) - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
- source() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
-
- source(BytesReference) - 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() - Method in interface org.elasticsearch.search.SearchHit
-
The source of the document (can be null).
- source() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
-
- 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.action.indexedscripts.put.PutIndexedScriptRequest
-
- 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() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- sourceAsMap(BytesReference) - Static method in class org.elasticsearch.search.lookup.SourceLookup
-
- sourceAsMap() - Method in interface org.elasticsearch.search.SearchHit
-
The source of the document as a map (can be null).
- 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).
- sourceAsString() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- sourceAsString() - Method in interface org.elasticsearch.search.SearchHit
-
The source of the document as string (can be null).
- sourceBuilder - Variable in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- sourceBuilder() - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- sourceContentType() - Method in class org.elasticsearch.search.lookup.SourceLookup
-
- SourceFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
- SourceFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- SourceFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- SourceFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- sourceLatitude - Variable in class org.elasticsearch.common.geo.GeoDistance.FixedSourceDistanceBase
-
- sourceLongitude - Variable in class org.elasticsearch.common.geo.GeoDistance.FixedSourceDistanceBase
-
- 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.RecoveryStatus
-
- sourceNode() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
- 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() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
Returns bytes reference, also un compress the source if needed.
- sourceRef(BytesReference) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
Sets representation, might be compressed....
- sourceRef() - Method in interface org.elasticsearch.search.SearchHit
-
Returns bytes reference, also un compress the source if needed.
- sourceRequested() - Method in class org.elasticsearch.percolator.PercolateContext
-
- sourceRequested() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
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.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
-
- SourceScoreOrderFragmentsBuilder - Class in org.elasticsearch.search.highlight.vectorhighlight
-
- SourceScoreOrderFragmentsBuilder(FieldMapper, SearchContext, FetchSubPhase.HitContext, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.highlight.vectorhighlight.SourceScoreOrderFragmentsBuilder
-
- SourceSimpleFragmentsBuilder - Class in org.elasticsearch.search.highlight.vectorhighlight
-
- SourceSimpleFragmentsBuilder(FieldMapper, SearchContext, FetchSubPhase.HitContext, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.highlight.vectorhighlight.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.logging.Loggers
-
- spaceify(int, String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
-
- spanContainingQuery() - 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() - Constructor for class org.elasticsearch.index.query.SpanContainingQueryBuilder
-
- SpanContainingQueryParser - Class in org.elasticsearch.index.query
-
Parser for SpanContainingQuery
- SpanContainingQueryParser() - Constructor for class org.elasticsearch.index.query.SpanContainingQueryParser
-
- spanFirstQuery(SpanQueryBuilder, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- SpanFirstQueryBuilder - Class in org.elasticsearch.index.query
-
- SpanFirstQueryBuilder(SpanQueryBuilder, int) - Constructor for class org.elasticsearch.index.query.SpanFirstQueryBuilder
-
- SpanFirstQueryParser - Class in org.elasticsearch.index.query
-
- SpanFirstQueryParser() - Constructor for class org.elasticsearch.index.query.SpanFirstQueryParser
-
- SpanishAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- SpanishAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SpanishAnalyzerProvider
-
- spanMultiTermQueryBuilder(MultiTermQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- SpanMultiTermQueryBuilder - Class in org.elasticsearch.index.query
-
- SpanMultiTermQueryBuilder(MultiTermQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
-
- SpanMultiTermQueryParser - Class in org.elasticsearch.index.query
-
- SpanMultiTermQueryParser() - Constructor for class org.elasticsearch.index.query.SpanMultiTermQueryParser
-
- spanNearQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- SpanNearQueryBuilder - Class in org.elasticsearch.index.query
-
- SpanNearQueryBuilder() - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder
-
- SpanNearQueryParser - Class in org.elasticsearch.index.query
-
- SpanNearQueryParser() - Constructor for class org.elasticsearch.index.query.SpanNearQueryParser
-
- spanNotQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- SpanNotQueryBuilder - Class in org.elasticsearch.index.query
-
- SpanNotQueryBuilder() - Constructor for class org.elasticsearch.index.query.SpanNotQueryBuilder
-
- SpanNotQueryParser - Class in org.elasticsearch.index.query
-
- SpanNotQueryParser() - Constructor for class org.elasticsearch.index.query.SpanNotQueryParser
-
- spanOrQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- SpanOrQueryBuilder - Class in org.elasticsearch.index.query
-
- SpanOrQueryBuilder() - Constructor for class org.elasticsearch.index.query.SpanOrQueryBuilder
-
- SpanOrQueryParser - Class in org.elasticsearch.index.query
-
- SpanOrQueryParser() - Constructor for class org.elasticsearch.index.query.SpanOrQueryParser
-
- SpanQueryBuilder - Class in org.elasticsearch.index.query
-
- SpanQueryBuilder() - Constructor for class org.elasticsearch.index.query.SpanQueryBuilder
-
- spanTermQuery(String, String) - 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, float) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- spanTermQuery(String, double) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
- SpanTermQueryBuilder - Class in org.elasticsearch.index.query
-
- SpanTermQueryBuilder(String, String) - 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, float) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
-
- SpanTermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
-
- SpanTermQueryParser - Class in org.elasticsearch.index.query
-
- SpanTermQueryParser() - Constructor for class org.elasticsearch.index.query.SpanTermQueryParser
-
- spanWithinQuery() - 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() - Constructor for class org.elasticsearch.index.query.SpanWithinQueryBuilder
-
- SpanWithinQueryParser - Class in org.elasticsearch.index.query
-
Parser for SpanWithinQuery
- SpanWithinQueryParser() - Constructor for class org.elasticsearch.index.query.SpanWithinQueryParser
-
- spare - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- SPATIAL4J_AVAILABLE - Static variable in class org.elasticsearch.common.geo.ShapesAvailability
-
- SPATIAL_CONTEXT - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- 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.
- spins - Variable in class org.elasticsearch.env.NodeEnvironment.NodePath
-
Cached result of Lucene's IOUtils.spins
on path.
- split(String, String) - Static method in class org.elasticsearch.common.Strings
-
Split a String at the first occurrence of the delimiter.
- splitArrayElementsIntoProperties(String[], String, String) - Static method in class org.elasticsearch.common.Strings
-
Take an array Strings and split each element based on the given delimiter.
- splitScrollIds(String) - Static method in class org.elasticsearch.rest.action.search.RestClearScrollAction
-
- 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
-
- splitStringByCommaToSet(String) - Static method in class org.elasticsearch.common.Strings
-
- splitStringToArray(CharSequence, char) - Static method in class org.elasticsearch.common.Strings
-
- splitStringToSet(String, char) - Static method in class org.elasticsearch.common.Strings
-
- splitUidIntoTypeAndId(BytesRef) - Static method in class org.elasticsearch.index.mapper.Uid
-
- sqrt(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- sqrt(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- sqrt(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- sqrt(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- sqrt(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- stackTrace(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
- StackTraceElements - Class in org.elasticsearch.common.inject.internal
-
Creates stack trace elements for members.
- StackTraceElements() - Constructor for class org.elasticsearch.common.inject.internal.StackTraceElements
-
- Stage - Enum in org.elasticsearch.common.inject
-
The stage we're running in.
- stage() - Method in class org.elasticsearch.index.shard.SnapshotStatus
-
- stage() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns current snapshot stage
- stage() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- 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(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardAnalyzerProvider
-
- StandardAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardAnalyzerProvider
-
- StandardHtmlStripAnalyzer - Class in org.elasticsearch.index.analysis
-
- StandardHtmlStripAnalyzer() - Constructor for class org.elasticsearch.index.analysis.StandardHtmlStripAnalyzer
-
- StandardHtmlStripAnalyzer(CharArraySet) - Constructor for class org.elasticsearch.index.analysis.StandardHtmlStripAnalyzer
-
- StandardHtmlStripAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- StandardHtmlStripAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardHtmlStripAnalyzerProvider
-
- StandardTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- StandardTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardTokenFilterFactory
-
- StandardTokenizerFactory - Class in org.elasticsearch.index.analysis
-
- StandardTokenizerFactory(Index, IndexSettingsService, 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(String) - Method in class org.elasticsearch.common.StopWatch
-
Start a named task.
- start(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
-
- 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.transport.netty.NettyTransport.NodeChannels
-
- START_RECOVERY - Static variable in class org.elasticsearch.indices.recovery.RecoverySource.Actions
-
- startAccumulatingJoins() - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
Accumulates any future incoming join request.
- startArray(String, XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startArray(String) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startArray(XContentBuilderString) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startArray() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startConstruction() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
-
- started(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Mark a shard as started and adjusts internal statistics.
- 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.
- StartedRerouteAllocation - Class in org.elasticsearch.cluster.routing.allocation
-
- StartedRerouteAllocation(AllocationDeciders, RoutingNodes, DiscoveryNodes, List<? extends ShardRouting>, ClusterInfo) - Constructor for class org.elasticsearch.cluster.routing.allocation.StartedRerouteAllocation
-
- startedShards() - Method in class org.elasticsearch.cluster.routing.allocation.StartedRerouteAllocation
-
Get started shards
- startHeaders() - Method in class org.elasticsearch.common.Table
-
- startInitialJoin() - Method in interface org.elasticsearch.discovery.Discovery
-
Triggers the first join cycle
- startInitialJoin() - Method in class org.elasticsearch.discovery.local.LocalDiscovery
-
- startInitialJoin() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
- startNanoTime - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
- startObject(String) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startObject(String, XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startObject(XContentBuilderString) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startObject(XContentBuilderString, XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startObject() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- startOffset() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
-
- startOffset - Variable in class org.elasticsearch.search.lookup.TermPosition
-
- startRecovery(IndexShard, DiscoveryNode, RecoveryTarget.RecoveryListener, TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
Starts are new recovery for the given shard, source node and state
- startRecovery(IndexShard, RecoveryState.Type, DiscoveryNode, RecoveryTarget.RecoveryListener) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
- StartRecoveryRequest - Class in org.elasticsearch.indices.recovery
-
- StartRecoveryRequest() - Constructor for class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
- StartRecoveryRequest(ShardId, DiscoveryNode, DiscoveryNode, boolean, Store.MetadataSnapshot, RecoveryState.Type, long) - Constructor for class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
Start recovery request.
- startRewriteTime() - Method in class org.elasticsearch.search.profile.Profiler
-
Begin timing the rewrite phase of a request.
- startRow() - Method in class org.elasticsearch.common.Table
-
- startTerm(BytesRef) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
-
- startTime() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- startTime() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
-
- startTime() - Method in class org.elasticsearch.index.engine.Engine.Delete
-
Returns operation start time in nanoseconds.
- startTime() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
-
Returns operation start time in nanoseconds.
- startTime() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
Returns operation start time in nanoseconds.
- startTime() - Method in interface org.elasticsearch.index.engine.Engine.Operation
-
- startTime() - Method in class org.elasticsearch.index.shard.SnapshotStatus.Index
-
- startTime(long) - Method in class org.elasticsearch.index.shard.SnapshotStatus.Index
-
- startTime() - Method in class org.elasticsearch.index.shard.SnapshotStatus
-
- startTime(long) - Method in class org.elasticsearch.index.shard.SnapshotStatus
-
- startTime() - Method in class org.elasticsearch.index.shard.SnapshotStatus.Translog
-
- startTime(long) - Method in class org.elasticsearch.index.shard.SnapshotStatus.Translog
-
- startTime() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot start time
- startTime() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns snapshot start time
- startTime(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Sets snapshot start time
- startTime - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
- startTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
Returns start time in millis
- startTime(ProfileBreakdown.TimingType) - Method in class org.elasticsearch.search.profile.ProfileBreakdown
-
Begin timing a query for a specific Timing context
- startTime() - Method in class org.elasticsearch.snapshots.Snapshot
-
Returns time when snapshot started
- startTime() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns time when snapshot started
- startVerification() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
- startVerification() - Method in interface org.elasticsearch.repositories.Repository
-
Verifies repository on the master node and returns the verification token.
- state(IndexMetaData.State) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
- state() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
- 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() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
The new cluster state that caused this change event.
- state() - Method in interface org.elasticsearch.cluster.ClusterService
-
The current state.
- state(IndexMetaData.State) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- 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.InternalClusterService
-
- 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 - Variable in class org.elasticsearch.index.shard.IndexShard
-
- state() - Method in class org.elasticsearch.index.shard.IndexShard
-
- state() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- state() - Method in class org.elasticsearch.snapshots.Snapshot
-
Returns current snapshot state
- state() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot state
- 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
-
- 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(String) - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- stateUUID() - Method in class org.elasticsearch.cluster.ClusterState
-
This stateUUID is automatically generated for for each version of cluster state.
- StaticInjectionRequest - Class in org.elasticsearch.common.inject.spi
-
A request to inject the static fields and methods of a type.
- 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() - Method in class org.elasticsearch.http.HttpServer
-
- stats() - Method in interface org.elasticsearch.http.HttpServerTransport
-
- stats() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- stats() - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
-
- stats(String...) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
-
- stats() - Method in class org.elasticsearch.index.get.ShardGetService
-
- Stats(long, long, long, long, long, long, long, long, boolean, long) - Constructor for class org.elasticsearch.index.indexing.IndexingStats.Stats
-
- stats(String...) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
Returns the stats, including type specific stats.
- stats(Terms, int) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- stats(Terms, int) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.DoubleFieldType
-
- stats(Terms, int) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- stats(Terms, int) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.LongFieldType
-
- stats(Terms, int) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- stats() - Method in class org.elasticsearch.index.percolator.stats.ShardPercolateService
-
- Stats(long, long, long, long, long, long, long, long, long) - Constructor for class org.elasticsearch.index.search.stats.SearchStats.Stats
-
- Stats(SearchStats.Stats) - Constructor for class org.elasticsearch.index.search.stats.SearchStats.Stats
-
- stats(String...) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
-
Returns the stats, including group specific stats.
- stats() - Method in class org.elasticsearch.index.store.Store
-
- stats() - Method in class org.elasticsearch.index.suggest.stats.ShardSuggestMetric
-
- 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(String) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
-
- stats() - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
-
- stats(String) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
-
- stats() - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
-
- stats(String) - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
-
- 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() - Method in class org.elasticsearch.monitor.fs.FsProbe
-
- 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.node.service.NodeService
-
- stats(CommonStatsFlags, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.node.service.NodeService
-
- stats() - Method in class org.elasticsearch.script.ScriptMetrics
-
- stats() - Method in class org.elasticsearch.script.ScriptService
-
- stats(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Stats
aggregation with the given name.
- Stats - Interface in org.elasticsearch.search.aggregations.metrics.stats
-
Statistics over a set of values (either aggregated over field data or scripts)
- stats(String...) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The stats groups this request will be aggregated under.
- stats(String...) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionTerms
-
- stats(String...) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.LookupFactory
-
- stats() - Method in class org.elasticsearch.threadpool.ThreadPool
-
- Stats(String, int, int, int, long, int, long) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
- stats() - Method in class org.elasticsearch.transport.TransportService
-
- StatsAggregator - Class in org.elasticsearch.search.aggregations.metrics.stats
-
- StatsAggregator(String, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsAggregator
-
- StatsAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.stats
-
- StatsBucket - Interface in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
-
Statistics over a set of buckets
- statsBucket(String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
-
- StatsBucketBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
-
- StatsBucketBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketBuilder
-
- StatsBucketParser - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
-
- StatsBucketParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketParser
-
- StatsBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
-
- StatsBucketPipelineAggregator(String, String[], BucketHelpers.GapPolicy, ValueFormatter, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
-
- StatsBucketPipelineAggregator.Factory - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats
-
- StatsBuilder - Class in org.elasticsearch.search.aggregations.metrics.stats
-
Builder for the
Stats
aggregation.
- StatsBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsBuilder
-
Sole constructor.
- StatsGroupsParseElement - Class in org.elasticsearch.index.search.stats
-
- StatsGroupsParseElement() - Constructor for class org.elasticsearch.index.search.stats.StatsGroupsParseElement
-
- StatsParser - Class in org.elasticsearch.search.aggregations.metrics.stats
-
- StatsParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsParser
-
- status() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- status() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- status() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
- status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
-
- 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.count.CountResponse
-
Deprecated.
- 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.search.ShardSearchFailure
-
- status() - Method in interface org.elasticsearch.action.ShardOperationFailedException
-
The status of the failure.
- status() - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
-
- Status(String) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask.Status
-
- Status(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask.Status
-
- status() - Method in exception org.elasticsearch.action.UnavailableShardsException
-
- 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 class org.elasticsearch.cluster.ClusterState
-
- status(ClusterState.ClusterStateStatus) - Method in class org.elasticsearch.cluster.ClusterState
-
- status() - Method in exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
-
- status() - Method in class org.elasticsearch.common.cli.CliTool.Command.Exit
-
- status() - Method in enum org.elasticsearch.common.cli.CliTool.ExitStatus
-
- status() - Method in exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
-
- status() - Method in exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
-
- status() - Method in interface org.elasticsearch.common.xcontent.StatusToXContent
-
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.ElasticsearchSecurityException
-
- status(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
- status() - Method in exception org.elasticsearch.index.engine.DocumentAlreadyExistsException
-
- 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.FlushNotAllowedEngineException
-
- 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.MergeMappingException
-
- status() - Method in exception org.elasticsearch.index.mapper.StrictDynamicMappingException
-
- status() - Method in exception org.elasticsearch.index.query.QueryParsingException
-
- status() - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
-
- status() - Method in exception org.elasticsearch.indices.IndexAlreadyExistsException
-
- status() - Method in exception org.elasticsearch.indices.IndexClosedException
-
- status() - Method in exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
-
- status() - Method in exception org.elasticsearch.indices.IndexTemplateAlreadyExistsException
-
- 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 class org.elasticsearch.indices.recovery.RecoveriesCollection.StatusRef
-
- 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.ResourceNotFoundException
-
- status() - Method in class org.elasticsearch.rest.BytesRestResponse
-
- status() - Method in class org.elasticsearch.rest.RestResponse
-
The rest status code.
- status(int, int, ShardOperationFailedException...) - Static method in enum org.elasticsearch.rest.RestStatus
-
- status() - Method in exception org.elasticsearch.script.groovy.GroovyScriptCompilationException
-
Deprecated.
- status() - Method in exception org.elasticsearch.script.groovy.GroovyScriptExecutionException
-
Deprecated.
- status() - Method in exception org.elasticsearch.search.SearchContextMissingException
-
- status() - Method in exception org.elasticsearch.search.SearchParseException
-
- status() - Method in exception org.elasticsearch.search.warmer.IndexWarmerMissingException
-
- 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.RestoreService.UpdateIndexShardRestoreStatusRequest
-
- status() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot REST status
- status() - Method in exception org.elasticsearch.snapshots.SnapshotMissingException
-
- status() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
Returns REST status corresponding to this failure
- status() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
-
- status() - Method in exception org.elasticsearch.transport.netty.SizeHeaderFrameDecoder.HttpOnTransportException
-
- StatusRef(RecoveryStatus) - Constructor for class org.elasticsearch.indices.recovery.RecoveriesCollection.StatusRef
-
- StatusToXContent - Interface in org.elasticsearch.common.xcontent
-
- StemmerOverrideTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- StemmerOverrideTokenFilterFactory(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StemmerOverrideTokenFilterFactory
-
- StemmerTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- StemmerTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StemmerTokenFilterFactory
-
- 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.metrics.MeterMetric
-
- stop() - Method in class org.elasticsearch.common.StopWatch
-
Stop the current task.
- stop(String) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
-
- stop() - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
-
stops all pinging
- stop() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
- stop() - Method in class org.elasticsearch.watcher.WatcherHandle
-
- STOP_WORDS - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryParser.Field
-
- stopAccumulatingJoins(String) - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
Stopped accumulating joins.
- StopAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- StopAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StopAnalyzerProvider
-
- stopAndAddRewriteTime() - Method in class org.elasticsearch.search.profile.Profiler
-
Stop recording the current rewrite and add it's time to the total tally, returning the
cumulative time so far.
- stopAndRecordTime() - Method in class org.elasticsearch.search.profile.ProfileBreakdown
-
Halt the timing process and save the elapsed time.
- stopAtNonOption(boolean) - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd.Builder
-
- stopped() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns true if the state is stopped.
- 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(Index, IndexSettingsService, 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(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Set the set of stopwords.
- 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 - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- store(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- store() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- store - Variable in class org.elasticsearch.index.engine.Engine
-
- store(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- store(boolean) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
-
- store() - Method in class org.elasticsearch.index.shard.IndexShard
-
- Store - Class in org.elasticsearch.index.store
-
A Store provides plain access to files written by an elasticsearch index shard.
- Store(ShardId, Settings, DirectoryService, ShardLock) - Constructor for class org.elasticsearch.index.store.Store
-
- Store(ShardId, IndexSettingsService, DirectoryService, ShardLock, Store.OnClose) - Constructor for class org.elasticsearch.index.store.Store
-
- Store(ShardId, Settings, DirectoryService, ShardLock, Store.OnClose) - Constructor for class org.elasticsearch.index.store.Store
-
- store() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
-
- Store.LegacyChecksums - Class in org.elasticsearch.index.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
- STORE_TYPE - Static variable in class org.elasticsearch.index.store.IndexStoreModule
-
- storeException() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
-
- StoreFileMetaData - Class in org.elasticsearch.index.store
-
- StoreFileMetaData(String, long) - Constructor for class org.elasticsearch.index.store.StoreFileMetaData
-
- StoreFileMetaData(String, long, String) - Constructor for class org.elasticsearch.index.store.StoreFileMetaData
-
- 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
-
- storeFilesMetaData() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
-
- StoreFilesMetaData(boolean, ShardId, Store.MetadataSnapshot) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
-
- StoreModule - Class in org.elasticsearch.index.store
-
- StoreModule(Class<? extends DirectoryService>, ShardLock, Store.OnClose, ShardPath) - Constructor for class org.elasticsearch.index.store.StoreModule
-
- StoreRateLimiting - Class in org.apache.lucene.store
-
- StoreRateLimiting() - Constructor for class org.apache.lucene.store.StoreRateLimiting
-
- StoreRateLimiting.Listener - Interface in org.apache.lucene.store
-
- StoreRateLimiting.Provider - Interface in org.apache.lucene.store
-
- StoreRateLimiting.Type - Enum in org.apache.lucene.store
-
- StoreRecoveryService - Class in org.elasticsearch.index.shard
-
- StoreRecoveryService(ShardId, IndexSettingsService, ThreadPool, MappingUpdatedAction, ClusterService, RepositoriesService, RestoreService) - Constructor for class org.elasticsearch.index.shard.StoreRecoveryService
-
- StoreRecoveryService.RecoveryListener - Interface in org.elasticsearch.index.shard
-
- storeStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
- StoreStats - Class in org.elasticsearch.index.store
-
- StoreStats() - Constructor for class org.elasticsearch.index.store.StoreStats
-
- StoreStats(long, long) - Constructor for class org.elasticsearch.index.store.StoreStats
-
- StoreStatus(DiscoveryNode, long, IndicesShardStoresResponse.StoreStatus.Allocation, Throwable) - 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
-
- StoreUtils - Class in org.apache.lucene.store
-
- STRATEGY - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
-
- STRATEGY - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
-
- strategy(SpatialStrategy) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Defines which spatial strategy will be used for building the geo shape filter.
- STRATEGY_POINTS_ONLY - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
-
- strategyName() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- stream(BytesReference) - Static method in class org.elasticsearch.search.aggregations.AggregationStreams
-
Returns the stream that is registered for the given type
- stream(BytesReference) - Static method in class org.elasticsearch.search.aggregations.bucket.BucketStreams
-
Returns the stream that is registered for the given type
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.children.InternalChildren
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
- stream() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.Type
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.InternalExtendedStatsBucket
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorPipelineAggregator
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.EwmaModel
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltLinearModel
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.HoltWintersModel
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.LinearModel
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.models.SimpleModel
-
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
-
- stream(BytesReference) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorStreams
-
Returns the stream that is registered for the given type
- STREAM - Static variable in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
-
- Streamable - Interface in org.elasticsearch.common.io.stream
-
- StreamableReader<T> - Interface in org.elasticsearch.common.io.stream
-
- streamContext() - Static method in class org.elasticsearch.search.internal.InternalSearchHits
-
- StreamContext() - Constructor for class org.elasticsearch.search.internal.InternalSearchHits.StreamContext
-
- streamInput() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- streamInput() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
A stream input of the bytes.
- streamInput() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- streamInput() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- streamInput(StreamInput) - Method in interface org.elasticsearch.common.compress.Compressor
-
- streamInput(StreamInput) - Method in class org.elasticsearch.common.compress.deflate.DeflateCompressor
-
- streamInput(StreamInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
-
Deprecated.
- StreamInput - Class in org.elasticsearch.common.io.stream
-
- StreamInput() - Constructor for class org.elasticsearch.common.io.stream.StreamInput
-
- StreamInputReader<T> - Interface in org.elasticsearch.common.io.stream
-
Defines a method for reading a list of objects from StreamInput.
- streamOutput(StreamOutput) - Method in interface org.elasticsearch.common.compress.Compressor
-
- streamOutput(StreamOutput) - Method in class org.elasticsearch.common.compress.deflate.DeflateCompressor
-
- streamOutput(StreamOutput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
-
Deprecated.
- StreamOutput - Class in org.elasticsearch.common.io.stream
-
- 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
-
- streamSeparator() - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- streamSeparator() - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- streamSeparator() - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- streamSeparator() - Method in interface org.elasticsearch.common.xcontent.XContent
-
- streamSeparator() - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- streamShardTarget() - Method in class org.elasticsearch.search.internal.InternalSearchHits.StreamContext
-
- streamShardTarget(InternalSearchHits.StreamContext.ShardTargetType) - Method in class org.elasticsearch.search.internal.InternalSearchHits.StreamContext
-
- STRICT - Static variable in class org.elasticsearch.common.ParseFieldMatcher
-
- 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
-
- 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() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
Returns a string representation of the builder (only applicable for text based xcontent).
- STRING_DISTANCE - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
-
- stringBuilder() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
A string builder that can be used to construct complex names for example.
- stringBuilder() - Method in class org.elasticsearch.index.mapper.ParseContext
-
A string builder that can be used to construct complex names for example.
- stringDistance() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- stringDistance(StringDistance) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- stringDistance - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
-
- stringDistance(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
Sets what string distance implementation to use for comparing how
similar suggested terms are.
- stringDistance(String) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets what string distance implementation to use for comparing how similar
suggested terms are.
- stringField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
-
- stringField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- StringFieldMapper - Class in org.elasticsearch.index.mapper.core
-
- StringFieldMapper(String, MappedFieldType, MappedFieldType, int, int, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper
-
- StringFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
-
- StringFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
-
- StringFieldMapper.StringFieldType - Class in org.elasticsearch.index.mapper.core
-
- StringFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
-
- StringFieldMapper.ValueAndBoost - Class in org.elasticsearch.index.mapper.core
-
- StringFieldType() - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.StringFieldType
-
- StringFieldType(StringFieldMapper.StringFieldType) - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.StringFieldType
-
- StringFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.support.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
-
- StringTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
- StringTerms(String, Terms.Order, int, int, long, List<? extends InternalTerms.Bucket>, boolean, long, long, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
-
- 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, Terms.Order, TermsAggregator.BucketCountThresholds, IncludeExclude.StringFilter, AggregationContext, 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.common.lucene.all.AllField
-
- stringValue() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
-
- stringValue() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
-
- StupidBackoff(double) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.StupidBackoff
-
Creates a Stupid-Backoff smoothing model.
- StupidBackoffScorer - Class in org.elasticsearch.search.suggest.phrase
-
- StupidBackoffScorer(IndexReader, Terms, String, double, BytesRef, double) - Constructor for class org.elasticsearch.search.suggest.phrase.StupidBackoffScorer
-
- subAggregation(AbstractAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Add a sub get to this bucket get.
- subAggregation(byte[]) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Sets a raw (xcontent / json) sub addAggregation.
- subAggregation(byte[], int, int) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Sets a raw (xcontent / json) sub addAggregation.
- subAggregation(BytesReference) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Sets a raw (xcontent / json) sub addAggregation.
- subAggregation(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Sets a raw (xcontent / json) sub addAggregation.
- subAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Sets a raw (xcontent / json) sub addAggregation.
- SubAggregationComparator(String, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket.SubAggregationComparator
-
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Return the sub aggregator with the provided name.
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
-
- 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).
- subFactories(AggregatorFactories) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Registers sub-factories with this factory.
- subFactories(AggregatorFactories) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator.Factory
-
- subFactories(AggregatorFactories) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory.LeafOnly
-
- submitRequest(DiscoveryNode, String, TransportRequest, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
-
- submitRequest(DiscoveryNode, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
-
- SubmitReschedulingClusterInfoUpdatedJob() - Constructor for class org.elasticsearch.cluster.InternalClusterInfoService.SubmitReschedulingClusterInfoUpdatedJob
-
- submitStateUpdateTask(String, T, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>, ClusterStateTaskListener) - Method in interface org.elasticsearch.cluster.ClusterService
-
Submits a cluster state update task; submitted updates will be
batched across the same instance of executor.
- submitStateUpdateTask(String, ClusterStateUpdateTask) - Method in interface org.elasticsearch.cluster.ClusterService
-
- submitStateUpdateTask(String, ClusterStateUpdateTask) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- submitStateUpdateTask(String, T, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>, ClusterStateTaskListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
-
- subOne(long) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- subPath(int, int) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
- subRequests() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
- subRequests() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- subRequests() - Method in interface org.elasticsearch.action.CompositeIndicesRequest
-
Returns the subrequests that a composite request is composed of
- subRequests() - Method in class org.elasticsearch.action.get.MultiGetRequest
-
- subRequests() - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
- subRequests() - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- subRequests() - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
- subRequests() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
-
- 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.io.FastStringReader
-
- subsetSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
- 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(T) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.BatchResult.Builder
-
- success() - Static method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
-
- success() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
-
- successes(Iterable<T>) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.BatchResult.Builder
-
- 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.Snapshot
-
Returns total number of shards that were successfully snapshotted
- successfulShards() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns total number of shards that were successfully snapshotted
- suggest - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- suggest(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- suggest() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- suggest() - Method in class org.elasticsearch.action.suggest.ShardSuggestRequest
-
- suggest() - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
The Phrase to get correction suggestions for
- suggest(BytesReference) - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
set a new source for the suggest query
- suggest(SuggestBuilder) - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
set a new source using a
SuggestBuilder
for phrase and term suggestion lookup
- suggest(SuggestBuilder.SuggestionBuilder) - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
- suggest(String) - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
- suggest(SuggestRequest) - Method in interface org.elasticsearch.client.Client
-
Suggestion matching a specific phrase.
- suggest(SuggestRequest, ActionListener<SuggestResponse>) - Method in interface org.elasticsearch.client.Client
-
Suggestions matching a specific phrase.
- suggest(SuggestRequest) - Method in class org.elasticsearch.client.support.AbstractClient
-
- suggest(SuggestRequest, ActionListener<SuggestResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
-
- suggest() - Method in class org.elasticsearch.percolator.PercolateContext
-
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.percolator.PercolateContext
-
- suggest() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
- suggest() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- suggest() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- suggest() - Method in class org.elasticsearch.search.internal.InternalSearchResponse
-
- suggest() - Method in class org.elasticsearch.search.internal.SearchContext
-
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.SearchContext
-
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- suggest() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- suggest(Suggest) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- Suggest - Class in org.elasticsearch.search.suggest
-
Top level suggest result, containing the result for each suggestion.
- Suggest() - Constructor for class org.elasticsearch.search.suggest.Suggest
-
- Suggest(XContentBuilderString) - Constructor for class org.elasticsearch.search.suggest.Suggest
-
- Suggest(List<Suggest.Suggestion<? extends Suggest.Suggestion.Entry<? extends Suggest.Suggestion.Entry.Option>>>) - Constructor for class org.elasticsearch.search.suggest.Suggest
-
- Suggest(XContentBuilderString, List<Suggest.Suggestion<? extends Suggest.Suggestion.Entry<? extends Suggest.Suggestion.Entry.Option>>>) - Constructor for class org.elasticsearch.search.suggest.Suggest
-
- SUGGEST - Static variable in class org.elasticsearch.search.suggest.Suggest.Fields
-
- SUGGEST - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
- Suggest.Fields - Class in org.elasticsearch.search.suggest
-
- 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.
- Suggest.Suggestion.Sort - Enum in org.elasticsearch.search.suggest
-
- SUGGEST_CODEC_VERSION - Static variable in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
-
- SUGGEST_MODE - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
-
- SUGGEST_VERSION_CURRENT - Static variable in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
-
- SuggestAction - Class in org.elasticsearch.action.suggest
-
- SuggestBuilder - Class in org.elasticsearch.search.suggest
-
Defines how to perform suggesting.
- SuggestBuilder() - Constructor for class org.elasticsearch.search.suggest.SuggestBuilder
-
- SuggestBuilder(String) - Constructor for class org.elasticsearch.search.suggest.SuggestBuilder
-
- SuggestBuilder.SuggestionBuilder<T> - Class in org.elasticsearch.search.suggest
-
- SuggestBuilders - Class in org.elasticsearch.search.suggest
-
A static factory for building suggester lookup queries
- SuggestBuilders() - Constructor for class org.elasticsearch.search.suggest.SuggestBuilders
-
- SuggestContextParser - Interface in org.elasticsearch.search.suggest
-
- Suggester<T extends SuggestionSearchContext.SuggestionContext> - Class in org.elasticsearch.search.suggest
-
- Suggester() - Constructor for class org.elasticsearch.search.suggest.Suggester
-
- Suggesters - Class in org.elasticsearch.search.suggest
-
- Suggesters() - Constructor for class org.elasticsearch.search.suggest.Suggesters
-
- Suggesters(Map<String, Suggester>) - Constructor for class org.elasticsearch.search.suggest.Suggesters
-
- Suggesters(Map<String, Suggester>, ScriptService) - Constructor for class org.elasticsearch.search.suggest.Suggesters
-
- Suggestion() - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion
-
- Suggestion(String, int) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion
-
- SuggestionBuilder(String, String) - Constructor for class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
- SuggestionContext(Suggester) - 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(SuggestMode) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
-
- suggestMode(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
The global suggest mode controls what suggested terms are included or
controls for what suggest text tokens, terms should be suggested for.
- suggestMode(String) - 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.
- SuggestParseElement - Class in org.elasticsearch.search.suggest
-
- SuggestParseElement(Suggesters) - Constructor for class org.elasticsearch.search.suggest.SuggestParseElement
-
- SuggestPhase - Class in org.elasticsearch.search.suggest
-
- SuggestPhase(Settings, SuggestParseElement) - Constructor for class org.elasticsearch.search.suggest.SuggestPhase
-
- SuggestRequest - Class in org.elasticsearch.action.suggest
-
A request to get suggestions for corrections of phrases.
- SuggestRequest() - Constructor for class org.elasticsearch.action.suggest.SuggestRequest
-
- SuggestRequest(String...) - Constructor for class org.elasticsearch.action.suggest.SuggestRequest
-
Constructs a new suggest request against the provided indices.
- suggestRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a suggest request for getting suggestions from provided indices
.
- SuggestRequestBuilder - Class in org.elasticsearch.action.suggest
-
A suggest action request builder.
- SuggestRequestBuilder(ElasticsearchClient, SuggestAction) - Constructor for class org.elasticsearch.action.suggest.SuggestRequestBuilder
-
- SuggestResponse - Class in org.elasticsearch.action.suggest
-
The response of the suggest action.
- suggestShardSideQueueSize(int, 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.
- suggestStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
- SuggestStats - Class in org.elasticsearch.index.suggest.stats
-
Exposes suggest related statistics.
- SuggestStats() - Constructor for class org.elasticsearch.index.suggest.stats.SuggestStats
-
- SuggestUtils - Class in org.elasticsearch.search.suggest
-
- SuggestUtils.Fields - Class in org.elasticsearch.search.suggest
-
- SuggestUtils.TokenConsumer - Class in org.elasticsearch.search.suggest
-
- sum() - Method in class org.elasticsearch.common.metrics.MeanMetric
-
- sum(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Sum
aggregation with the given name.
- sum - Variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- Sum - Interface in org.elasticsearch.search.aggregations.metrics.sum
-
An aggregation that computes the sum of the values in the current bucket.
- SUM_OF_OTHER_DOC_COUNTS - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
- SumAggregator - Class in org.elasticsearch.search.aggregations.metrics.sum
-
- SumAggregator(String, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
-
- SumAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.sum
-
- sumBucket(String) - Static method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorBuilders
-
- SumBucketBuilder - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum
-
- SumBucketBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketBuilder
-
- SumBucketParser - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum
-
- SumBucketParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketParser
-
- SumBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum
-
- SumBucketPipelineAggregator(String, String[], BucketHelpers.GapPolicy, ValueFormatter, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
-
- SumBucketPipelineAggregator.Factory - Class in org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum
-
- SumBuilder - Class in org.elasticsearch.search.aggregations.metrics.sum
-
Builder for the
Sum
aggregation.
- SumBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumBuilder
-
Sole constructor.
- sumdf() - Method in class org.elasticsearch.search.lookup.IndexField
-
- SumParser - Class in org.elasticsearch.search.aggregations.metrics.sum
-
- SumParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumParser
-
- sumttf() - Method in class org.elasticsearch.search.lookup.IndexField
-
- supersetSize - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
-
- supertypeOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type that represents an unknown supertype of bound
.
- SUPPORTED_PROTOCOLS_SETTING - Static variable in class org.elasticsearch.repositories.uri.URLRepository
-
- SUPPORTS_V6 - Static variable in class org.elasticsearch.common.network.NetworkUtils
-
- supportsRawWrites() - Method in class org.elasticsearch.common.xcontent.cbor.CborXContentGenerator
-
- supportsRawWrites() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
-
Whether this generator supports writing raw data directly
- supportsRawWrites() - Method in class org.elasticsearch.common.xcontent.smile.SmileXContentGenerator
-
- supportsRawWrites() - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContentGenerator
-
- SuppressForbidden - Annotation Type in org.elasticsearch.common
-
Annotation to suppress forbidden-apis errors inside a whole class, a method, or a field.
- SURVIVOR - Static variable in class org.elasticsearch.monitor.jvm.GcNames
-
- suspendEncoding() - Method in class org.elasticsearch.common.Base64.OutputStream
-
Suspends encoding of the stream.
- Swap() - Constructor for class org.elasticsearch.monitor.os.OsStats.Swap
-
- swapPrimaryFlag(ShardRouting...) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
swaps the status of a shard, making replicas primary and vice versa.
- SwedishAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- SwedishAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SwedishAnalyzerProvider
-
- switchDoc(ParseContext.Document) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Return a new context that has the provided document as the current document.
- sync(Translog.Location) - Method in class org.elasticsearch.index.shard.IndexShard
-
Syncs the given location with the underlying storage unless already synced.
- sync() - Method in class org.elasticsearch.index.translog.BufferingTranslogWriter
-
- 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_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 - Class in org.elasticsearch.action.admin.indices.flush
-
A synced flush request to sync flush one or more indices.
- SyncedFlushRequest() - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequest
-
- SyncedFlushRequest(ActionRequest) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequest
-
Copy constructor that creates a new synced flush request that is a copy of the one provided as an argument.
- SyncedFlushRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequest
-
Constructs a new synced flush request against one or more indices.
- syncedFlushRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a synced flush indices request.
- 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(Settings, 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.ShadowEngine
-
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.shard.IndexShard
-
- 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.BufferingTranslogWriter
-
- syncNeeded() - Method in class org.elasticsearch.index.translog.Translog
-
- syncNeeded() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
returns true if there are buffered ops
- syncUpTo(long) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Syncs the translog up to at least the given offset unless already synced
- SynonymTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- SynonymTokenFilterFactory(Index, IndexSettingsService, Environment, IndicesAnalysisService, Map<String, TokenizerFactoryFactory>, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
-
- SYSTEM_ERR - Static variable in class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
- SYSTEM_OUT - Static variable in class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
- Table - Class in org.elasticsearch.common
-
- Table() - Constructor for class org.elasticsearch.common.Table
-
- Table.Cell - Class in org.elasticsearch.common
-
- tagsSchema(String) - Method in class org.elasticsearch.search.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
-
- tan(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- tan(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- tan(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- tan(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- tan(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- tanh(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- target - Variable in class org.elasticsearch.common.logging.log4j.ConsoleAppender
-
- targetNode() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
- targetThrottling() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
- targetValueType(ValueType) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser.Builder
-
- 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) - Constructor for class org.elasticsearch.tasks.Task
-
- Task(long, String, String, String, TaskId) - Constructor for class org.elasticsearch.tasks.Task
-
- Task(long, String, String, String, TaskId, long, long) - Constructor for class org.elasticsearch.tasks.Task
-
- Task.Status - Interface in org.elasticsearch.tasks
-
- taskCount() - Method in class org.elasticsearch.common.StopWatch
-
Return the number of tasks timed.
- TaskId - Class in org.elasticsearch.tasks
-
Task id that consists of node id and id of the task on the node
- TaskId(String, long) - Constructor for class org.elasticsearch.tasks.TaskId
-
- TaskId(String) - Constructor for class org.elasticsearch.tasks.TaskId
-
- TaskId(StreamInput) - Constructor for class org.elasticsearch.tasks.TaskId
-
- TaskInfo - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
Information about a currently running task.
- TaskInfo(DiscoveryNode, long, String, String, String, Task.Status, long, long, TaskId) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- TaskInfo(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- taskInfo() - Method in class org.elasticsearch.common.StopWatch
-
Return an array of the data for tasks performed.
- taskInfo(DiscoveryNode, 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.
- TaskListener<Response> - Interface in org.elasticsearch.tasks
-
Listener for Task success or failure.
- taskManager - Variable in class org.elasticsearch.action.support.TransportAction
-
- TaskManager - Class in org.elasticsearch.tasks
-
Task Manager service for keeping track of currently running tasks on the nodes
- TaskManager(Settings) - Constructor for class org.elasticsearch.tasks.TaskManager
-
- taskManager - Variable in class org.elasticsearch.transport.TransportService
-
- taskOperation(CancelTasksRequest, CancellableTask) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
-
- taskOperation(ListTasksRequest, Task) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
-
- taskOperation(TasksRequest, OperationTask) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
- TaskOperationFailure - Class in org.elasticsearch.action
-
Information about task operation failures
The class is final due to serialization limitations
- TaskOperationFailure(StreamInput) - Constructor for class org.elasticsearch.action.TaskOperationFailure
-
- TaskOperationFailure(String, long, Throwable) - Constructor for class org.elasticsearch.action.TaskOperationFailure
-
- 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
-
- tb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- tbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
- TCP_BLOCKING - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_BLOCKING_CLIENT - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_BLOCKING_SERVER - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_CONNECT_TIMEOUT - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_DEFAULT_CONNECT_TIMEOUT - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_DEFAULT_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_DEFAULT_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_KEEP_ALIVE - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_NO_DELAY - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_REUSE_ADDRESS - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TCP_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- tcpKeepAlive - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- tcpNoDelay - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- tcpReceiveBufferSize - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- tcpSendBufferSize - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
-
- TcpSettings() - Constructor for class org.elasticsearch.common.network.NetworkService.TcpSettings
-
- TDigestPercentileRanksAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
-
- TDigestPercentileRanksAggregator(String, ValuesSource.Numeric, AggregationContext, Aggregator, double[], double, boolean, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentileRanksAggregator
-
- TDigestPercentileRanksAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
-
- TDigestPercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
-
- TDigestPercentilesAggregator(String, ValuesSource.Numeric, AggregationContext, Aggregator, double[], double, boolean, ValueFormatter, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestPercentilesAggregator
-
- TDigestPercentilesAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
-
- 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) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
- template(Template) - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateRequest
-
- template() - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateRequest
-
- template(Template) - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateRequestBuilder
-
- template() - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateRequestBuilder
-
- template(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- template() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
- template(Template) - Method in class org.elasticsearch.action.search.SearchRequest
-
The stored template
- template() - Method in class org.elasticsearch.action.search.SearchRequest
-
The stored template
- template(String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- template() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
-
- template() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
-
- template(String) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
-
- template() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutResponse
-
- Template - Class in org.elasticsearch.script
-
- Template() - Constructor for class org.elasticsearch.script.Template
-
- Template(String) - Constructor for class org.elasticsearch.script.Template
-
Constructor for simple inline template.
- Template(String, ScriptService.ScriptType, String, XContentType, Map<String, Object>) - Constructor for class org.elasticsearch.script.Template
-
Constructor for Template.
- template() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- template() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
- template() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
-
- templateName(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
- templateName() - Method in class org.elasticsearch.action.search.SearchRequest
-
- templateParams(Map<String, Object>) - Method in class org.elasticsearch.action.search.SearchRequest
-
- templateParams() - Method in class org.elasticsearch.action.search.SearchRequest
-
- templateQuery(Template) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Facilitates creating template query requests using an inline script
- templateQuery(String, Map<String, Object>) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Facilitates creating template query requests using an inline script
- templateQuery(String, ScriptService.ScriptType, Map<String, Object>) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Facilitates creating template query requests
- TemplateQueryBuilder - Class in org.elasticsearch.index.query
-
Facilitates creating template query requests.
- TemplateQueryBuilder(Template) - Constructor for class org.elasticsearch.index.query.TemplateQueryBuilder
-
- TemplateQueryBuilder(String, Map<String, Object>) - Constructor for class org.elasticsearch.index.query.TemplateQueryBuilder
-
- TemplateQueryBuilder(String, ScriptService.ScriptType, Map<String, Object>) - Constructor for class org.elasticsearch.index.query.TemplateQueryBuilder
-
- TemplateQueryParser - Class in org.elasticsearch.index.query
-
In the simplest case, parse template string and variables from the request,
compile the template and execute the template against the given variables.
- TemplateQueryParser(ScriptService) - Constructor for class org.elasticsearch.index.query.TemplateQueryParser
-
- templates(ImmutableOpenMap<String, IndexTemplateMetaData>) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- templates() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- templateSource() - Method in class org.elasticsearch.action.search.SearchRequest
-
The search source template to execute.
- templateSource(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequest
-
Allows to provide template as source.
- templateSource(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
The template of the search request.
- templateSource() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
-
- templateSource() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
-
- templateSource() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
-
- templateType(ScriptService.ScriptType) - Method in class org.elasticsearch.action.search.SearchRequest
-
- templateType() - Method in class org.elasticsearch.action.search.SearchRequest
-
- tera() - Method in class org.elasticsearch.common.unit.SizeValue
-
- teraFrac() - Method in class org.elasticsearch.common.unit.SizeValue
-
- term() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
-
- term(String) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
-
- term(boolean) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.Terms.Order
-
- term - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
-
- terminal - Variable in class org.elasticsearch.common.cli.CliTool.Command
-
- terminal - Variable in class org.elasticsearch.common.cli.CliTool
-
- Terminal - Class in org.elasticsearch.common.cli
-
- Terminal() - Constructor for class org.elasticsearch.common.cli.Terminal
-
- Terminal(Terminal.Verbosity) - Constructor for class org.elasticsearch.common.cli.Terminal
-
- Terminal.Verbosity - Enum in org.elasticsearch.common.cli
-
- TerminalAppender - Class in org.elasticsearch.common.logging.log4j
-
TerminalAppender logs event to Terminal.DEFAULT.
- TerminalAppender() - Constructor for class org.elasticsearch.common.logging.log4j.TerminalAppender
-
- terminate(ExecutorService, long, TimeUnit) - Static method in class org.elasticsearch.threadpool.ThreadPool
-
Returns true
if the given service was terminated successfully.
- terminate(ThreadPool, long, TimeUnit) - Static method in class org.elasticsearch.threadpool.ThreadPool
-
Returns true
if the given pool was terminated successfully.
- terminateAfter(int) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
Upon reaching terminateAfter
counts, the count request will early terminate
- terminateAfter() - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
- terminateAfter() - Method in class org.elasticsearch.percolator.PercolateContext
-
- terminateAfter(int) - Method in class org.elasticsearch.percolator.PercolateContext
-
- terminateAfter(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
An optional terminate_after to terminate the search after collecting
terminateAfter
documents
- terminateAfter() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- terminateAfter(int) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- terminateAfter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- terminateAfter(int) - 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.internal.SearchContext
-
- terminateAfter(int) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- TerminateAfterParseElement - Class in org.elasticsearch.search.query
-
Parser element for 'terminate_after'
- TerminateAfterParseElement() - Constructor for class org.elasticsearch.search.query.TerminateAfterParseElement
-
- terminated() - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
-
- terminatedEarly() - Method in class org.elasticsearch.action.count.CountResponse
-
Deprecated.
True if the request has been terminated early due to enough count
- terminatedEarly() - Method in class org.elasticsearch.search.internal.InternalSearchResponse
-
- terminatedEarly(boolean) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- terminatedEarly() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- termPosition - Variable in class org.elasticsearch.search.lookup.PositionIterator
-
- TermPosition - Class in org.elasticsearch.search.lookup
-
- TermPosition() - Constructor for class org.elasticsearch.search.lookup.TermPosition
-
- termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- termQuery(String, String) - 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, float) - 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, boolean) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(MappedFieldType, Object) - Method in class org.elasticsearch.index.search.MatchQuery
-
Creates a TermQuery-like-query for MappedFieldTypes that don't support
QueryBuilder which is very string-ish.
- termQuery(MappedFieldType, Object, boolean) - Method in class org.elasticsearch.index.search.MatchQuery
-
- termQuery(MappedFieldType, Object) - Method in class org.elasticsearch.index.search.MultiMatchQuery.CrossFieldsQueryBuilder
-
- termQuery(MappedFieldType, Object) - Method in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
-
- termQuery(MappedFieldType, Object) - Method in class org.elasticsearch.index.search.MultiMatchQuery
-
- TermQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents containing a term.
- TermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Constructs a new term query.
- TermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Constructs a new term query.
- TermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Constructs a new term query.
- TermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Constructs a new term query.
- TermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Constructs a new term query.
- TermQueryBuilder(String, boolean) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Constructs a new term query.
- TermQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Constructs a new term query.
- TermQueryParser - Class in org.elasticsearch.index.query
-
- TermQueryParser() - Constructor for class org.elasticsearch.index.query.TermQueryParser
-
- terms(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsFields
-
- terms(String) - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
-
Deprecated.
- 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() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- terms - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
-
- Terms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
-
A bucket that is associated with a single term
- Terms.Order - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Determines the order by which the term buckets will be sorted
- Terms.ValueType - Enum in org.elasticsearch.search.aggregations.bucket.terms
-
- termsAggFactory - Variable in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
-
- termsAggFactory - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
-
- TermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
-
- TermsAggregator(String, AggregatorFactories, AggregationContext, Aggregator, TermsAggregator.BucketCountThresholds, Terms.Order, 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(String, ValuesSourceConfig, Terms.Order, TermsAggregator.BucketCountThresholds, IncludeExclude, String, Aggregator.SubAggCollectionMode, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
-
- TermsAggregatorFactory.ExecutionMode - Enum in org.elasticsearch.search.aggregations.bucket.terms
-
- TermsBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Builder for the
Terms
aggregation.
- TermsBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
Sole constructor.
- TermsLookup - Class in org.elasticsearch.indices.cache.query.terms
-
- TermsLookup(String, String, String, String, String, QueryParseContext) - Constructor for class org.elasticsearch.indices.cache.query.terms.TermsLookup
-
- termsLookupQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A terms lookup filter for the provided field name.
- TermsLookupQueryBuilder - Class in org.elasticsearch.index.query
-
A filer for a field based on several terms matching on any of them.
- TermsLookupQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.TermsLookupQueryBuilder
-
- TermsParametersParser - Class in org.elasticsearch.search.aggregations.bucket.terms
-
- TermsParametersParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsParametersParser
-
- TermsParser - Class in org.elasticsearch.search.aggregations.bucket.terms
-
- TermsParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsParser
-
- termsQuery(List, QueryParseContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
- 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, 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, 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, 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, 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, Collection<?>) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder - Class in org.elasticsearch.index.query
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, String...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, int...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, long...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, float...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, double...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, Object...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, Iterable) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filer for a field based on several terms matching on any of them.
- TermsQueryParser - Class in org.elasticsearch.index.query
-
- TermsQueryParser() - Constructor for class org.elasticsearch.index.query.TermsQueryParser
-
- termsStatistics(Term[], TermStatistics[]) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- termStatistics() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- termStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the term statistics for each term in the shard or skip.
- termStatistics() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
-
- termStatistics() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
-
- termStatistics(Term, TermContext) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
- TermSuggester - Class in org.elasticsearch.search.suggest.term
-
- TermSuggester() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggester
-
- termSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a term suggestion lookup query with the provided name
- 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, Suggest.Suggestion.Sort) - 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
-
- TermSuggestParser - Class in org.elasticsearch.search.suggest.term
-
- TermSuggestParser(TermSuggester) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestParser
-
- termVector(TermVectorsRequest) - Method in interface org.elasticsearch.client.Client
-
Deprecated.
- termVector(TermVectorsRequest, ActionListener<TermVectorsResponse>) - 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 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, ActionListener<TermVectorsResponse>) - 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 class org.elasticsearch.client.support.AbstractClient
-
- termVectors() - Method in class org.elasticsearch.search.lookup.LeafIndexLookup
-
- TermVectorsAction - Class in org.elasticsearch.action.termvectors
-
- TermVectorsFields - Class in org.elasticsearch.action.termvectors
-
- 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(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(MultiGetRequest.Item) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- 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() - Method in class org.elasticsearch.index.shard.IndexShard
-
- 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() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- text(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- Text() - Constructor for class org.elasticsearch.action.fieldstats.FieldStats.Text
-
- Text(long, long, long, long, BytesRef, BytesRef) - Constructor for class org.elasticsearch.action.fieldstats.FieldStats.Text
-
- Text - Class in org.elasticsearch.common.text
-
- Text(BytesReference) - Constructor for class org.elasticsearch.common.text.Text
-
- Text(String) - Constructor for class org.elasticsearch.common.text.Text
-
- text() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- text() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- TEXT - Static variable in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction.Fields
-
- text - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
-
- text(String) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
-
- TEXT_CONTENT_TYPE - Static variable in class org.elasticsearch.rest.BytesRestResponse
-
- TEXT_PROMPT_VALUE - Static variable in class org.elasticsearch.node.internal.InternalSettingsPreparer
-
- textCharacters() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- textCharacters() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- textLength() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- textLength() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- textOffset() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
-
- textOffset() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- textOrNull() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
-
- textOrNull() - Method in interface org.elasticsearch.common.xcontent.XContentParser
-
- tf() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
-
- ThaiAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- ThaiAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ThaiAnalyzerProvider
-
- ThaiTokenizerFactory - Class in org.elasticsearch.index.analysis
-
Factory for ThaiTokenizer
- ThaiTokenizerFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ThaiTokenizerFactory
-
- THREAD_POOL_TYPE_SETTINGS_VALIDATOR - Static variable in class org.elasticsearch.threadpool.ThreadPool
-
- THREAD_POOL_TYPES - Static variable in class org.elasticsearch.threadpool.ThreadPool
-
- ThreadBarrier - Class in org.elasticsearch.common.util.concurrent
-
A synchronization aid that allows a set of threads to all wait for each other
to reach a common barrier point.
- ThreadBarrier(int) - Constructor for class org.elasticsearch.common.util.concurrent.ThreadBarrier
-
- ThreadBarrier(int, Runnable) - Constructor for class org.elasticsearch.common.util.concurrent.ThreadBarrier
-
- ThreadBarrier.BarrierTimer - Class in org.elasticsearch.common.util.concurrent
-
A Barrier action to be used in conjunction with
ThreadBarrier
to
measure performance between barrier awaits.
- ThreadedActionListener<Response> - Class in org.elasticsearch.action.support
-
An action listener that wraps another action listener and threading its execution.
- ThreadedActionListener(ESLogger, ThreadPool, String, ActionListener<Response>) - 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
-
- threadLocal - Variable in class org.elasticsearch.common.util.concurrent.KeyedLock
-
- 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() - 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.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(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node Thread Pool be returned.
- threadPool() - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
-
- threadPool - Variable in class org.elasticsearch.action.support.TransportAction
-
- 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 - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- ThreadPool - Class in org.elasticsearch.threadpool
-
- ThreadPool(String) - Constructor for class org.elasticsearch.threadpool.ThreadPool
-
- ThreadPool(Settings) - Constructor for class org.elasticsearch.threadpool.ThreadPool
-
- threadPool - Variable in class org.elasticsearch.transport.netty.MessageChannelHandler
-
- threadPool - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- threadPool - Variable in class org.elasticsearch.transport.TransportService
-
- ThreadPool.Info - Class in org.elasticsearch.threadpool
-
- ThreadPool.Names - Class in org.elasticsearch.threadpool
-
- ThreadPool.ThreadPoolType - Enum in org.elasticsearch.threadpool
-
- THREADPOOL_GROUP - Static variable in class org.elasticsearch.threadpool.ThreadPool
-
- ThreadPoolInfo - Class in org.elasticsearch.threadpool
-
- ThreadPoolInfo(List<ThreadPool.Info>) - Constructor for class org.elasticsearch.threadpool.ThreadPoolInfo
-
- ThreadPoolModule - Class in org.elasticsearch.threadpool
-
- ThreadPoolModule(ThreadPool) - Constructor for class org.elasticsearch.threadpool.ThreadPoolModule
-
- ThreadPoolStats - Class in org.elasticsearch.threadpool
-
- ThreadPoolStats(List<ThreadPoolStats.Stats>) - 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
-
- thresholdBytesFromWatermark(String, String) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Attempts to parse the watermark into a
ByteSizeValue
, returning
a ByteSizeValue of 0 bytes if the value cannot be parsed.
- thresholdFrequency(long, long) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
-
- thresholdPercentageFromWatermark(String) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Attempts to parse the watermark into a percentage, returning 100.0% if
it cannot be parsed.
- THROTTLE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
- throttleTime() - Method in class org.elasticsearch.index.recovery.RecoveryStats
-
Total time recoveries waited due to throttling
- throttleTime() - Method in class org.elasticsearch.index.store.StoreStats
-
- throttleTimeInNanos() - Method in class org.elasticsearch.index.store.DirectoryService
-
- throttleTimeInNanos() - Method in class org.elasticsearch.index.store.FsDirectoryService
-
- throttlingActivated() - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- ThrottlingAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
- ThrottlingAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
-
- throttlingDeactivated() - Method in class org.elasticsearch.index.indexing.ShardIndexingService
-
- 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
-
- throwProvisionExceptionIfErrorsExist() - Method in class org.elasticsearch.common.inject.internal.Errors
-
- tick() - Method in class org.elasticsearch.common.metrics.EWMA
-
Mark the passage of time and decay the current rate accordingly.
- tieBreaker() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- tieBreaker(float) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- 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() - Method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
- 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 - Variable in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
-
- TIME - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- time() - Method in class org.elasticsearch.index.shard.SnapshotStatus.Index
-
- time(long) - Method in class org.elasticsearch.index.shard.SnapshotStatus.Index
-
- time() - Method in class org.elasticsearch.index.shard.SnapshotStatus
-
- time(long) - Method in class org.elasticsearch.index.shard.SnapshotStatus
-
- time() - Method in class org.elasticsearch.index.shard.SnapshotStatus.Translog
-
- time(long) - Method in class org.elasticsearch.index.shard.SnapshotStatus.Translog
-
- time() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot running time
- time() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns snapshot processing time
- time(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Sets snapshot processing time
- time - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
- 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_NON_NEGATIVE - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- TIME_UNIT - Static variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
-
- timedOut() - Method in class org.elasticsearch.search.internal.InternalSearchResponse
-
- timeElementParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO time parser.
- timeEstimateCounter() - Method in class org.elasticsearch.percolator.PercolateContext
-
- timeEstimateCounter() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- 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() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
- timeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
- timeout(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
- timeout() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
- timeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
- timeout(String) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
- timeout - Variable in class org.elasticsearch.action.bulk.BulkRequest
-
- timeout(TimeValue) - 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.bulk.BulkRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
- timeout - Variable in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
- timeout(String) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Allows to set the timeout
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Allows to set the timeout
- 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(TimeValue) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
-
- timeout(String) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
-
- timeout - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
-
- 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(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout() - Method 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.support.single.instance.InstanceShardOperationRequest
-
- 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(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() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
- timeout() - Method in class org.elasticsearch.cluster.BasicClusterStateTaskConfig
-
- 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
-
- timeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Request
-
- TIMEOUT - Static variable in interface org.elasticsearch.cluster.settings.Validator
-
- timeout - Variable in class org.elasticsearch.indices.store.IndicesStore.ShardActiveRequest
-
- timeout(TimeValue) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
An optional timeout to control how long search is allowed to take.
- timeout(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
An optional timeout to control how long search is allowed to take.
- timeout() - Method in class org.elasticsearch.transport.TransportRequestOptions
-
- TimeoutClusterStateListener - Interface in org.elasticsearch.cluster
-
An exception to cluster state listener that allows for timeouts and for post added notifications.
- timeoutInMillis() - Method in class org.elasticsearch.percolator.PercolateContext
-
- timeoutInMillis(long) - Method in class org.elasticsearch.percolator.PercolateContext
-
- timeoutInMillis() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- timeoutInMillis(long) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- timeoutInMillis() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- timeoutInMillis(long) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- timeoutInMillis() - Method in class org.elasticsearch.search.internal.SearchContext
-
- timeoutInMillis(long) - Method in class org.elasticsearch.search.internal.SearchContext
-
- timeoutInMillis(long) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- TimeoutParseElement - Class in org.elasticsearch.search.query
-
- TimeoutParseElement() - Constructor for class org.elasticsearch.search.query.TimeoutParseElement
-
- timeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO time parser for parsing times with a possible zone.
- Timer() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
- timestamp(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the timestamp either as millis since the epoch, or, in the configured date format.
- timestamp() - Method in class org.elasticsearch.action.index.IndexRequest
-
- timestamp() - Method in exception org.elasticsearch.action.TimestampParsingException
-
- timestamp() - Method in class org.elasticsearch.Build
-
- timestamp() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
The timestamp value parsed, null if does not require parsing, or not resolved.
- timestamp() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
- Timestamp(boolean, String, String, String, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
-
- timestamp() - Method in exception org.elasticsearch.index.AlreadyExpiredException
-
- timestamp() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- timestamp() - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- timestamp() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- timestamp(String) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- timestamp(long) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- timestamp() - Method in class org.elasticsearch.index.translog.Translog.Create
-
- timestamp() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- timestamp - Variable in class org.elasticsearch.index.translog.Translog.Source
-
- timestampFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- TimestampFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
- TimestampFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- TimestampFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- TimestampFieldMapper.TimestampFieldType - Class in org.elasticsearch.index.mapper.internal
-
- TimestampFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- TimestampFieldType() - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.TimestampFieldType
-
- TimestampFieldType(TimestampFieldMapper.TimestampFieldType) - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.TimestampFieldType
-
- 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
-
- timestampParsingStillNeeded() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Is timestamp parsing still needed?
- timestampResolved() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
-
Has timestamp been resolved during the parsing phase.
- timeUnit(TimeUnit) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
-
- timeUnit - Variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- timeUnit() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- TimeValue - Class in org.elasticsearch.common.unit
-
- TimeValue(long) - Constructor for class org.elasticsearch.common.unit.TimeValue
-
- TimeValue(long, TimeUnit) - Constructor for class org.elasticsearch.common.unit.TimeValue
-
- timeValueField(XContentBuilderString, XContentBuilderString, TimeValue) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- timeValueField(XContentBuilderString, XContentBuilderString, long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- timeValueField(String, String, long, TimeUnit) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- timeValueHours(long) - Static method in class org.elasticsearch.common.unit.TimeValue
-
- timeValueMillis(long) - Static method in class org.elasticsearch.common.unit.TimeValue
-
- timeValueMinutes(long) - Static method in class org.elasticsearch.common.unit.TimeValue
-
- timeValueNanos(long) - Static method in class org.elasticsearch.common.unit.TimeValue
-
- timeValueSeconds(long) - Static method in class org.elasticsearch.common.unit.TimeValue
-
- timeZone(DateTimeZone) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- timeZone() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
-
- timeZone(DateTimeZone) - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
-
- 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(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
-
Set the timezone in which to translate dates before computing buckets.
- timezone() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser.Input
-
- timezoneAware(boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser.Builder
-
- TimeZoneRounding - Class in org.elasticsearch.common.rounding
-
- TimeZoneRounding() - Constructor for class org.elasticsearch.common.rounding.TimeZoneRounding
-
- TimeZoneRounding.Builder - Class in org.elasticsearch.common.rounding
-
- tmpFile() - Method in class org.elasticsearch.env.Environment
-
Path to the default temp directory used by the JDK
- to(String) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(int) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(long) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(boolean) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(double) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(float) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(short) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(char) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(Class<?>) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(E) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(Class<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
.
- to(TypeLiteral<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
.
- to(Key<? 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(TypeLiteral<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
-
- to(Key<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
-
- to(String) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(int) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(long) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(boolean) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(double) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(float) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(short) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(char) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(Class<?>) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(E) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
-
- to(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeQueryBuilder
-
- to(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(int) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(long) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(float) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(double) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
-
- to - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
-
- TO - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
-
- TO_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
-
- toArray() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
- toArray() - Method in class org.elasticsearch.common.blobstore.BlobPath
-
- toArray(E[]) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Copies the content of the underlying atomic array to a normal one.
- toArray() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- toArray(T[]) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
- toArray() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingCollection
-
serialize current pings to an array
- toAutomaton(boolean, Iterable<ContextMapping.ContextQuery>) - Static method in class org.elasticsearch.search.suggest.context.ContextMapping.ContextQuery
-
Create a automaton for a given context query this automaton will be used
to find the matching paths with the fst
- toAutomaton() - Method in class org.elasticsearch.search.suggest.context.ContextMapping.ContextQuery
-
Build a LookUp Automaton for this context.
- ToBlockJoinQueryBuilder(QueryParseContext) - Constructor for class org.elasticsearch.index.query.NestedQueryParser.ToBlockJoinQueryBuilder
-
- toBytes(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
-
- toBytes() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- toBytes() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns the bytes as a single byte array.
- toBytes() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- toBytes() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- toBytes(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
-
- toBytes() - Method in class org.elasticsearch.index.mapper.Mapping
-
- toBytesArray() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- toBytesArray() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns the bytes as a byte array, possibly sharing the underlying byte buffer.
- toBytesArray() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- toBytesArray() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- toBytesRef() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- toBytesRef() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Converts to Lucene BytesRef.
- toBytesRef() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- toBytesRef() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- 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
-
- toBytesRef() - Method in class org.elasticsearch.index.mapper.Uid
-
- toCamelCase(String) - Static method in class org.elasticsearch.common.Strings
-
- toCamelCase(String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
-
- toChannelBuffer() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- toChannelBuffer() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns the bytes as a channel buffer.
- toChannelBuffer() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- toChannelBuffer() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- toCharArray() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Returns a copy of the input data.
- toDegrees(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toDegrees(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toDegrees(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toDegrees(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toDegrees(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toDelimitedString(char) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the settings as delimited string.
- toDouble(BytesRef) - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
- toException() - Method in class org.elasticsearch.common.inject.internal.Errors
-
- toFiniteStrings(TokenStream) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
-
- toFiniteStrings(TokenStream) - Method in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
-
- toFiniteStrings(TokenStream) - Method in interface org.elasticsearch.search.suggest.completion.CompletionTokenStream.ToFiniteStrings
-
- toFloat(double) - Static method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
-
- 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
-
- toIndexForm(Number, BytesRefBuilder) - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
- toInnerXContent(XContentBuilder) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Text
-
- toInnerXContent(XContentBuilder) - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.context.ContextMapping
-
Since every context mapping is assumed to have a name given by the field name of an context object, this
method is used to build the value used to serialize the mapping
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- 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
-
- toKB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
-
- token(String, XContentParser.Token, XContentParser, ParseFieldMatcher) - Method in class org.elasticsearch.script.ScriptParameterParser
-
- token(String, XContentParser.Token, XContentParser) - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude.Parser
-
- token(String, XContentParser.Token, XContentParser) - Method in class org.elasticsearch.search.aggregations.support.GeoPointParser
-
- token(String, XContentParser.Token, XContentParser) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
-
- TOKEN_FILTERS - Static variable in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction.Fields
-
- TokenConsumer() - Constructor for class org.elasticsearch.search.suggest.SuggestUtils.TokenConsumer
-
- tokenCountField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
-
- TokenCountFieldMapper - Class in org.elasticsearch.index.mapper.core
-
A
FieldMapper
that takes a string and writes a count of the tokens in that string
to the index.
- TokenCountFieldMapper(String, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Settings, NamedAnalyzer, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
-
- TokenCountFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
-
- TokenCountFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
-
- TokenCountFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
-
- tokenFilter(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
-
- tokenFilterFactories() - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- TokenFilterFactory - Interface in org.elasticsearch.index.analysis
-
- TokenFilterFactoryFactory - Interface in org.elasticsearch.index.analysis
-
- tokenFilterFactoryFactory(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- tokenFilters(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- tokenFilters() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- 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.index.analysis.CustomAnalyzer
-
- TokenFiltersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.TokenFiltersBindings
-
- tokenized(boolean) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
-
- tokenized(boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
- tokenizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- tokenizer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
-
- tokenizer() - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
-
- tokenizer(DetailAnalyzeResponse.AnalyzeTokenList) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse
-
- tokenizer(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
-
- TOKENIZER - Static variable in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction.Fields
-
- tokenizerFactories() - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- tokenizerFactory() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
-
- TokenizerFactory - Interface in org.elasticsearch.index.analysis
-
- TokenizerFactoryFactory - Interface in org.elasticsearch.index.analysis
-
- tokenizerFactoryFactory(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
-
- TokenizersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.TokenizersBindings
-
- tokenizeToStringArray(String, String) - Static method in class org.elasticsearch.common.Strings
-
Tokenize the given String into a String array via a StringTokenizer.
- tokenizeToStringArray(String, String, boolean, boolean) - Static method in class org.elasticsearch.common.Strings
-
Tokenize the given String into a String array via a StringTokenizer.
- 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.core.ByteFieldMapper.CustomByteNumericField
-
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericField
-
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericField
-
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.CustomIntegerNumericField
-
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.CustomLongNumericField
-
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
-
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper.CustomShortNumericField
-
- tokenStream(Analyzer, BytesRef, CharsRefBuilder, String) - Method in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
-
- toKilo(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
-
- toLong(BytesRef) - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
- toMB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
-
- 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
-
- toNumber(BytesRef) - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
- toolType() - Method in class org.elasticsearch.common.cli.CliToolConfig
-
- tooManyConstructors(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
-
- TOP - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- TOP_LEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
- TOP_LEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- TOP_RIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- toPB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
-
- topDocs(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.BaseInnerHits
-
- topDocs(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.NestedInnerHits
-
- topDocs(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.ParentChildInnerHits
-
- topDocs() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- topDocs(TopDocs) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
- topDocs() - Method in class org.elasticsearch.search.scan.ScanContext.ScanCollector
-
- 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.
- TopHitsAggregator - Class in org.elasticsearch.search.aggregations.metrics.tophits
-
- TopHitsAggregator(FetchPhase, SubSearchContext, String, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
-
- TopHitsAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.tophits
-
- TopHitsBuilder - Class in org.elasticsearch.search.aggregations.metrics.tophits
-
Builder for the
TopHits
aggregation.
- TopHitsBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
Sole constructor.
- TopHitsParser - Class in org.elasticsearch.search.aggregations.metrics.tophits
-
- TopHitsParser(FetchPhase, SortParseElement, FetchSourceParseElement, HighlighterParseElement, FieldDataFieldsParseElement, ScriptFieldsParseElement, FieldsParseElement) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsParser
-
- topLeft - Variable in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
-
- topLeft(Coordinate) - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
-
- topLeft(double, double) - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
-
- topLeft() - Method in interface org.elasticsearch.common.geo.GeoDistance.DistanceBoundingCheck
-
- topLeft() - Method in class org.elasticsearch.common.geo.GeoDistance.Meridian180DistanceBoundingCheck
-
- topLeft() - Method in class org.elasticsearch.common.geo.GeoDistance.SimpleDistanceBoundingCheck
-
- topLeft(double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds top left point.
- topLeft(GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
- topLeft(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
- TOPLEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- topLeft() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxQuery
-
- 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
-
- topLevelQuery(Term[], TermContext[], int[], int) - Method in class org.apache.lucene.queries.BlendedTermQuery
-
- topLevelReader() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
-
- topLevelSearcher() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
-
- toPolygon() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- toPolygon(GeometryFactory) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- topRight(double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds top right point.
- topRight(GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
- topRight(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
- TOPRIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryParser
-
- toProvider(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 interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
.
- toProvider(Key<? extends 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
-
- toProvider(Class<? extends Provider<? extends T>>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
-
- toProvider(Key<? extends Provider<? extends T>>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
-
- toRadians(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toRadians(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toRadians(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toRadians(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toRadians(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
-
- toSearchRequest() - Method in class org.elasticsearch.action.count.CountRequest
-
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 a
SortedNumericDocValues
instance that will translate double values to sortable long bits using
NumericUtils.doubleToSortableLong(double)
.
- toString(String) - Method in class org.apache.lucene.queries.BlendedTermQuery
-
- toString(String) - Method in class org.apache.lucene.queries.MinDocQuery
-
- toString() - Method in class org.apache.lucene.store.RateLimitedFSDirectory
-
- toString(Directory) - Static method in class org.apache.lucene.store.StoreUtils
-
- toString(Directory[]) - Static method in class org.apache.lucene.store.StoreUtils
-
- toString() - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- 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.stats.NodesStatsResponse
-
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
- toString() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
-
- 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.tasks.PendingClusterTasksResponse
-
- 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.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.BulkShardRequest
-
- toString() - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
- toString() - Method in class org.elasticsearch.action.count.CountRequestBuilder
-
Deprecated.
- toString() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
- toString() - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
- toString() - Method in class org.elasticsearch.action.get.GetRequest
-
- 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.indexedscripts.delete.DeleteIndexedScriptRequest
-
- toString() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- toString() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- 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.SearchRequestBuilder
-
- toString() - Method in class org.elasticsearch.action.search.SearchResponse
-
- toString() - Method in class org.elasticsearch.action.search.ShardSearchFailure
-
- toString() - Method in class org.elasticsearch.action.suggest.SuggestRequest
-
- toString() - Method in class org.elasticsearch.action.suggest.SuggestResponse
-
- 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.ReplicationRequest
-
- toString() - Method in class org.elasticsearch.action.support.ToXContentToBytes
-
- toString() - Method in class org.elasticsearch.action.TaskOperationFailure
-
- toString() - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyRequest
-
- toString() - Method in class org.elasticsearch.Build
-
- toString() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardRoutingEntry
-
- toString() - Method in class org.elasticsearch.cluster.block.ClusterBlock
-
- 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.metadata.SnapshotId
-
- 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.routing.allocation.decider.Decision.Multi
-
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
-
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation.FailedShard
-
- toString() - Method in class org.elasticsearch.cluster.routing.AllocationId
-
- toString() - Method in class org.elasticsearch.cluster.routing.RestoreSource
-
- toString() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
- toString() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- toString() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
- toString() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
- 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.blobstore.url.URLBlobStore
- 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.collect.Tuple
-
- 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.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 class org.elasticsearch.common.inject.assistedinject.FactoryProvider2
-
- 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(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
- 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>()
or java.util.List.remove()
.
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
-
- toString() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
-
- toString() - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
-
- toString() - Method in class org.elasticsearch.common.inject.internal.ToStringBuilder
-
- toString() - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
-
- toString() - Method in class org.elasticsearch.common.inject.Key
-
- toString() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
-
- toString() - Method in interface org.elasticsearch.common.inject.Scope
-
A short but useful description of this scope.
- toString() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
- toString() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
- toString() - Method in class org.elasticsearch.common.inject.spi.Message
-
- toString() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup.ProviderImpl
-
- toString() - Method in class org.elasticsearch.common.inject.TypeLiteral
-
- toString() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Converts input data to a string.
- toString() - Method in class org.elasticsearch.common.io.FastStringReader
-
- toString() - Method in class org.elasticsearch.common.lucene.all.AllEntries
-
- toString(String) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
-
- toString() - Method in class org.elasticsearch.common.lucene.all.AllTokenStream
-
- 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 call
BytesRef.utf8ToString()
.
- toString() - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
-
Deprecated.
- toString() - Method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
-
- toString(String) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
-
- toString(String) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
- toString() - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
-
- toString(String) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
- toString(String) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
- toString() - Method in class org.elasticsearch.common.ParseField
-
- toString() - Method in class org.elasticsearch.common.Priority
-
- 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(ToXContent) - Static method in class org.elasticsearch.common.Strings
-
- 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.DummyTransportAddress
-
- toString() - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
-
- toString() - Method in class org.elasticsearch.common.transport.LocalTransportAddress
-
- toString() - Method in interface 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(double) - Method in enum org.elasticsearch.common.unit.DistanceUnit
-
Convert a value to a distance string
- 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.unit.TimeValue
-
- toString() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
-
- toString() - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
-
- toString(Locale) - Static method in class org.elasticsearch.common.util.LocaleUtils
-
Return a string for a
Locale
object
- toString() - Method in class org.elasticsearch.common.util.URIPattern
-
- toString() - Method in class org.elasticsearch.common.xcontent.support.filtering.FilterPath
-
- toString(ToXContent) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Writes serialized toXContent to pretty-printed JSON string.
- toString(ToXContent, ToXContent.Params) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Writes serialized toXContent to pretty-printed JSON string.
- toString() - Method in class org.elasticsearch.common.xcontent.XContentLocation
-
- toString() - Method in class org.elasticsearch.discovery.zen.ping.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.ShardLock
-
- toString() - Method in class org.elasticsearch.http.netty.cors.CorsConfig
-
- 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(SortedNumericDocValues) - 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(RandomAccessOrds) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values.
- toString(MultiGeoPointValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values.
- 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.Uid
-
- toString() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- toString() - Method in class org.elasticsearch.index.recovery.RecoveryStats
-
- toString(String) - Method in class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
-
Deprecated.
- toString(String) - Method in class org.elasticsearch.index.search.child.ChildrenQuery
-
Deprecated.
- toString(String) - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
-
Deprecated.
- toString(String) - Method in class org.elasticsearch.index.search.child.ParentQuery
-
Deprecated.
- toString(String) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeQuery
-
- toString(String) - Method in class org.elasticsearch.index.search.geo.GeoPolygonQuery
-
- toString(String) - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxQuery
-
- toString(String) - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
-
- toString() - Method in class org.elasticsearch.index.search.stats.SearchStats
-
- toString() - Method in class org.elasticsearch.index.shard.ElasticsearchMergePolicy
-
- 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.snapshots.blobstore.BlobStoreIndexShardRepository
-
- 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.Translog.Create
-
- toString() - Method in class org.elasticsearch.index.translog.Translog.Delete
-
- toString() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
-
Deprecated.
- 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.TranslogReader
-
- 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.cache.query.terms.TermsLookup
-
- 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.IndicesWarmer.WarmerContext
-
- 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.RecoveryStatus
-
- toString() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
-
- toString() - Method in class org.elasticsearch.plugins.PluginInfo
-
- toString() - Method in class org.elasticsearch.repositories.VerificationFailure
-
- toString() - Method in class org.elasticsearch.script.CompiledScript
-
- toString() - Method in class org.elasticsearch.script.Script
-
- toString() - Method in class org.elasticsearch.script.ScriptContext.Plugin
-
- toString() - Method in enum org.elasticsearch.script.ScriptContext.Standard
-
- toString() - Method in class org.elasticsearch.script.ScriptModes
-
- toString() - Method in enum org.elasticsearch.script.ScriptService.ScriptType
-
- toString() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
-
- 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.InternalAggregation.Type
-
- toString() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
-
- toString() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
-
- toString() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
- toString() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
-
- toString() - Method in class org.elasticsearch.search.highlight.HighlightField
-
- toString() - Method in enum org.elasticsearch.search.profile.ProfileBreakdown.TimingType
-
- toString() - Method in class org.elasticsearch.search.SearchShardTarget
-
- toString() - Method in class org.elasticsearch.search.sort.SortBuilder
-
- toString() - Method in class org.elasticsearch.search.suggest.context.ContextMapping.ContextQuery
-
- toString() - Method in class org.elasticsearch.search.suggest.context.ContextMapping
-
- 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.Suggest
-
- toString() - Method in class org.elasticsearch.snapshots.RestoreService.UpdateIndexShardRestoreStatusRequest
-
- toString() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
- toString() - Method in class org.elasticsearch.snapshots.SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
-
- toString() - Method in class org.elasticsearch.tasks.TaskId
-
- toString() - Method in class org.elasticsearch.transport.PlainTransportFuture
-
- toString() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
-
- toString() - Method in class org.elasticsearch.Version
-
- 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(String) - Constructor for class org.elasticsearch.common.inject.internal.ToStringBuilder
-
- ToStringBuilder(Class) - Constructor for class org.elasticsearch.common.inject.internal.ToStringBuilder
-
- toStringTrim() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
-
Converts the input data to a string with trimmed whitespaces.
- total() - Method in class org.elasticsearch.index.warmer.WarmerStats
-
The total number of warmer executed.
- total() - Method in class org.elasticsearch.monitor.fs.FsInfo
-
- TOTAL_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
-
- totalBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of bytes in th shard
- totalChannels() - Method in class org.elasticsearch.common.netty.OpenChannelsHandler
-
- 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.InternalSearchHits
-
- totalHits() - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- totalHits - Variable in class org.elasticsearch.search.internal.ScrollContext
-
- totalHits() - Method in interface org.elasticsearch.search.SearchHits
-
The total number of hits that matches the search request.
- totalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- totalOperations() - Method in class org.elasticsearch.index.translog.ImmutableTranslogReader
-
- totalOperations() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the number of operations in the transaction files that aren't committed to lucene..
- totalOperations() - Method in class org.elasticsearch.index.translog.Translog.View
-
The total number of operations in the view.
- 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
-
- 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
-
- totalShard() - Method in class org.elasticsearch.snapshots.Snapshot
-
Returns total number of shards that were snapshotted
- 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
- 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.shard.SnapshotStatus.Index
-
- totalSize() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns total size of all files that where snapshotted
- totalSize() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Total snapshot size
- 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.RecoveryPrepareForTranslogOperationsRequest
-
- 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
-
- toTermVectorsRequest() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- toTimingMap() - Method in class org.elasticsearch.search.profile.ProfileBreakdown
-
- toUnderscoreCase(String) - Static method in class org.elasticsearch.common.Strings
-
- toUnderscoreCase(String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
-
- toUTF16() - Method in interface org.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttribute
-
- toUTF16() - Method in class org.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttributeImpl
-
- toUtf8() - Method in class org.elasticsearch.common.bytes.BytesArray
-
- toUtf8() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Converts to a string based on utf8.
- toUtf8() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
-
- toUtf8() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
-
- toUTF8Bytes(CharSequence) - Static method in class org.elasticsearch.common.Strings
-
- toUTF8Bytes(CharSequence, BytesRefBuilder) - Static method in class org.elasticsearch.common.Strings
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo.Failure
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ActionWriteResponse.ShardInfo
-
- 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.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.list.ListTasksResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskInfo
-
- 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.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.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.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.tasks.PendingClusterTasksResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateResponse
-
- 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.flush.SyncedFlushResponse
-
- 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.recovery.RecoveryResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
-
- 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.stats.CommonStats
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
-
- 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.upgrade.get.UpgradeStatusResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.GetResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.percolate.PercolateResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder.DocBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
-
- 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 class org.elasticsearch.action.search.SearchResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.ShardSearchFailure
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.QuerySourceBuilder
-
- 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.cluster.block.ClusterBlock
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.ClusterState
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
-
- 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(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
- 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(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- toXContent(RepositoryMetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
Serializes information about a single repository
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.RestoreInProgress
- toXContent(RestoreInProgress.Entry, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.RestoreInProgress
-
Serializes single restore operation
- toXContent(AllocateAllocationCommand, XContentBuilder, ToXContent.Params, String) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand.Factory
-
- toXContent(T, XContentBuilder, ToXContent.Params, String) - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand.Factory
-
- toXContent(AllocationCommands, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
- toXContent(CancelAllocationCommand, XContentBuilder, ToXContent.Params, String) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand.Factory
-
- toXContent(MoveAllocationCommand, XContentBuilder, ToXContent.Params, String) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand.Factory
-
- 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.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.AllocationId
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RestoreSource
-
- 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.SnapshotsInProgress
-
- toXContent(SnapshotsInProgress.Entry, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.BaseLineStringBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- 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.ShapeBuilder.CoordinateNode
-
- toXContent(XContentBuilder, Coordinate) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.settings.Settings
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.unit.Fuzziness
-
- toXContent(XContentBuilder, ToXContent.Params, boolean) - Method in class org.elasticsearch.common.unit.Fuzziness
-
- ToXContent - Interface in org.elasticsearch.common.xcontent
-
An interface allowing to transfer an object to "XContent" using an
XContentBuilder
.
- toXContent(XContentBuilder, ToXContent.Params) - Method in interface org.elasticsearch.common.xcontent.ToXContent
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.ElasticsearchException
-
- toXContent(XContentBuilder, ToXContent.Params, Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
-
- 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(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.indexing.IndexingStats.Stats
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.indexing.IndexingStats
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- 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.internal.AllFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.Mapping
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- toXContent(XContentBuilder, ToXContent.Params, ToXContent) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.merge.MergeStats
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.QueryBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.support.QueryInnerHitBuilder
-
- 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.search.stats.SearchStats.Stats
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.search.stats.SearchStats
-
- toXContent(CommitPoint) - Static method in class org.elasticsearch.index.shard.CommitPoints
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.DocsStats
-
- toXContent(BlobStoreIndexShardSnapshot.FileInfo, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Serializes file info into JSON
- 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.suggest.stats.SuggestStats
-
- 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.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
-
- 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.plugins.PluginInfo
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.Script
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptStats
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters.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.AbstractRangeBuilder.Range
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder.Range
-
- 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.significant.heuristics.ChiSquare.ChiSquareBuilder
-
- 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.JLHScore.JLHScoreBuilder
-
- 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.PercentageScore.PercentageScoreBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
-
- toXContent(XContentBuilder) - 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.InternalAggregations
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.MetricsAggregationBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
-
- 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.HoltLinearModel.HoltLinearModelBuilder
-
- 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.LinearModel.LinearModelBuilder
-
- 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.PipelineAggregatorBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder.InnerHit
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.internal.InternalSearchHit.InternalNestedIdentity
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.internal.InternalSearchHits
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.internal.InternalSearchResponse
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.CollectorResult
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.InternalProfileShardResults
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.ProfileShardResult
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.RescoreBuilder.Rescorer
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.RescoreBuilder
-
- 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.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.context.ContextMapping
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.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.SuggestionBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData
-
- toXContent(IndexWarmersMetaData.Entry, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.search.warmer.IndexWarmersMetaData
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.RestoreInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.Snapshot
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
- toXContent(SnapshotShardFailure, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
Serializes snapshot failure information into JSON
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
-
- 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.TransportInfo
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.TransportStats
-
- ToXContent.DelegatingMapParams - Class in org.elasticsearch.common.xcontent
-
- ToXContent.MapParams - Class in org.elasticsearch.common.xcontent
-
- ToXContent.Params - Interface in org.elasticsearch.common.xcontent
-
- toXContentEmbedded(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.get.GetResult
-
- toXContentInternal(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Directly write all the addAggregation without their bounding object.
- ToXContentToBytes - Class in org.elasticsearch.action.support
-
- ToXContentToBytes() - Constructor for class org.elasticsearch.action.support.ToXContentToBytes
-
- ToXContentToBytes(XContentType) - Constructor for class org.elasticsearch.action.support.ToXContentToBytes
-
- toXContentWithoutObject(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.DetailAnalyzeResponse.AnalyzeTokenList
-
- trace(String, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
-
Logs a DEBUG level message.
- trace(String, Throwable, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
-
Logs a DEBUG level message.
- trace(String, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- trace(String, Throwable, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
-
- traceEnabled() - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- traceReceivedRequest(long, String) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- traceReceivedResponse(long, DiscoveryNode, String) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- traceRequestSent(DiscoveryNode, long, String, TransportRequestOptions) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- traceResponseSent(long, String, Throwable) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- traceResponseSent(long, String) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- traceUnresolvedResponse(long) - Method in class org.elasticsearch.transport.TransportService.Adapter
-
- trackScores(boolean) - Method in class org.elasticsearch.percolator.PercolateContext
-
- trackScores() - Method in class org.elasticsearch.percolator.PercolateContext
-
- 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.DefaultSearchContext
-
- trackScores() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- trackScores() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
-
- trackScores() - Method in class org.elasticsearch.search.internal.SearchContext
-
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- trackScores() - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- TrackScoresParseElement - Class in org.elasticsearch.search.sort
-
- TrackScoresParseElement() - Constructor for class org.elasticsearch.search.sort.TrackScoresParseElement
-
- transform(ScriptService, Script) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
-
- transform(ScriptService, String, ScriptService.ScriptType, String, Map<String, Object>) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
-
- transformSource() - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
-
Should the document be transformed after the source is loaded?
- transformSource(boolean) - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
-
Should the document be transformed after the source is loaded?
- transformSourceAsMap(Map<String, Object>) - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
Transform the source when it is expressed as a map.
- transformSourceAsMap(Map<String, Object>) - Method in interface org.elasticsearch.index.mapper.Mapping.SourceTransform
-
Transform the source when it is expressed as a map.
- transientSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
- transientSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the transient settings to be updated.
- transientSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the transient settings to be updated.
- transientSettings(String) - 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() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- transientSettings(Settings) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- transientSettings() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- translate(Coordinate[]) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
-
Transforms coordinates in the eastern hemisphere (-180:0) to a (180:360) range
- translated - Variable in class org.elasticsearch.common.geo.builders.PointCollection
-
- translog - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
- translog(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- translog() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
- translog() - Method in class org.elasticsearch.index.shard.SnapshotStatus
-
- Translog() - Constructor for class org.elasticsearch.index.shard.SnapshotStatus.Translog
-
- 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(TranslogConfig) - Constructor for class org.elasticsearch.index.translog.Translog
-
Creates a new Translog instance.
- Translog() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
- Translog.Create - Class in org.elasticsearch.index.translog
-
- Translog.Delete - Class in org.elasticsearch.index.translog
-
- Translog.DeleteByQuery - Class in org.elasticsearch.index.translog
-
- Translog.Durabilty - Enum in org.elasticsearch.index.translog
-
- Translog.Index - Class in org.elasticsearch.index.translog
-
- Translog.Location - 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
- Translog.View - Class in org.elasticsearch.index.translog
-
a view into the translog, capturing all translog file at the moment of creation
and updated with any future translog.
- TRANSLOG_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.indices.memory.IndexingMemoryController
-
How much heap (% or bytes) we will share across all actively indexing shards for the translog buffer (default: 1%).
- TRANSLOG_CODEC - Static variable in class org.elasticsearch.index.translog.TranslogWriter
-
- 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.RecoveryTarget.Actions
-
- TRANSLOG_UUID_KEY - Static variable in class org.elasticsearch.index.translog.Translog
-
- TranslogBasedFlush() - Constructor for class org.elasticsearch.index.translog.TranslogService.TranslogBasedFlush
-
- translogBufferSize() - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
-
returns the current budget for the total amount of translog buffers of
active shards on this node
- TranslogConfig - Class in org.elasticsearch.index.translog
-
- TranslogConfig(ShardId, Path, Settings, Translog.Durabilty, BigArrays, ThreadPool) - Constructor for class org.elasticsearch.index.translog.TranslogConfig
-
Creates a new TranslogConfig instance
- TranslogCorruptedException - Exception in org.elasticsearch.index.translog
-
- TranslogCorruptedException(String) - 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
-
- TranslogException - Exception in org.elasticsearch.index.translog
-
- TranslogException(ShardId, String) - Constructor for exception org.elasticsearch.index.translog.TranslogException
-
- TranslogException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TranslogException
-
- TranslogException(StreamInput) - Constructor for exception org.elasticsearch.index.translog.TranslogException
-
- translogFileGeneration - Variable in class org.elasticsearch.index.translog.Translog.TranslogGeneration
-
- translogFiles() - Method in class org.elasticsearch.index.shard.CommitPoint
-
- TranslogGeneration(String, long) - Constructor for class org.elasticsearch.index.translog.Translog.TranslogGeneration
-
- translogLocation - Variable in class org.elasticsearch.index.translog.Translog.Location
-
- translogOps() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- TranslogReader - Class in org.elasticsearch.index.translog
-
A base class for all classes that allows reading ops from translog files
- TranslogReader(long, ChannelReference, long) - Constructor for class org.elasticsearch.index.translog.TranslogReader
-
- TranslogRecoveryPerformer - Class in org.elasticsearch.index.shard
-
The TranslogRecoveryPerformer encapsulates all the logic needed to transform a translog entry into an
indexing operation including source parsing and field creation from the source.
- TranslogRecoveryPerformer(ShardId, MapperService, IndexQueryParserService, IndexAliasesService, IndexCache, ESLogger) - Constructor for class org.elasticsearch.index.shard.TranslogRecoveryPerformer
-
- TranslogRecoveryPerformer.BatchOperationException - Exception in org.elasticsearch.index.shard
-
- TranslogService - Class in org.elasticsearch.index.translog
-
- TranslogService(ShardId, IndexSettingsService, ThreadPool, IndexShard) - Constructor for class org.elasticsearch.index.translog.TranslogService
-
- TranslogService.TranslogBasedFlush - Class in org.elasticsearch.index.translog
-
- translogSize() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
-
- translogStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
- translogStats() - Method in class org.elasticsearch.index.shard.ShadowIndexShard
-
- TranslogStats - Class in org.elasticsearch.index.translog
-
- TranslogStats() - Constructor for class org.elasticsearch.index.translog.TranslogStats
-
- TranslogStats(int, long) - Constructor for class org.elasticsearch.index.translog.TranslogStats
-
- translogUUID - Variable in class org.elasticsearch.index.translog.Translog.TranslogGeneration
-
- TranslogWriter - Class in org.elasticsearch.index.translog
-
- TranslogWriter(ShardId, long, ChannelReference) - Constructor for class org.elasticsearch.index.translog.TranslogWriter
-
- TranslogWriter.Type - Enum in org.elasticsearch.index.translog
-
- transport() - 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.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.stats.NodesStatsRequest
-
Should the node Transport be returned.
- transport - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport.HttpChannelPipelineFactory
-
- transport - Variable in class org.elasticsearch.transport.netty.MessageChannelHandler
-
- Transport - Interface in org.elasticsearch.transport
-
- transport - Variable in class org.elasticsearch.transport.TransportService
-
- Transport.TransportSettings - Class in org.elasticsearch.transport
-
- TRANSPORT_CLIENT_BOSS_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.netty.NettyTransport
-
- TRANSPORT_CLIENT_WORKER_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.netty.NettyTransport
-
- TRANSPORT_LOCAL_ADDRESS - Static variable in class org.elasticsearch.transport.local.LocalTransport
-
- TRANSPORT_LOCAL_QUEUE - Static variable in class org.elasticsearch.transport.local.LocalTransport
-
- TRANSPORT_LOCAL_WORKERS - Static variable in class org.elasticsearch.transport.local.LocalTransport
-
- TRANSPORT_SERVICE_TYPE_KEY - Static variable in class org.elasticsearch.transport.TransportModule
-
- TRANSPORT_TCP_COMPRESS - Static variable in class org.elasticsearch.transport.Transport.TransportSettings
-
- TRANSPORT_TYPE_KEY - Static variable in class org.elasticsearch.transport.TransportModule
-
- 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
-
- 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
-
- TransportActions - Class in org.elasticsearch.action.support
-
- TransportActions() - Constructor for class org.elasticsearch.action.support.TransportActions
-
- TransportAddress - Interface in org.elasticsearch.common.transport
-
- transportAddresses() - Method in class org.elasticsearch.client.transport.TransportClient
-
- transportAddresses() - Method in class org.elasticsearch.client.transport.TransportClientNodesService
-
- TransportAddressSerializers - Class in org.elasticsearch.common.transport
-
A global registry of all different types of
TransportAddress
allowing
to perform serialization of them.
- TransportAddressSerializers() - Constructor for class org.elasticsearch.common.transport.TransportAddressSerializers
-
- 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, IndicesAnalysisService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
-
- TransportBroadcastAction<Request extends BroadcastRequest,Response extends BroadcastResponse,ShardRequest extends BroadcastShardRequest,ShardResponse extends BroadcastShardResponse> - Class in org.elasticsearch.action.support.broadcast
-
- TransportBroadcastAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Class<Request>, Class<ShardRequest>, String) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
-
- TransportBroadcastAction.AsyncBroadcastAction - Class in org.elasticsearch.action.support.broadcast
-
- TransportBroadcastByNodeAction<Request extends BroadcastRequest,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, Class<Request>, String) - 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,Response extends BroadcastResponse,ShardRequest extends ReplicationRequest,ShardResponse extends ActionWriteResponse> - 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, Class<Request>, Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, TransportReplicationAction) - Constructor for class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
-
- TransportBulkAction - Class in org.elasticsearch.action.bulk
-
- TransportBulkAction(Settings, ThreadPool, TransportService, ClusterService, TransportShardBulkAction, TransportCreateIndexAction, ActionFilters, IndexNameExpressionResolver, AutoCreateIndex) - 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, ClusterName, 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(ESLogger, TransportChannel, String) - 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, IndicesRequestCache, 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, SearchServiceTransportAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.search.TransportClearScrollAction
-
- TransportClient - Class in org.elasticsearch.client.transport
-
- TransportClient.Builder - Class in org.elasticsearch.client.transport
-
A builder used to create an instance of the transport client.
- TransportClientNodesService - Class in org.elasticsearch.client.transport
-
- TransportClientNodesService(Settings, ClusterName, TransportService, ThreadPool, Headers, Version) - Constructor for class org.elasticsearch.client.transport.TransportClientNodesService
-
- TransportClientNodesService.NodeListenerCallback<Response> - Interface in org.elasticsearch.client.transport
-
- TransportClientNodesService.RetryListener<Response> - Class in org.elasticsearch.client.transport
-
- TransportCloseIndexAction - Class in org.elasticsearch.action.admin.indices.close
-
Close index action
- TransportCloseIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexStateService, NodeSettingsService, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
-
- TransportClusterHealthAction - Class in org.elasticsearch.action.admin.cluster.health
-
- TransportClusterHealthAction(Settings, TransportService, ClusterService, ThreadPool, ClusterName, ActionFilters, IndexNameExpressionResolver, GatewayAllocator) - Constructor for class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
-
- TransportClusterInfoAction<Request extends ClusterInfoRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.master.info
-
- TransportClusterInfoAction(Settings, String, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Class<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, 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, ClusterName, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
-
- TransportClusterStatsAction - Class in org.elasticsearch.action.admin.cluster.stats
-
- TransportClusterStatsAction(Settings, ClusterName, 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, DynamicSettings, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
-
- transportCompress() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
-
- transportCompress() - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
- transportCompress() - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
- transportCompress() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
-
- transportCompress() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
-
- TransportConnectionListener - Interface in org.elasticsearch.transport
-
- 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
-
Performs the delete operation.
- TransportDeleteAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, TransportCreateIndexAction, ActionFilters, IndexNameExpressionResolver, MappingUpdatedAction, AutoCreateIndex) - Constructor for class org.elasticsearch.action.delete.TransportDeleteAction
-
- TransportDeleteIndexAction - Class in org.elasticsearch.action.admin.indices.delete
-
Delete index action.
- TransportDeleteIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataDeleteIndexService, NodeSettingsService, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
-
- TransportDeleteIndexedScriptAction - Class in org.elasticsearch.action.indexedscripts.delete
-
Performs the delete operation.
- TransportDeleteIndexedScriptAction(Settings, ThreadPool, ScriptService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.indexedscripts.delete.TransportDeleteIndexedScriptAction
-
- 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
-
- TransportDeleteWarmerAction - Class in org.elasticsearch.action.admin.indices.warmer.delete
-
Internal Actions executed on the master deleting the warmer from the cluster state metadata.
- TransportDeleteWarmerAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
-
- TransportDfsOnlyAction - Class in org.elasticsearch.action.termvectors.dfs
-
Get the dfs only with no fetch phase.
- TransportDfsOnlyAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, SearchService, SearchPhaseController) - Constructor for class org.elasticsearch.action.termvectors.dfs.TransportDfsOnlyAction
-
- TransportException - Exception in org.elasticsearch.transport
-
- TransportException(Exception) - Constructor for exception org.elasticsearch.transport.TransportException
-
- TransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.TransportException
-
- TransportException(String) - Constructor for exception org.elasticsearch.transport.TransportException
-
- TransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.TransportException
-
- TransportExistsAction - Class in org.elasticsearch.action.exists
-
- TransportExistsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ScriptService, PageCacheRecycler, BigArrays, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.exists.TransportExistsAction
-
- TransportExplainAction - Class in org.elasticsearch.action.explain
-
Explain transport action.
- TransportExplainAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ScriptService, PageCacheRecycler, BigArrays, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.explain.TransportExplainAction
-
- TransportFieldStatsTransportAction - Class in org.elasticsearch.action.fieldstats
-
- TransportFieldStatsTransportAction(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.action.fieldstats.TransportFieldStatsTransportAction
-
- 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, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
-
- TransportGetIndexedScriptAction - Class in org.elasticsearch.action.indexedscripts.get
-
Performs the get operation.
- TransportGetIndexedScriptAction(Settings, ThreadPool, ScriptService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.indexedscripts.get.TransportGetIndexedScriptAction
-
- 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) - 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) - 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
-
- TransportGetWarmersAction - Class in org.elasticsearch.action.admin.indices.warmer.get
-
Internal Actions executed on the master fetching the warmer from the cluster state metadata.
- TransportGetWarmersAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.warmer.get.TransportGetWarmersAction
-
- TransportIndexAction - Class in org.elasticsearch.action.index
-
Performs the index operation.
- TransportIndexAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, TransportCreateIndexAction, MappingUpdatedAction, ActionFilters, IndexNameExpressionResolver, AutoCreateIndex) - Constructor for class org.elasticsearch.action.index.TransportIndexAction
-
- 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
-
- 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(BoundTransportAddress, Map<String, BoundTransportAddress>) - Constructor for class org.elasticsearch.transport.TransportInfo
-
- TransportInstanceSingleOperationAction<Request extends InstanceShardOperationRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.instance
-
- TransportInstanceSingleOperationAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Class<Request>) - Constructor for class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
- TransportListTasksAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
- TransportListTasksAction(Settings, ClusterName, 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(ClusterName, ClusterService, TransportService) - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.TransportLivenessAction
-
- TransportMasterNodeAction<Request extends MasterNodeRequest,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, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Class<Request>) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeAction
-
- TransportMasterNodeReadAction<Request extends MasterNodeReadRequest,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, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Class<Request>) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
-
- TransportMessage<TM extends TransportMessage<TM>> - Class in org.elasticsearch.transport
-
The transport message is also a
context holder
that holds
transient context, that is,
the context is not serialized with message.
- TransportMessage() - Constructor for class org.elasticsearch.transport.TransportMessage
-
- TransportMessage(TM) - Constructor for class org.elasticsearch.transport.TransportMessage
-
- TransportModule - Class in org.elasticsearch.transport
-
- TransportModule(Settings, NamedWriteableRegistry) - Constructor for class org.elasticsearch.transport.TransportModule
-
- TransportMultiGetAction - Class in org.elasticsearch.action.get
-
- TransportMultiGetAction(Settings, ThreadPool, TransportService, ClusterService, TransportShardMultiGetAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.get.TransportMultiGetAction
-
- TransportMultiPercolateAction - Class in org.elasticsearch.action.percolate
-
- TransportMultiPercolateAction(Settings, ThreadPool, TransportShardMultiPercolateAction, ClusterService, TransportService, PercolatorService, TransportMultiGetAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.percolate.TransportMultiPercolateAction
-
- 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,NodesResponse extends BaseNodesResponse,NodeRequest extends BaseNodeRequest,NodeResponse extends BaseNodeResponse> - Class in org.elasticsearch.action.support.nodes
-
- TransportNodesAction(Settings, String, ClusterName, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Class<NodesRequest>, Class<NodeRequest>, String) - Constructor for class org.elasticsearch.action.support.nodes.TransportNodesAction
-
- TransportNodesHotThreadsAction - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
-
- TransportNodesHotThreadsAction(Settings, ClusterName, 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, ClusterName, 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, ClusterName, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver) - 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, ClusterName, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, NodeEnvironment) - 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, ClusterName, ThreadPool, ClusterService, TransportService, IndicesService, NodeEnvironment, ActionFilters, IndexNameExpressionResolver) - 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
-
- TransportNodesSnapshotsStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Transport client that collects snapshot shard statuses from data nodes
- TransportNodesSnapshotsStatus(Settings, ClusterName, 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, ClusterName, 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
-
- TransportOpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
-
Open index action
- TransportOpenIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexStateService, NodeSettingsService, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
-
- transportOptions(Settings) - Method in class org.elasticsearch.action.bulk.BulkAction
-
- transportOptions() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
-
- transportOptions(Settings) - Method in class org.elasticsearch.action.GenericAction
-
Optional request options for the action.
- transportOptions - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- transportOptions() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- transportOptions() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
- TransportPendingClusterTasksAction - Class in org.elasticsearch.action.admin.cluster.tasks
-
- TransportPendingClusterTasksAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
-
- TransportPercolateAction - Class in org.elasticsearch.action.percolate
-
- TransportPercolateAction(Settings, ThreadPool, ClusterService, TransportService, PercolatorService, TransportGetAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.percolate.TransportPercolateAction
-
- TransportProxyClient - Class in org.elasticsearch.client.transport.support
-
- TransportProxyClient(Settings, TransportService, TransportClientNodesService, Map<String, GenericAction>) - Constructor for class org.elasticsearch.client.transport.support.TransportProxyClient
-
- TransportPutIndexedScriptAction - Class in org.elasticsearch.action.indexedscripts.put
-
Performs the put indexed script operation.
- TransportPutIndexedScriptAction(Settings, ThreadPool, ScriptService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.indexedscripts.put.TransportPutIndexedScriptAction
-
- TransportPutIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
-
Put index template action.
- TransportPutIndexTemplateAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexTemplateService, ActionFilters, IndexNameExpressionResolver) - 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) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
-
- TransportPutRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Transport action for register repository operation
- TransportPutRepositoryAction(Settings, TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
-
- TransportPutWarmerAction - Class in org.elasticsearch.action.admin.indices.warmer.put
-
Internal Actions executed on the master associating a warmer with a name in the cluster state metadata.
- TransportPutWarmerAction(Settings, TransportService, ClusterService, ThreadPool, TransportSearchAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
-
- 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
-
- TransportRenderSearchTemplateAction - Class in org.elasticsearch.action.admin.cluster.validate.template
-
- TransportRenderSearchTemplateAction(ScriptService, Settings, ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.validate.template.TransportRenderSearchTemplateAction
-
- TransportReplicationAction<Request extends ReplicationRequest,ReplicaRequest extends ReplicationRequest,Response extends ActionWriteResponse> - 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, MappingUpdatedAction, ActionFilters, IndexNameExpressionResolver, Class<Request>, Class<ReplicaRequest>, String) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- TransportReplicationAction.RetryOnPrimaryException - Exception in org.elasticsearch.action.support.replication
-
- TransportReplicationAction.RetryOnReplicaException - Exception in org.elasticsearch.action.support.replication
-
- TransportReplicationAction.WriteResult<T extends ActionWriteResponse> - Class in org.elasticsearch.action.support.replication
-
- TransportRequest - Class in org.elasticsearch.transport
-
- TransportRequest() - Constructor for class org.elasticsearch.transport.TransportRequest
-
- TransportRequest(TransportRequest) - Constructor for class org.elasticsearch.transport.TransportRequest
-
- TransportRequest.Empty - Class in org.elasticsearch.transport
-
- TransportRequestHandler<T extends TransportRequest> - Class in org.elasticsearch.transport
-
- TransportRequestHandler() - Constructor for class org.elasticsearch.transport.TransportRequestHandler
-
- TransportRequestOptions - Class in org.elasticsearch.transport
-
- TransportRequestOptions.Builder - Class in org.elasticsearch.transport
-
- TransportRequestOptions.Type - Enum in org.elasticsearch.transport
-
- TransportResponse - Class in org.elasticsearch.transport
-
- TransportResponse() - Constructor for class org.elasticsearch.transport.TransportResponse
-
- TransportResponse(TransportResponse) - Constructor for class org.elasticsearch.transport.TransportResponse
-
- TransportResponse.Empty - Class in org.elasticsearch.transport
-
- TransportResponseHandler<T extends TransportResponse> - Interface in org.elasticsearch.transport
-
- TransportResponseOptions - Class in org.elasticsearch.transport
-
- TransportResponseOptions.Builder - Class 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
-
- Transports - Enum in org.elasticsearch.transport
-
- TransportSearchAction - Class in org.elasticsearch.action.search
-
- TransportSearchAction(Settings, ThreadPool, SearchPhaseController, TransportService, SearchServiceTransportAction, ClusterService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.search.TransportSearchAction
-
- TransportSearchScrollAction - Class in org.elasticsearch.action.search
-
- TransportSearchScrollAction(Settings, ThreadPool, TransportService, ClusterService, SearchServiceTransportAction, SearchPhaseController, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.search.TransportSearchScrollAction
-
- TransportSerializationException - Exception in org.elasticsearch.transport
-
- TransportSerializationException(StreamInput) - Constructor for exception org.elasticsearch.transport.TransportSerializationException
-
- TransportSerializationException(String, Throwable) - Constructor for exception org.elasticsearch.transport.TransportSerializationException
-
- transportService - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
-
- transportService - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeAction
-
- transportService - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
- transportService - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
- transportService - Variable in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
- transportService - Variable in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
- transportService - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
- transportService - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
-
- TransportService - Class in org.elasticsearch.transport
-
- TransportService(Transport, ThreadPool) - Constructor for class org.elasticsearch.transport.TransportService
-
- TransportService(Settings, Transport, ThreadPool) - Constructor for class org.elasticsearch.transport.TransportService
-
- TransportService.Adapter - Class in org.elasticsearch.transport
-
- transportServiceAdapter(TransportServiceAdapter) - Method in class org.elasticsearch.transport.local.LocalTransport
-
- transportServiceAdapter - Variable in class org.elasticsearch.transport.netty.MessageChannelHandler
-
- transportServiceAdapter - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- transportServiceAdapter(TransportServiceAdapter) - Method in class org.elasticsearch.transport.netty.NettyTransport
-
- transportServiceAdapter(TransportServiceAdapter) - Method in interface org.elasticsearch.transport.Transport
-
- TransportServiceAdapter - Interface in org.elasticsearch.transport
-
- TransportSettings() - Constructor for class org.elasticsearch.transport.Transport.TransportSettings
-
- TransportShardBulkAction - Class in org.elasticsearch.action.bulk
-
Performs the index operation.
- TransportShardBulkAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, MappingUpdatedAction, UpdateHelper, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.bulk.TransportShardBulkAction
-
- TransportShardFlushAction - Class in org.elasticsearch.action.admin.indices.flush
-
- TransportShardFlushAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, MappingUpdatedAction, 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
-
- TransportShardMultiPercolateAction - Class in org.elasticsearch.action.percolate
-
- TransportShardMultiPercolateAction(Settings, ThreadPool, ClusterService, TransportService, PercolatorService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
-
- TransportShardMultiPercolateAction.Request - Class in org.elasticsearch.action.percolate
-
- TransportShardMultiPercolateAction.Response - Class in org.elasticsearch.action.percolate
-
- TransportShardMultiPercolateAction.Response.Item - Class in org.elasticsearch.action.percolate
-
- 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, MappingUpdatedAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
-
- TransportSingleShardAction<Request extends SingleShardRequest,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, Class<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
-
- TransportStatus - Class in org.elasticsearch.transport.support
-
- TransportStatus() - Constructor for class org.elasticsearch.transport.support.TransportStatus
-
- TransportSuggestAction - Class in org.elasticsearch.action.suggest
-
Defines the transport of a suggestion request across the cluster
- TransportSuggestAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, SuggestPhase, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.suggest.TransportSuggestAction
-
- 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<TaskResponse>> - Class in org.elasticsearch.action.support.tasks
-
The base class for transport actions that are interacting with currently running tasks.
- TransportTasksAction(Settings, String, ClusterName, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Callable<TasksRequest>, 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, TransportIndexAction, TransportDeleteAction, 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, IndicesService, ScriptService, PageCacheRecycler, BigArrays, 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, ClusterName, TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
-
- transpositions(boolean) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
-
- transpositions - Variable in class org.elasticsearch.index.search.MatchQuery
-
- TREE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
-
- tree() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- TREE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
-
- TREE_GEOHASH - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
-
- TREE_LEVELS - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
-
- TREE_PRESISION - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
-
- TREE_QUADTREE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
-
- treeLevels() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- TRIBE_METADATA_BLOCK - Static variable in class org.elasticsearch.tribe.TribeService
-
- TRIBE_NAME - Static variable in class org.elasticsearch.tribe.TribeService
-
- TRIBE_WRITE_BLOCK - Static variable in class org.elasticsearch.tribe.TribeService
-
- TribeModule - Class in org.elasticsearch.tribe
-
- TribeModule() - Constructor for class org.elasticsearch.tribe.TribeModule
-
- TribeService - Class in org.elasticsearch.tribe
-
The tribe service holds a list of node clients connected to a list of tribe members, and uses their
cluster state events to update this local node cluster state with the merged view of it.
- TribeService(Settings, ClusterService, DiscoveryService) - Constructor for class org.elasticsearch.tribe.TribeService
-
- TrieNode(String, T, PathTrie.TrieNode, String) - Constructor for class org.elasticsearch.common.path.PathTrie.TrieNode
-
- 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.
- trimLeadingWhitespace(String) - Static method in class org.elasticsearch.common.Strings
-
Trim leading whitespace from the given String.
- TrimTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- TrimTokenFilterFactory(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.TrimTokenFilterFactory
-
- TRUE - Static variable in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Values
-
- TruncatedTranslogException - Exception in org.elasticsearch.index.translog
-
- TruncatedTranslogException(String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TruncatedTranslogException
-
- TruncatedTranslogException(StreamInput) - Constructor for exception org.elasticsearch.index.translog.TruncatedTranslogException
-
- TruncateTokenFilterFactory - Class in org.elasticsearch.index.analysis
-
- TruncateTokenFilterFactory(Index, IndexSettingsService, String, Settings) - Constructor for class org.elasticsearch.index.analysis.TruncateTokenFilterFactory
-
- 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) - Static method in class org.elasticsearch.index.store.Store
-
Tries to open an index for the given location.
- ttf() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
-
- 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).
- ttl(long) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the relative ttl value in milliseconds.
- ttl(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
- ttl(TimeValue) - Method in class org.elasticsearch.action.index.IndexRequest
-
- ttl() - Method in class org.elasticsearch.action.index.IndexRequest
-
- ttl() - Method in exception org.elasticsearch.index.AlreadyExpiredException
-
- ttl() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- ttl() - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- ttl() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- ttl(TimeValue) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- ttl(long) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- ttl() - Method in class org.elasticsearch.index.translog.Translog.Create
-
- ttl() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- ttl - Variable in class org.elasticsearch.index.translog.Translog.Source
-
- TTL_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
-
- TTLFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- TTLFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
- TTLFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- TTLFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- TTLFieldMapper.TTLFieldType - Class in org.elasticsearch.index.mapper.internal
-
- TTLFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- TTLFieldType() - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper.TTLFieldType
-
- TTLFieldType(TTLFieldMapper.TTLFieldType) - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper.TTLFieldType
-
- Tuple<V1,V2> - Class in org.elasticsearch.common.collect
-
- Tuple(V1, V2) - Constructor for class org.elasticsearch.common.collect.Tuple
-
- tuple(V1, V2) - Static method in class org.elasticsearch.common.collect.Tuple
-
- TurkishAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
- TurkishAnalyzerProvider(Index, IndexSettingsService, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.TurkishAnalyzerProvider
-
- 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(long, TimeUnit) - 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 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(String) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
-
- type() - 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() - 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(String) - 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(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The type of the mappings.
- type() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
The type of the document to delete.
- type(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Sets the type of the document to delete.
- type() - Method in interface org.elasticsearch.action.DocumentRequest
-
Get the type that this request operates on
- type() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- 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() - Method in class org.elasticsearch.action.get.GetRequest
-
- type() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- type(String) - 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(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() - 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(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the type of the indexed document.
- TYPE - Static variable in class org.elasticsearch.cache.recycler.PageCacheRecycler
-
- type() - Method in interface org.elasticsearch.cluster.ClusterState.Custom
-
- type() - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom
-
- type() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
-
- type() - Method in interface org.elasticsearch.cluster.metadata.MetaData.Custom
-
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
-
- type() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
- type() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
-
Returns repository type
- TYPE - Static variable in class org.elasticsearch.cluster.RestoreInProgress
-
- type() - Method in class org.elasticsearch.cluster.RestoreInProgress
- 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
-
- type() - Method in enum org.elasticsearch.cluster.routing.Preference
-
- TYPE - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress
-
- type() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
-
- type() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder.Ring
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.CircleBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.LineStringBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.LineStringBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder.InternalLineStringBuilder
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.MultiPointBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.MultiPointBuilder
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
-
- TYPE - Static variable in class org.elasticsearch.common.geo.builders.PointBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
-
- type() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
-
get the shapes type
- type() - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
-
- type() - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
-
- type() - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
-
- type() - Method in interface org.elasticsearch.common.xcontent.XContent
-
The type this content handles and produces.
- type() - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
-
- type - Variable in class org.elasticsearch.gateway.AsyncShardFetch
-
- type() - Method in exception org.elasticsearch.index.AlreadyExpiredException
-
- type() - Method in exception org.elasticsearch.index.engine.CreateFailedEngineException
-
- type() - Method in class org.elasticsearch.index.engine.Engine.Delete
-
- type() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- type() - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
-
- TYPE - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
-
- TYPE - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
-
- type() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- type(String) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
-
- type() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
-
- type() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
-
- type() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- type() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- type() - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- type() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- type(String) - Method in class org.elasticsearch.index.mapper.SourceToParse
-
- type() - Method in class org.elasticsearch.index.mapper.Uid
-
- type(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Sets the type of executing of the geo bounding box.
- type(MatchQueryBuilder.Type) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets the type of the text query.
- TYPE - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item.Field
-
- type() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- type(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- type(MultiMatchQueryBuilder.Type) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the type of the text query.
- type(Object) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the type of the text query.
- type() - Method in class org.elasticsearch.index.shard.CommitPoint
-
- type() - Method in class org.elasticsearch.index.translog.Translog.Create
-
- type() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- type(String) - Method in class org.elasticsearch.monitor.jvm.HotThreads
-
- TYPE - Static variable in class org.elasticsearch.repositories.fs.FsRepository
-
- type() - Method in class org.elasticsearch.repositories.RepositoryName
-
- TYPE - Static variable in class org.elasticsearch.repositories.uri.URLRepository
-
- type() - Method in class org.elasticsearch.script.CompiledScript
-
Method to get the type of language.
- type - Variable in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
- type() - Method in interface org.elasticsearch.search.aggregations.Aggregator.Parser
-
- type - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.children.ChildrenParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.children.InternalChildren
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.children.InternalChildren
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramParser
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramParser
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Factory
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedParser
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedParser
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeParser
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Factory
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceParser
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance.Factory
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Factory
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IpRangeParser
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
- type() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
- Type(String) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation.Type
-
- Type(String, String) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation.Type
-
- Type(String, BytesReference) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation.Type
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.GeoCentroidParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.geocentroid.InternalGeoCentroid
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.NumericValuesSourceMetricsAggregatorParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentileRanks
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.hdr.InternalHDRPercentiles
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksParser
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentileRanks
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.InternalTDigestPercentiles
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
-
- type() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountParser
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.avg.AvgBucketPipelineAggregator
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.InternalBucketMetricValue
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.max.MaxBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.min.MinBucketPipelineAggregator
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.PercentilesBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.ExtendedStatsBucketPipelineAggregator
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.InternalExtendedStatsBucket
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.extended.InternalExtendedStatsBucket
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.InternalStatsBucket
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.stats.StatsBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.sum.SumBucketPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.bucketscript.BucketScriptPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.cumulativesum.CumulativeSumPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativeParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.DerivativePipelineAggregator
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.derivative.InternalDerivative
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.having.BucketSelectorPipelineAggregator
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.movavg.MovAvgPipelineAggregator
-
- type() - Method in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
- type - Variable in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorFactory
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffParser
-
- TYPE - Static variable in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.serialdiff.SerialDiffPipelineAggregator
-
- type() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- type() - Method in interface org.elasticsearch.search.SearchHit
-
The type of the document.
- TYPE - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
-
- TYPE - Static variable in class org.elasticsearch.search.suggest.context.CategoryContextMapping
-
- type - Variable in class org.elasticsearch.search.suggest.context.ContextMapping
-
- type() - Method in class org.elasticsearch.search.suggest.context.ContextMapping
-
- TYPE - Static variable in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
-
- 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 - Static variable in class org.elasticsearch.search.warmer.IndexWarmersMetaData
-
- type() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData
-
- type() - Method in class org.elasticsearch.transport.TransportRequestOptions
-
- TYPE_KEY - Static variable in class org.elasticsearch.indices.breaker.CircuitBreakerModule
-
- TYPE_NAME - Static variable in class org.elasticsearch.percolator.PercolatorService
-
- 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
-
- 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.
- TypeEncounter<I> - Interface in org.elasticsearch.common.inject.spi
-
Context of an injectable type encounter.
- TypeFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
- TypeFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- TypeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- TypeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- typeFilter() - 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(Index, String...) - Constructor for exception org.elasticsearch.indices.TypeMissingException
-
- TypeMissingException(StreamInput) - Constructor for exception org.elasticsearch.indices.TypeMissingException
-
- typeName() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.BooleanFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.DoubleFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.LongFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.StringFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.GeoPointFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.FieldNamesFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- typeName() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the name of this type, as would be specified in mapping properties
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.CompletionFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.TokenCountFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.geo.BaseGeoPointFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.VersionFieldMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.TypeParser
-
- typeParser(String) - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
-
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.object.RootObjectMapper.TypeParser
-
- TypeParsers - Class in org.elasticsearch.index.mapper.core
-
- TypeParsers() - Constructor for class org.elasticsearch.index.mapper.core.TypeParsers
-
- typeParsers() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
-
- typePrefixAsBytes(BytesRef) - Static method in class org.elasticsearch.index.mapper.Uid
-
- 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
-
- TypeQueryParser - Class in org.elasticsearch.index.query
-
- TypeQueryParser() - Constructor for class org.elasticsearch.index.query.TypeQueryParser
-
- types() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
The document types to execute the search against.
- types(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
The document types to execute the search against.
- types() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
-
- types(String[]) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
-
- types() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
-
- types(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
- types() - 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() - 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() - 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(String...) - 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.count.CountRequest
-
Deprecated.
The types of documents the query will run against.
- types(String...) - Method in class org.elasticsearch.action.count.CountRequest
-
Deprecated.
The types of documents the query will run against.
- types() - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
The types of documents the query will run against.
- types(String...) - Method in class org.elasticsearch.action.exists.ExistsRequest
-
Deprecated.
The types of documents the query will run against.
- types() - Method in class org.elasticsearch.action.exists.ShardExistsRequest
-
- types() - Method in class org.elasticsearch.action.search.SearchRequest
-
The document types to execute the search 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() - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
-
- types() - Method in class org.elasticsearch.action.termvectors.dfs.DfsOnlyRequest
-
- types() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
-
- Types - Class in org.elasticsearch.common.inject.util
-
Static methods for working with types.
- types() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
-
- types() - Method in interface org.elasticsearch.index.fielddata.AtomicParentChildFieldData
-
Return the set of types there is a mapping for.
- types() - Method in class org.elasticsearch.index.fielddata.plain.ParentChildAtomicFieldData
-
- 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.translog.Translog.DeleteByQuery
-
Deprecated.
- types() - Method in class org.elasticsearch.percolator.PercolateContext
-
- types(String[]) - Method in class org.elasticsearch.percolator.PercolateContext
-
- types() - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
-
- types() - Method in class org.elasticsearch.script.NativeScriptEngineService
-
- types() - Method in interface org.elasticsearch.script.ScriptEngineService
-
- types() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- types() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- types() - Method in class org.elasticsearch.search.internal.SearchContext
-
- 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() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
-
- 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
-
- 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
-
- typeText() - Method in class org.elasticsearch.index.mapper.DocumentMapper
-
- v() - Method in class org.elasticsearch.common.recycler.NoneRecycler.NV
-
- v() - Method in interface org.elasticsearch.common.recycler.Recycler.V
-
Reference to the value.
- v1() - Method in class org.elasticsearch.common.collect.Tuple
-
- v2() - Method in class org.elasticsearch.common.collect.Tuple
-
- V_0_18_0 - Static variable in class org.elasticsearch.Version
-
- V_0_18_0_ID - Static variable in class org.elasticsearch.Version
-
- V_0_18_1 - Static variable in class org.elasticsearch.Version
-
- V_0_18_1_ID - Static variable in class org.elasticsearch.Version
-
- V_0_18_2 - Static variable in class org.elasticsearch.Version
-
- V_0_18_2_ID - Static variable in class org.elasticsearch.Version
-
- V_0_18_3 - Static variable in class org.elasticsearch.Version
-
- V_0_18_3_ID - Static variable in class org.elasticsearch.Version
-
- V_0_18_4 - Static variable in class org.elasticsearch.Version
-
- V_0_18_4_ID - Static variable in class org.elasticsearch.Version
-
- V_0_18_5 - Static variable in class org.elasticsearch.Version
-
- V_0_18_5_ID - Static variable in class org.elasticsearch.Version
-
- V_0_18_6 - Static variable in class org.elasticsearch.Version
-
- V_0_18_6_ID - Static variable in class org.elasticsearch.Version
-
- V_0_18_7 - Static variable in class org.elasticsearch.Version
-
- V_0_18_7_ID - Static variable in class org.elasticsearch.Version
-
- V_0_18_8 - Static variable in class org.elasticsearch.Version
-
- V_0_18_8_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_0 - Static variable in class org.elasticsearch.Version
-
- V_0_19_0_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_0_RC1 - Static variable in class org.elasticsearch.Version
-
- V_0_19_0_RC1_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_0_RC2 - Static variable in class org.elasticsearch.Version
-
- V_0_19_0_RC2_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_0_RC3 - Static variable in class org.elasticsearch.Version
-
- V_0_19_0_RC3_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_1 - Static variable in class org.elasticsearch.Version
-
- V_0_19_10 - Static variable in class org.elasticsearch.Version
-
- V_0_19_10_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_11 - Static variable in class org.elasticsearch.Version
-
- V_0_19_11_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_12 - Static variable in class org.elasticsearch.Version
-
- V_0_19_12_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_13 - Static variable in class org.elasticsearch.Version
-
- V_0_19_13_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_1_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_2 - Static variable in class org.elasticsearch.Version
-
- V_0_19_2_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_3 - Static variable in class org.elasticsearch.Version
-
- V_0_19_3_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_4 - Static variable in class org.elasticsearch.Version
-
- V_0_19_4_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_5 - Static variable in class org.elasticsearch.Version
-
- V_0_19_5_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_6 - Static variable in class org.elasticsearch.Version
-
- V_0_19_6_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_7 - Static variable in class org.elasticsearch.Version
-
- V_0_19_7_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_8 - Static variable in class org.elasticsearch.Version
-
- V_0_19_8_ID - Static variable in class org.elasticsearch.Version
-
- V_0_19_9 - Static variable in class org.elasticsearch.Version
-
- V_0_19_9_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_0 - Static variable in class org.elasticsearch.Version
-
- V_0_20_0_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_0_RC1 - Static variable in class org.elasticsearch.Version
-
- V_0_20_0_RC1_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_1 - Static variable in class org.elasticsearch.Version
-
- V_0_20_1_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_2 - Static variable in class org.elasticsearch.Version
-
- V_0_20_2_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_3 - Static variable in class org.elasticsearch.Version
-
- V_0_20_3_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_4 - Static variable in class org.elasticsearch.Version
-
- V_0_20_4_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_5 - Static variable in class org.elasticsearch.Version
-
- V_0_20_5_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_6 - Static variable in class org.elasticsearch.Version
-
- V_0_20_6_ID - Static variable in class org.elasticsearch.Version
-
- V_0_20_7 - Static variable in class org.elasticsearch.Version
-
- V_0_20_7_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_0 - Static variable in class org.elasticsearch.Version
-
- V_0_90_0_Beta1 - Static variable in class org.elasticsearch.Version
-
- V_0_90_0_Beta1_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_0_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_0_RC1 - Static variable in class org.elasticsearch.Version
-
- V_0_90_0_RC1_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_0_RC2 - Static variable in class org.elasticsearch.Version
-
- V_0_90_0_RC2_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_1 - Static variable in class org.elasticsearch.Version
-
- V_0_90_10 - Static variable in class org.elasticsearch.Version
-
- V_0_90_10_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_11 - Static variable in class org.elasticsearch.Version
-
- V_0_90_11_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_12 - Static variable in class org.elasticsearch.Version
-
- V_0_90_12_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_13 - Static variable in class org.elasticsearch.Version
-
- V_0_90_13_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_14 - Static variable in class org.elasticsearch.Version
-
- V_0_90_14_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_1_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_2 - Static variable in class org.elasticsearch.Version
-
- V_0_90_2_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_3 - Static variable in class org.elasticsearch.Version
-
- V_0_90_3_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_4 - Static variable in class org.elasticsearch.Version
-
- V_0_90_4_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_5 - Static variable in class org.elasticsearch.Version
-
- V_0_90_5_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_6 - Static variable in class org.elasticsearch.Version
-
- V_0_90_6_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_7 - Static variable in class org.elasticsearch.Version
-
- V_0_90_7_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_8 - Static variable in class org.elasticsearch.Version
-
- V_0_90_8_ID - Static variable in class org.elasticsearch.Version
-
- V_0_90_9 - Static variable in class org.elasticsearch.Version
-
- V_0_90_9_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_0 - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_Beta1 - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_Beta1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_Beta2 - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_Beta2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_RC1 - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_RC1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_RC2 - Static variable in class org.elasticsearch.Version
-
- V_1_0_0_RC2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_1 - Static variable in class org.elasticsearch.Version
-
- V_1_0_1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_2 - Static variable in class org.elasticsearch.Version
-
- V_1_0_2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_3 - Static variable in class org.elasticsearch.Version
-
- V_1_0_3_ID - Static variable in class org.elasticsearch.Version
-
- V_1_0_4 - Static variable in class org.elasticsearch.Version
-
- V_1_0_4_ID - Static variable in class org.elasticsearch.Version
-
- V_1_1_0 - Static variable in class org.elasticsearch.Version
-
- V_1_1_0_ID - Static variable in class org.elasticsearch.Version
-
- V_1_1_1 - Static variable in class org.elasticsearch.Version
-
- V_1_1_1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_1_2 - Static variable in class org.elasticsearch.Version
-
- V_1_1_2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_2_0 - Static variable in class org.elasticsearch.Version
-
- V_1_2_0_ID - Static variable in class org.elasticsearch.Version
-
- V_1_2_1 - Static variable in class org.elasticsearch.Version
-
- V_1_2_1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_2_2 - Static variable in class org.elasticsearch.Version
-
- V_1_2_2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_2_3 - Static variable in class org.elasticsearch.Version
-
- V_1_2_3_ID - Static variable in class org.elasticsearch.Version
-
- V_1_2_4 - Static variable in class org.elasticsearch.Version
-
- V_1_2_4_ID - Static variable in class org.elasticsearch.Version
-
- V_1_2_5 - Static variable in class org.elasticsearch.Version
-
- V_1_2_5_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_0 - Static variable in class org.elasticsearch.Version
-
- V_1_3_0_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_1 - Static variable in class org.elasticsearch.Version
-
- V_1_3_10 - Static variable in class org.elasticsearch.Version
-
- V_1_3_10_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_2 - Static variable in class org.elasticsearch.Version
-
- V_1_3_2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_3 - Static variable in class org.elasticsearch.Version
-
- V_1_3_3_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_4 - Static variable in class org.elasticsearch.Version
-
- V_1_3_4_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_5 - Static variable in class org.elasticsearch.Version
-
- V_1_3_5_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_6 - Static variable in class org.elasticsearch.Version
-
- V_1_3_6_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_7 - Static variable in class org.elasticsearch.Version
-
- V_1_3_7_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_8 - Static variable in class org.elasticsearch.Version
-
- V_1_3_8_ID - Static variable in class org.elasticsearch.Version
-
- V_1_3_9 - Static variable in class org.elasticsearch.Version
-
- V_1_3_9_ID - Static variable in class org.elasticsearch.Version
-
- V_1_4_0 - Static variable in class org.elasticsearch.Version
-
- V_1_4_0_Beta1 - Static variable in class org.elasticsearch.Version
-
- V_1_4_0_Beta1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_4_0_ID - Static variable in class org.elasticsearch.Version
-
- V_1_4_1 - Static variable in class org.elasticsearch.Version
-
- V_1_4_1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_4_2 - Static variable in class org.elasticsearch.Version
-
- V_1_4_2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_4_3 - Static variable in class org.elasticsearch.Version
-
- V_1_4_3_ID - Static variable in class org.elasticsearch.Version
-
- V_1_4_4 - Static variable in class org.elasticsearch.Version
-
- V_1_4_4_ID - Static variable in class org.elasticsearch.Version
-
- V_1_4_5 - Static variable in class org.elasticsearch.Version
-
- V_1_4_5_ID - Static variable in class org.elasticsearch.Version
-
- V_1_4_6 - Static variable in class org.elasticsearch.Version
-
- V_1_4_6_ID - Static variable in class org.elasticsearch.Version
-
- V_1_5_0 - Static variable in class org.elasticsearch.Version
-
- V_1_5_0_ID - Static variable in class org.elasticsearch.Version
-
- V_1_5_1 - Static variable in class org.elasticsearch.Version
-
- V_1_5_1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_5_2 - Static variable in class org.elasticsearch.Version
-
- V_1_5_2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_5_3 - Static variable in class org.elasticsearch.Version
-
- V_1_5_3_ID - Static variable in class org.elasticsearch.Version
-
- V_1_6_0 - Static variable in class org.elasticsearch.Version
-
- V_1_6_0_ID - Static variable in class org.elasticsearch.Version
-
- V_1_6_1 - Static variable in class org.elasticsearch.Version
-
- V_1_6_1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_6_2 - Static variable in class org.elasticsearch.Version
-
- V_1_6_2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_6_3 - Static variable in class org.elasticsearch.Version
-
- V_1_6_3_ID - Static variable in class org.elasticsearch.Version
-
- V_1_7_0 - Static variable in class org.elasticsearch.Version
-
- V_1_7_0_ID - Static variable in class org.elasticsearch.Version
-
- V_1_7_1 - Static variable in class org.elasticsearch.Version
-
- V_1_7_1_ID - Static variable in class org.elasticsearch.Version
-
- V_1_7_2 - Static variable in class org.elasticsearch.Version
-
- V_1_7_2_ID - Static variable in class org.elasticsearch.Version
-
- V_1_7_3 - Static variable in class org.elasticsearch.Version
-
- V_1_7_3_ID - Static variable in class org.elasticsearch.Version
-
- V_1_7_4 - Static variable in class org.elasticsearch.Version
-
- V_1_7_4_ID - Static variable in class org.elasticsearch.Version
-
- V_1_7_5 - Static variable in class org.elasticsearch.Version
-
- V_1_7_5_ID - Static variable in class org.elasticsearch.Version
-
- V_1_7_6 - Static variable in class org.elasticsearch.Version
-
- V_1_7_6_ID - Static variable in class org.elasticsearch.Version
-
- V_2_0_0 - Static variable in class org.elasticsearch.Version
-
- V_2_0_0_beta1 - Static variable in class org.elasticsearch.Version
-
- V_2_0_0_beta1_ID - Static variable in class org.elasticsearch.Version
-
- V_2_0_0_beta2 - Static variable in class org.elasticsearch.Version
-
- V_2_0_0_beta2_ID - Static variable in class org.elasticsearch.Version
-
- V_2_0_0_ID - Static variable in class org.elasticsearch.Version
-
- V_2_0_0_rc1 - Static variable in class org.elasticsearch.Version
-
- V_2_0_0_rc1_ID - Static variable in class org.elasticsearch.Version
-
- V_2_0_1 - Static variable in class org.elasticsearch.Version
-
- V_2_0_1_ID - Static variable in class org.elasticsearch.Version
-
- V_2_0_2 - Static variable in class org.elasticsearch.Version
-
- V_2_0_2_ID - Static variable in class org.elasticsearch.Version
-
- V_2_0_3 - Static variable in class org.elasticsearch.Version
-
- V_2_0_3_ID - Static variable in class org.elasticsearch.Version
-
- V_2_1_0 - Static variable in class org.elasticsearch.Version
-
- V_2_1_0_ID - Static variable in class org.elasticsearch.Version
-
- V_2_1_1 - Static variable in class org.elasticsearch.Version
-
- V_2_1_1_ID - Static variable in class org.elasticsearch.Version
-
- V_2_1_2 - Static variable in class org.elasticsearch.Version
-
- V_2_1_2_ID - Static variable in class org.elasticsearch.Version
-
- V_2_1_3 - Static variable in class org.elasticsearch.Version
-
- V_2_1_3_ID - Static variable in class org.elasticsearch.Version
-
- V_2_2_0 - Static variable in class org.elasticsearch.Version
-
- V_2_2_0_ID - Static variable in class org.elasticsearch.Version
-
- V_2_2_1 - Static variable in class org.elasticsearch.Version
-
- V_2_2_1_ID - Static variable in class org.elasticsearch.Version
-
- V_2_2_2 - Static variable in class org.elasticsearch.Version
-
- V_2_2_2_ID - Static variable in class org.elasticsearch.Version
-
- V_2_2_3 - Static variable in class org.elasticsearch.Version
-
- V_2_2_3_ID - Static variable in class org.elasticsearch.Version
-
- V_2_3_0 - Static variable in class org.elasticsearch.Version
-
- V_2_3_0_ID - Static variable in class org.elasticsearch.Version
-
- V_2_3_1 - Static variable in class org.elasticsearch.Version
-
- V_2_3_1_ID - Static variable in class org.elasticsearch.Version
-
- V_2_3_2 - Static variable in class org.elasticsearch.Version
-
- V_2_3_2_ID - Static variable in class org.elasticsearch.Version
-
- valid() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Is this a valid nodes that has the minimal information set.
- valid() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
-
- valid() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- VALID_AGG_NAME - Static variable in class org.elasticsearch.search.aggregations.AggregatorParsers
-
- validate() - Method in class org.elasticsearch.action.ActionRequest
-
- 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.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.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.tasks.PendingClusterTasksRequest
-
- validate() - Method in class org.elasticsearch.action.admin.cluster.validate.template.RenderSearchTemplateRequest
-
- 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.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.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.admin.indices.warmer.delete.DeleteWarmerRequest
-
- validate() - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequest
-
- validate() - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
-
- 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.exists.ExistsRequest
-
Deprecated.
- validate() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
- validate() - Method in class org.elasticsearch.action.fieldstats.FieldStatsRequest
-
- 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.indexedscripts.delete.DeleteIndexedScriptRequest
-
- validate() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- validate() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- validate() - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
-
- validate() - Method in class org.elasticsearch.action.percolate.PercolateRequest
-
- validate() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Request
-
- 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.suggest.SuggestRequest
-
- 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 class org.elasticsearch.action.termvectors.dfs.DfsOnlyRequest
-
- 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(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateObserver.ValidationPredicate
-
- validate(RoutingTableValidation, MetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
- validate(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
validate based on a meta data, returning failures found
- validate() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
- validate(MetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- validate(String, String, ClusterState) - Method in interface org.elasticsearch.cluster.settings.Validator
-
- validate() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
-
- validate() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Validates the state of this factory (makes sure the factory is properly configured)
- validate(AggregatorFactory, AggregatorFactory[], List<PipelineAggregatorFactory>) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregatorFactory
-
Validates the state of this factory (makes sure the factory is properly
configured)
- validate(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Validates this path over the given aggregator as a point of reference.
- ValidateActions - Class in org.elasticsearch.action
-
- ValidateActions() - Constructor for class org.elasticsearch.action.ValidateActions
-
- 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.
- validateAliasAction(AliasAction, MetaData) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Allows to validate an
AliasAction
and make sure
it's valid before it gets added to the index metadata.
- validateAliasFilter(String, String, IndexQueryParserService) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
- validateAliasFilter(String, byte[], IndexQueryParserService) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
- 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.
- validateDynamicSetting(String, String, ClusterState) - Method in class org.elasticsearch.cluster.settings.DynamicSettings
-
- validateFlags(int) - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
-
- validateHole(BaseLineStringBuilder, BaseLineStringBuilder) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
-
Validates only 1 vertex is tangential (shared) between the interior and exterior of a polygon
- validateIndexName(String, ClusterState) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
-
- validateIndexSettings(String, Settings) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
-
- ValidateJoinRequest() - Constructor for class org.elasticsearch.discovery.zen.membership.MembershipAction.ValidateJoinRequest
-
- ValidateJoinRequest(ClusterState) - Constructor for class org.elasticsearch.discovery.zen.membership.MembershipAction.ValidateJoinRequest
-
- validateMultiPointNode(ShapeBuilder.CoordinateNode) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- validateNonNullIndex() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
- validatePointNode(ShapeBuilder.CoordinateNode) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
-
- 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.
- validateRaiseException(MetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- validateSettings(BreakerSettings[]) - Static method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
-
Validate that child settings are valid
- 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 exception org.elasticsearch.cluster.routing.RoutingValidationException
-
- 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
-
- ValidationPredicate() - Constructor for class org.elasticsearch.cluster.ClusterStateObserver.ValidationPredicate
-
- Validator - Interface in org.elasticsearch.cluster.settings
-
Validates a setting, returning a failure message if applicable.
- validFileName(String) - Static method in class org.elasticsearch.common.Strings
-
- validFileNameExcludingAstrix(String) - Static method in class org.elasticsearch.common.Strings
-
- validName(String) - Method in enum org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
-
- validWatermarkSetting(String, String) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Checks if a watermark string is a valid percentage or byte size value,
returning true if valid, false if invalid.
- 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.shards.IndicesShardStoresResponse.StoreStatus.Allocation
-
- value() - Method in class org.elasticsearch.cluster.ClusterName
-
- value() - Method in enum org.elasticsearch.cluster.health.ClusterHealthStatus
-
- value() - Method in enum org.elasticsearch.cluster.metadata.AliasAction.Type
-
- value() - Method in enum org.elasticsearch.cluster.RestoreInProgress.State
-
Returns state code
- value() - Method in enum org.elasticsearch.cluster.routing.ShardRoutingState
-
- value() - Method in enum org.elasticsearch.cluster.SnapshotsInProgress.State
-
- value() - Method in class org.elasticsearch.common.Explicit
-
- 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.concurrent.AtomicArray.Entry
-
The value.
- value - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
-
- value(Object) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Boolean) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(boolean) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(ReadableInstant) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(ReadableInstant, DateTimeFormatter) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Date) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Date, DateTimeFormatter) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Integer) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(int) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Float) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(float) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(String) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(byte[]) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(byte[], int, int) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(BytesRef) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Text) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Map<String, Object>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- value(Iterable<?>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
-
- Value(BitSet, ShardId) - Constructor for class org.elasticsearch.index.cache.bitset.BitsetFilterCache.Value
-
- value(Object) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.BooleanFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.CompletionFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.DoubleFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.IntegerFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.LongFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.NumberFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.StringFieldType
-
- value() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.ValueAndBoost
-
Value of string field.
- value(Object) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.GeoShapeFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.FieldNamesFieldType
-
- value(Document) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
-
- value(Document) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
-
- value(Object) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
- value(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the actual value of the field.
- value() - Method in enum org.elasticsearch.index.query.RegexpFlag
-
- value() - Method in enum org.elasticsearch.index.query.SimpleQueryStringFlag
-
- value - Variable in class org.elasticsearch.indices.cache.request.IndicesRequestCache.Key
-
- Value(BytesReference, long) - Constructor for class org.elasticsearch.indices.cache.request.IndicesRequestCache.Value
-
- value - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
-
- VALUE - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
-
- value() - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
-
- value() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
-
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
-
- 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(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.stats.extended.InternalExtendedStats
-
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
-
- 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.pipeline.bucketmetrics.InternalBucketMetricValue
-
- value(String) - Method in class org.elasticsearch.search.aggregations.pipeline.bucketmetrics.percentile.InternalPercentilesBucket
-
- value() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
- value() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- value() - Method in interface org.elasticsearch.search.SearchHitField
-
The first value of the hit.
- value() - Method in enum org.elasticsearch.snapshots.SnapshotState
-
Returns code that represents the snapshot state
- VALUE_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
-
- ValueAndBoost(String, float) - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.ValueAndBoost
-
- valueAsString(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
-
- valueAt(int) - Method in class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Return the i-th
value associated with the current document.
- valueAt(int) - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Retrieve the value for the current document at the specified index.
- valueAt(int) - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Retrieve the value for the current document at the specified index.
- valueAt(int) - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
- valueAt(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
- valueAt(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
-
- valueAt(int) - Method in interface org.elasticsearch.search.MultiValueMode.UnsortedNumericDoubleValues
-
- 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.
- 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, ValueFormatter, AggregationContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
-
- ValueCountAggregator.Factory<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.metrics.valuecount
-
- ValueCountBuilder - Class in org.elasticsearch.search.aggregations.metrics.valuecount
-
- ValueCountBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountBuilder
-
Sole constructor.
- ValueCountParser - Class in org.elasticsearch.search.aggregations.metrics.valuecount
-
- ValueCountParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountParser
-
- valueForKey(long) - Method in class org.elasticsearch.common.rounding.Rounding.FactorRounding
-
- valueForKey(long) - Method in class org.elasticsearch.common.rounding.Rounding.Interval
-
- valueForKey(long) - Method in class org.elasticsearch.common.rounding.Rounding.OffsetRounding
-
- valueForKey(long) - Method in class org.elasticsearch.common.rounding.Rounding
-
Compute the rounded value given the key that identifies it.
- ValueFormat - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormat(ValueFormatter, ValueParser) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormat
-
- ValueFormat.DateTime - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormat.Number - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormat.Patternable<VF extends ValueFormat.Patternable<VF>> - Class in org.elasticsearch.search.aggregations.support.format
-
- valueFormatter - Variable in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
-
- ValueFormatter - Interface in org.elasticsearch.search.aggregations.support.format
-
A strategy for formatting time represented as millis long value to string
- ValueFormatter.BooleanFormatter - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormatter.DateTime - Class in org.elasticsearch.search.aggregations.support.format
-
A time formatter which is based on date/time format.
- ValueFormatter.GeoHash - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormatter.IPv4Formatter - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormatter.Number - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormatter.Number.Pattern - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormatter.Raw - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormatterStreams - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueFormatterStreams() - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormatterStreams
-
- valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.BooleanFieldType
-
- valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.DateFieldType
-
- valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.NumberFieldType
-
- valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.TimestampFieldType
-
Override the default behavior to return a timestamp
- valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.TTLFieldType
-
- valueForSearch(long) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
-
- valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.IpFieldType
-
IPs should return as a string.
- valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the value that will be used as a result for search.
- valueOf(String) - Static method in enum org.apache.lucene.store.StoreRateLimiting.Type
-
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.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.Allocation
-
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, String) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Date
-
- valueOf(String, String) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Double
-
- valueOf(String, String) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Float
-
- valueOf(String, String) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Long
-
- valueOf(String, String) - Method in class org.elasticsearch.action.fieldstats.FieldStats.Text
-
- valueOf(String, String) - Method in class org.elasticsearch.action.fieldstats.FieldStats
-
- valueOf(String) - Static method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Comparison
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Property
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.index.IndexRequest.OpType
-
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.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.action.update.UpdateHelper.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.action.WriteConsistencyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.cache.recycler.PageCacheRecycler.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.ClusterStateStatus
-
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.AliasAction.Type
-
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.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.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.Preference
-
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.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.cli.CliTool.ExitStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.cli.Terminal.Verbosity
-
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.GeoShapeType
-
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.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.FiltersFunctionScoreQuery.ScoreMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.math.MathUtils
-
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.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.CollectionUtils
-
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.xcontent.XContentBuilder.FieldCaseConversion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.xcontent.XContentParser.NumberType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.xcontent.XContentParser.Token
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.common.xcontent.XContentType
-
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.analysis.CharMatcher.Basic
-
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.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.IndexFieldData.CommonSettings.MemoryStorageFormat
-
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.mapper.ContentPath.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.internal.EnabledAttributeMapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.MappedFieldType.Loading
-
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.MapperUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.object.DynamicTemplate.MatchType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.mapper.object.ObjectMapper.Dynamic
-
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.CommonTermsQueryBuilder.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.MatchQueryBuilder.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.MatchQueryBuilder.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.query.MatchQueryBuilder.ZeroTermsQuery
-
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.QueryStringQueryBuilder.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.SimpleQueryStringBuilder.Operator
-
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.child.ScoreType
-
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.CommitPoint.Type
-
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.SnapshotStatus.Stage
-
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.store.IndexStoreModule.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.index.translog.Translog.Durabilty
-
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.translog.TranslogWriter.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.PreBuiltCharFilters
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltTokenFilters
-
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.recovery.RecoveryState.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.indices.recovery.RecoveryState.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.plugins.PluginManager.OutputMode
-
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.ScriptContext.Standard
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.script.ScriptService.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.Terms.ValueType
-
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.ValueType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.elasticsearch.search.internal.InternalSearchHits.StreamContext.ShardTargetType
-
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.ProfileBreakdown.TimingType
-
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.Suggest.Suggestion.Sort
-
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.
- ValueParser - Interface in org.elasticsearch.search.aggregations.support.format
-
- ValueParser.Boolean - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueParser.DateMath - Class in org.elasticsearch.search.aggregations.support.format
-
Knows how to parse datatime values based on elasticsearch's date math expression
- ValueParser.DateTime - Class in org.elasticsearch.search.aggregations.support.format
-
Knows how to parse datatime values based on date/time format
- ValueParser.IPv4 - Class in org.elasticsearch.search.aggregations.support.format
-
Knows how to parse IPv4 formats
- ValueParser.Number - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueParser.Number.Pattern - Class in org.elasticsearch.search.aggregations.support.format
-
- ValueParser.Raw - Class in org.elasticsearch.search.aggregations.support.format
-
- values() - Static method in enum org.apache.lucene.store.StoreRateLimiting.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.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.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.Allocation
-
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.fieldstats.IndexConstraint.Comparison
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.action.fieldstats.IndexConstraint.Property
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.action.index.IndexRequest.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.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.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.action.update.UpdateHelper.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.action.WriteConsistencyLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.cache.recycler.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.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.ClusterStateStatus
-
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.AliasAction.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.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.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.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.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.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.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() - Static method in enum org.elasticsearch.common.cli.CliTool.ExitStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.common.cli.Terminal.Verbosity
-
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.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.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.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.FiltersFunctionScoreQuery.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.math.MathUtils
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in class org.elasticsearch.common.Priority
-
- 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.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.CollectionUtils
-
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() - Method in class org.elasticsearch.common.util.MinimalMap
-
- values() - Static method in enum org.elasticsearch.common.xcontent.XContentBuilder.FieldCaseConversion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.common.xcontent.XContentParser.NumberType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.common.xcontent.XContentParser.Token
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.common.xcontent.XContentType
-
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.analysis.CharMatcher.Basic
-
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.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.IndexFieldData.CommonSettings.MemoryStorageFormat
-
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 - 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() - Static method in enum org.elasticsearch.index.mapper.ContentPath.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- Values() - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Values
-
- values() - Static method in enum org.elasticsearch.index.mapper.internal.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.Loading
-
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.MapperUtils
-
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.object.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.object.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.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.CommonTermsQueryBuilder.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.MatchQueryBuilder.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.MatchQueryBuilder.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.MatchQueryBuilder.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.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.QueryStringQueryBuilder.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.SimpleQueryStringBuilder.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.SimpleQueryStringFlag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
-
Deprecated.
- values() - Static method in enum org.elasticsearch.index.search.child.ScoreType
-
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.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.CommitPoint.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.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.SnapshotStatus.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.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.store.IndexStoreModule.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.translog.Translog.Durabilty
-
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.translog.TranslogWriter.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.PreBuiltCharFilters
-
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.PreBuiltTokenFilters
-
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.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.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.indices.recovery.RecoveryState.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.plugins.PluginManager.OutputMode
-
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() - Static method in enum org.elasticsearch.script.ScriptContext.Standard
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.elasticsearch.script.ScriptService.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.Terms.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.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
-
- 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.ValueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
-
- values() - Static method in enum org.elasticsearch.search.internal.InternalSearchHits.StreamContext.ShardTargetType
-
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.ProfileBreakdown.TimingType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface org.elasticsearch.search.SearchHitField
-
The field values.
- 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.Suggest.Suggestion.Sort
-
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_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksParser
-
- 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.
- 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(ValuesSourceConfig<VS>, SearchContext) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Get a value source given its configuration.
- 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.ParentChild - 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<B extends ValuesSourceAggregationBuilder<B>> - Class in org.elasticsearch.search.aggregations
-
A base class for all bucket aggregation builders that are based on values (either script generated or field data values)
- ValuesSourceAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
-
Constructs a new builder.
- ValuesSourceAggregatorFactory<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.support
-
- ValuesSourceAggregatorFactory(String, String, ValuesSourceConfig<VS>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
-
- ValuesSourceAggregatorFactory.LeafOnly<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.support
-
- ValuesSourceConfig<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.support
-
- ValuesSourceConfig(Class<VS>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
- ValuesSourceMetricsAggregationBuilder<B extends ValuesSourceMetricsAggregationBuilder<B>> - Class in org.elasticsearch.search.aggregations.metrics
-
- ValuesSourceMetricsAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
-
- ValuesSourceParser<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.support
-
- ValuesSourceParser.Builder<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.support
-
- ValuesSourceParser.Input - Class in org.elasticsearch.search.aggregations.support
-
- valueType(Terms.ValueType) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
-
When using scripts, the value type indicates the types of the values the script is generating.
- ValueType - Enum in org.elasticsearch.search.aggregations.support
-
- verbose - Variable in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
-
- 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.indices.segments.IndicesSegmentsRequest
-
Sets the verbose
option.
- VerboseProgress(PrintWriter) - Constructor for class org.elasticsearch.common.http.client.HttpDownloadHelper.VerboseProgress
-
Construct a verbose progress reporter.
- verbosity(Terminal.Verbosity) - Method in class org.elasticsearch.common.cli.Terminal
-
- verbosity() - Method in class org.elasticsearch.common.cli.Terminal
-
- VerificationFailure - Class in org.elasticsearch.repositories
-
- VerificationFailure(String, Throwable) - Constructor for class org.elasticsearch.repositories.VerificationFailure
-
- 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() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Returns true if repository should be verified after creation
- verify(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
-
- verify(String) - Method in interface org.elasticsearch.index.snapshots.IndexShardRepository
-
Verifies repository settings on data node
- verify(IndexOutput) - Static method in class org.elasticsearch.index.store.Store
-
- verify(IndexInput) - Static method in class org.elasticsearch.index.store.Store
-
- verify() - Method in class org.elasticsearch.index.store.VerifyingIndexOutput
-
Verifies the checksum and compares the written length with the expected file length.
- verify(String) - Method in class org.elasticsearch.repositories.uri.URLIndexShardRepository
-
- verify(String, String, ActionListener<RepositoriesService.VerifyResponse>) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
-
- VerifyIndex() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
-
- VerifyingIndexOutput - Class in org.elasticsearch.index.store
-
abstract class for verifying what was written.
- VerifyNodeRepositoryAction - Class in org.elasticsearch.repositories
-
- VerifyNodeRepositoryAction(Settings, 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(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.
- verifyRepository(String, ActionListener<RepositoriesService.VerifyResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
-
- VerifyRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Unregister repository action
- 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.
- verifyRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Verifies snapshot repository
- 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
-
Unregister repository response
- VerifyRepositoryResponse(ClusterName, DiscoveryNode[]) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
-
- VerifyResponse(DiscoveryNode[], VerificationFailure[]) - Constructor for class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
-
- verifyStarted() - Method in class org.elasticsearch.index.shard.IndexShard
-
- verifyStartedOrRecovering() - Method in class org.elasticsearch.index.shard.IndexShard
-
- verifySuggestion(MapperService, BytesRef, SuggestionSearchContext.SuggestionContext) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
-
- version(long) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
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.
- version() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
- 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(long) - Method in class org.elasticsearch.action.get.GetRequest
-
- version() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- version(long) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- version(long) - Method in class org.elasticsearch.action.index.IndexRequest
-
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.
- version() - Method in class org.elasticsearch.action.index.IndexRequest
-
- version(long) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
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.
- version() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
- version() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
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(long) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- version(long) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
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.
- version() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- version() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- version(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- version(long) - Method in class org.elasticsearch.action.update.UpdateRequest
-
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.
- version() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- version(long) - Method in class org.elasticsearch.cluster.ClusterState.Builder
-
- version() - Method in class org.elasticsearch.cluster.ClusterState
-
- version() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- version(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
-
- version(long) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
-
- version() - Method in class org.elasticsearch.cluster.metadata.MetaData
-
- version() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
- version() - Method in class org.elasticsearch.cluster.routing.RestoreSource
-
- version(long) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
- version() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
- version() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The routing version associated with the shard.
- VERSION - Static variable in class org.elasticsearch.common.lucene.Lucene
-
- version - Variable in class org.elasticsearch.common.lucene.uid.Versions.DocIdAndVersion
-
- version() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
-
- version - Variable in class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
-
- version - Variable in class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
-
- version() - Method in class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
-
- version - Variable in class org.elasticsearch.index.analysis.AbstractTokenizerFactory
-
- version() - Method in class org.elasticsearch.index.analysis.AbstractTokenizerFactory
-
- version() - Method in class org.elasticsearch.index.engine.Engine.Delete
-
before delete execution this is the version to be deleted.
- version() - Method in class org.elasticsearch.index.engine.Engine.Get
-
- version(long) - 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.IndexingOperation
-
- version - Variable in class org.elasticsearch.index.engine.Segment
-
- version() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- version(Field) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
-
- version() - Method in class org.elasticsearch.index.mapper.ParseContext
-
- version(Field) - Method in class org.elasticsearch.index.mapper.ParseContext
-
- version() - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
- VERSION - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item.Field
-
- version() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- version(long) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- version() - Method in class org.elasticsearch.index.shard.CommitPoint
-
- version - Variable in class org.elasticsearch.index.shard.ShardStateMetaData
-
- version() - Method in class org.elasticsearch.index.translog.Translog.Create
-
- version() - Method in class org.elasticsearch.index.translog.Translog.Delete
-
- version() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- VERSION - Static variable in class org.elasticsearch.index.translog.TranslogWriter
-
- 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.percolator.PercolateContext
-
- version(boolean) - Method in class org.elasticsearch.percolator.PercolateContext
-
- VERSION - Static variable in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
- version(Boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should each
SearchHit
be returned with a
version associated with it.
- version() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- version(boolean) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
-
- version() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- version(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
-
- version(long) - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- version() - Method in class org.elasticsearch.search.internal.InternalSearchHit
-
- version() - Method in class org.elasticsearch.search.internal.SearchContext
-
- version(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
-
- version() - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- version(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
-
- version() - Method in interface org.elasticsearch.search.SearchHit
-
The version of the hit.
- version() - Method in class org.elasticsearch.snapshots.Snapshot
-
Returns version of Elasticsearch that was used to create this snapshot
- 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 - Variable in class org.elasticsearch.transport.netty.NettyTransport
-
- Version - Class in org.elasticsearch
-
- Version.Module - Class in org.elasticsearch
-
- VERSION_CHECKPOINTS - Static variable in class org.elasticsearch.index.translog.TranslogWriter
-
- VERSION_CHECKSUMS - Static variable in class org.elasticsearch.index.translog.TranslogWriter
-
- VERSION_TYPE - Static variable in interface org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item.Field
-
- versionAsInteger() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
- VersionConflictEngineException - Exception in org.elasticsearch.index.engine
-
- VersionConflictEngineException(ShardId, String, String, long, long) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
-
- VersionConflictEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
-
- VersionFetchSubPhase - Class in org.elasticsearch.search.fetch.version
-
- VersionFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.version.VersionFetchSubPhase
-
- VersionFieldMapper - Class in org.elasticsearch.index.mapper.internal
-
Mapper for the _version field.
- VersionFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
-
- VersionFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
-
- VersionFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
-
- VersionParseElement - Class in org.elasticsearch.search.fetch.version
-
- VersionParseElement() - Constructor for class org.elasticsearch.search.fetch.version.VersionParseElement
-
- 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
-
Utility class to resolve the Lucene doc ID and version for a given uid.
- Versions.DocIdAndVersion - Class in org.elasticsearch.common.lucene.uid
-
Wraps an LeafReaderContext
, a doc ID relative to the context doc base and a version.
- versionType(VersionType) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
- versionType() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
- versionType(VersionType) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the versioning type.
- versionType() - Method in class org.elasticsearch.action.get.GetRequest
-
- versionType() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- versionType(VersionType) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
- versionType(VersionType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the versioning type.
- versionType() - Method in class org.elasticsearch.action.index.IndexRequest
-
- versionType(VersionType) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
- versionType() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
-
- versionType(VersionType) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
Sets the versioning type.
- versionType() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
-
- versionType(VersionType) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
Sets the versioning type.
- versionType() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
-
- versionType() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- versionType(VersionType) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
- versionType(VersionType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the versioning type.
- versionType() - Method in class org.elasticsearch.action.update.UpdateRequest
-
- versionType() - Method in class org.elasticsearch.index.engine.Engine.Delete
-
- versionType() - Method in class org.elasticsearch.index.engine.Engine.Get
-
- versionType(VersionType) - Method in class org.elasticsearch.index.engine.Engine.Get
-
- versionType() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
-
- versionType() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- versionType(VersionType) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
- versionType() - Method in class org.elasticsearch.index.translog.Translog.Create
-
- versionType() - Method in class org.elasticsearch.index.translog.Translog.Delete
-
- versionType() - Method in class org.elasticsearch.index.translog.Translog.Index
-
- 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(InstanceBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a instance binding.
- visit(ProviderInstanceBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a provider instance binding.
- visit(ProviderKeyBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a provider key binding.
- visit(LinkedKeyBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a linked key binding.
- 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(UntargettedBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit an untargetted binding.
- visit(ConstructorBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a constructor binding.
- 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(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(InstanceBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(ProviderInstanceBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(ProviderKeyBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(LinkedKeyBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(ExposedBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(UntargettedBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(ConstructorBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(ConvertedConstantBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(ProviderBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
- visit(Message) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(Binding<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(ScopeBinding) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(TypeConverterBinding) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(ProviderLookup<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(InjectionRequest) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(StaticInjectionRequest) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(PrivateElements) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(MembersInjectorLookup<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
- visit(TypeListenerBinding) - 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(ScopeBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a registration of a scope annotation with the scope that implements it.
- visit(TypeConverterBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a registration of type converters for matching target types.
- 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(StaticInjectionRequest) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a request to inject the static fields and methods of type.
- visit(ProviderLookup<T>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a lookup of the provider for a type.
- visit(MembersInjectorLookup<T>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a lookup of the members injector.
- 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 interface org.elasticsearch.common.inject.spi.ElementVisitor
-
- visit(TypeListenerBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit an injectable type listener binding.
- 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
-