Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

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
 
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.
AbstractAsyncAction - Class in org.elasticsearch.action.search.type
Base implementation for an async action.
AbstractAsyncAction() - Constructor for class org.elasticsearch.action.search.type.AbstractAsyncAction
 
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() - Constructor for class org.elasticsearch.client.support.AbstractClient
 
AbstractClusterAdminClient - Class in org.elasticsearch.client.support
 
AbstractClusterAdminClient() - Constructor for class org.elasticsearch.client.support.AbstractClusterAdminClient
 
AbstractComponent - Class in org.elasticsearch.common.component
 
AbstractComponent(Settings) - Constructor for class org.elasticsearch.common.component.AbstractComponent
 
AbstractComponent(Settings, String) - Constructor for class org.elasticsearch.common.component.AbstractComponent
 
AbstractComponent(Settings, Class) - Constructor for class org.elasticsearch.common.component.AbstractComponent
 
AbstractComponent(Settings, String, Class) - Constructor for class org.elasticsearch.common.component.AbstractComponent
 
AbstractComponent(Settings, Class, Class) - Constructor for class org.elasticsearch.common.component.AbstractComponent
 
AbstractComponent(Settings, String, Class, 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
 
AbstractDistanceScoreFunction(double, double, double, DecayFunction, MultiValueMode) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionParser.AbstractDistanceScoreFunction
 
AbstractDistributor - Class in org.elasticsearch.index.store.distributor
 
AbstractDistributor(DirectoryService) - Constructor for class org.elasticsearch.index.store.distributor.AbstractDistributor
 
AbstractDocValuesFormatProvider - Class in org.elasticsearch.index.codec.docvaluesformat
Simple abstract DocValuesFormat requiring a name for the provider;
AbstractDocValuesFormatProvider(String) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.AbstractDocValuesFormatProvider
 
AbstractDoubleSearchScript - Class in org.elasticsearch.script
A simpler base class instead of AbstractSearchScript for computations that return a double number.
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
 
AbstractFieldMapper<T> - Class in org.elasticsearch.index.mapper.core
 
AbstractFieldMapper(FieldMapper.Names, float, FieldType, Boolean, NamedAnalyzer, NamedAnalyzer, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
AbstractFieldMapper(FieldMapper.Names, float, FieldType, Boolean, NamedAnalyzer, NamedAnalyzer, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
AbstractFieldMapper.Builder<T extends AbstractFieldMapper.Builder,Y extends AbstractFieldMapper> - Class in org.elasticsearch.index.mapper.core
 
AbstractFieldMapper.CopyTo - Class in org.elasticsearch.index.mapper.core
Represents a list of fields with optional boost factor where the current field should be copied to
AbstractFieldMapper.CopyTo.Builder - Class in org.elasticsearch.index.mapper.core
 
AbstractFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
AbstractFieldMapper.MultiFields - Class in org.elasticsearch.index.mapper.core
 
AbstractFieldMapper.MultiFields.Builder - Class in org.elasticsearch.index.mapper.core
 
AbstractFloatSearchScript - Class in org.elasticsearch.script
A simpler base class instead of AbstractSearchScript for computations that return a float number.
AbstractFloatSearchScript() - Constructor for class org.elasticsearch.script.AbstractFloatSearchScript
 
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.
AbstractIndexAnalyzerProvider(Index, Settings, String, 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.
AbstractIndexComponent(Index, Settings, String) - Constructor for class org.elasticsearch.index.AbstractIndexComponent
Constructs a new index component, with the index name and its settings, as well as settings prefix.
AbstractIndexFieldData<FD extends AtomicFieldData> - Class in org.elasticsearch.index.fielddata.plain
 
AbstractIndexFieldData(Index, Settings, FieldMapper.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, FieldMapper.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
 
AbstractIndexShardComponent(ShardId, Settings, String) - Constructor for class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
AbstractIndexStore - Class in org.elasticsearch.index.store.support
 
AbstractIndexStore(Index, Settings, IndexService, IndicesStore, NodeEnvironment) - Constructor for class org.elasticsearch.index.store.support.AbstractIndexStore
 
AbstractIndicesAdminClient - Class in org.elasticsearch.client.support
 
AbstractIndicesAdminClient() - Constructor for class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
 
AbstractLifecycleComponent(Settings, Class, Class) - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
 
AbstractLifecycleComponent(Settings, String) - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
 
AbstractLifecycleComponent(Settings, String, Class) - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
 
AbstractLifecycleComponent(Settings, String, Class, Class) - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
 
AbstractListenableActionFuture<T,L> - Class in org.elasticsearch.action.support
 
AbstractListenableActionFuture(boolean, ThreadPool) - Constructor for class org.elasticsearch.action.support.AbstractListenableActionFuture
 
AbstractLongSearchScript - Class in org.elasticsearch.script
A simpler base class instead of AbstractSearchScript for computations that return a long number.
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
 
AbstractMergePolicyProvider<MP extends org.apache.lucene.index.MergePolicy> - Class in org.elasticsearch.index.merge.policy
 
AbstractMergePolicyProvider(Store) - Constructor for class org.elasticsearch.index.merge.policy.AbstractMergePolicyProvider
 
AbstractModule - Class in org.elasticsearch.common.inject
A support class for Modules which reduces repetition and results in a more readable configuration.
AbstractModule() - Constructor for class org.elasticsearch.common.inject.AbstractModule
 
AbstractPercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
AbstractPercentilesAggregator(String, long, ValuesSource.Numeric, AggregationContext, Aggregator, double[], double, boolean, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
AbstractPercentilesParser - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
AbstractPercentilesParser(boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesParser
 
AbstractPlugin - Class in org.elasticsearch.plugins
A base class for a plugin.
AbstractPlugin() - Constructor for class org.elasticsearch.plugins.AbstractPlugin
 
AbstractPostingsFormatProvider - Class in org.elasticsearch.index.codec.postingsformat
Simple abstract PostingsFormat requiring a name for the provider;
AbstractPostingsFormatProvider(String) - Constructor for class org.elasticsearch.index.codec.postingsformat.AbstractPostingsFormatProvider
 
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
A basic RefCounted implementation that is initialized with a ref count of 1 and calls AbstractRefCounted.closeInternal() once it reaches a 0 ref count
AbstractRefCounted(String) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractRefCounted
 
AbstractResourceWatcher<Listener> - Class in org.elasticsearch.watcher
Abstract resource watcher framework, which handles adding and removing listeners and calling resource observer.
AbstractResourceWatcher() - Constructor for class org.elasticsearch.watcher.AbstractResourceWatcher
 
AbstractRiverComponent - Class in org.elasticsearch.river
 
AbstractRiverComponent(RiverName, RiverSettings) - Constructor for class org.elasticsearch.river.AbstractRiverComponent
 
AbstractRunnable - Class in org.elasticsearch.common.util.concurrent
An extension to runnable.
AbstractRunnable() - Constructor for class org.elasticsearch.common.util.concurrent.AbstractRunnable
 
AbstractSearchScript - Class in org.elasticsearch.script
A base class for any script type that is used during the search process (custom score, facets, and so on).
AbstractSearchScript() - Constructor for class org.elasticsearch.script.AbstractSearchScript
 
AbstractSimilarityProvider - Class in org.elasticsearch.index.similarity
Abstract implemenetation of SimilarityProvider providing common behaviour
AbstractSimilarityProvider(String) - Constructor for class org.elasticsearch.index.similarity.AbstractSimilarityProvider
Creates a new AbstractSimilarityProvider with the given name
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
 
AbstractXContentGenerator - Class in org.elasticsearch.common.xcontent.support
 
AbstractXContentGenerator() - Constructor for class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
AbstractXContentParser - Class in org.elasticsearch.common.xcontent.support
 
AbstractXContentParser() - Constructor for class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
accept(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer.BlobNameFilter
Return false if the blob should be filtered.
accept(BytesRef) - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
Always accept the term.
accept(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude
Returns whether the given value is accepted based on the include & exclude patterns.
accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.IncludeExclude.LongFilter
 
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
Computes which global ordinals are accepted by this IncludeExclude instance.
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
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.common.lucene.Lucene.EarlyTerminatingCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.common.lucene.MultiCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.common.lucene.search.NoopCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.search.aggregations.AggregationPhase.AggregationsCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.search.facet.FacetExecutor.Collector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Collector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.search.internal.DocIdSetCollector
 
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.restart.TransportNodesRestartAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
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.delete.TransportIndexDeleteAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
accumulateExceptions() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
accumulateExceptions() - Method in class org.elasticsearch.gateway.local.state.shards.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.local.state.meta.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
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
 
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 MasterNodeOperationRequest> - 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,Client>,Client extends ElasticsearchClient> - Class in org.elasticsearch.action.support.master
Base request builder for master node operations that support acknowledgements
AcknowledgedRequestBuilder(Client, 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 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(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock.GlobalLockable
 
acquire() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
 
acquireSearcher(String) - Method in class org.elasticsearch.index.engine.Engine
Returns a new searcher instance.
acquireSearcher(String) - Method in class org.elasticsearch.index.shard.IndexShard
 
acquireSearcher(String, boolean) - 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,Client>,Client extends ElasticsearchClient> - Class in org.elasticsearch.action
Base action.
Action(String) - Constructor for class org.elasticsearch.action.Action
 
action() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
 
ACTION() - Constructor for class org.elasticsearch.plugins.PluginManager.ACTION
 
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.local.LocalTransportChannel
 
action() - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
 
action() - Method in interface org.elasticsearch.transport.TransportChannel
 
action(String, Version) - Method in class org.elasticsearch.transport.TransportService.Adapter
 
action(String, Version) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
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.MappingUpdatedAction
 
ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
 
ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
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.local.state.meta.LocalAllocateDangledIndices
 
ACTION_NAME - Static variable in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
ACTION_NAME - Static variable in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
ACTION_NAME - Static variable in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
ACTION_NAME - Static variable in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
 
ACTION_NAME - Static variable in class org.elasticsearch.river.cluster.PublishRiverClusterStateAction
 
ACTION_NAME_GTE_1_4 - Static variable in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
when pinging the initial configured target hosts, we do not know their version.
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
Holds the action filters injected through plugins, properly sorted by ActionFilter.order()
ActionFilters(Set<ActionFilter>) - Constructor for class org.elasticsearch.action.support.ActionFilters
 
ActionFuture<T> - Interface in org.elasticsearch.action
An extension to Future allowing for simplified "get" operations.
actionGet() - Method in interface org.elasticsearch.action.ActionFuture
Similar to Future.get(), just catching the InterruptedException and throwing an ElasticsearchIllegalStateException instead.
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.
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(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,Client extends ElasticsearchClient> - Class in org.elasticsearch.action
 
ActionRequestBuilder(Client, 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
Base class for Runnables that need to call ActionListener.onFailure(Throwable) in case an uncaught exception or error is thrown while the actual action is run.
ActionRunnable(ActionListener<Response>) - Constructor for class org.elasticsearch.action.ActionRunnable
 
actions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
Returns the alias actions to be performed
actions(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(String, Throwable) - 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
 
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.ImmutableShardRouting
 
active() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
Returns true iff the this shard is currently started or relocating to another node.
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.
activeOpens() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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 ImmutableList of active shards
activeShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
activeShardsIt(int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
activeShardsRandomIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
activityTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
 
actualFree() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
actualSizeToRead() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
 
actualUsed() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
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
 
AdapterStreamInput - Class in org.elasticsearch.common.io.stream
 
AdapterStreamInput() - Constructor for class org.elasticsearch.common.io.stream.AdapterStreamInput
 
AdapterStreamInput(StreamInput) - Constructor for class org.elasticsearch.common.io.stream.AdapterStreamInput
 
AdapterStreamOutput - Class in org.elasticsearch.common.io.stream
 
AdapterStreamOutput(StreamOutput) - Constructor for class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
add(double) - Method in class jsr166e.DoubleAdder
Adds the given value.
add(long) - Method in class jsr166e.LongAdder
Adds the given value.
add(PluginInfo) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsInfo
 
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
Adds an IndexRequest to the list of actions to execute.
add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
Adds an DeleteRequest to the list of actions to execute.
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, boolean, String, String) - Method in class org.elasticsearch.action.bulk.BulkProcessor
 
add(BytesReference, boolean, 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(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
Adds an IndexRequest to the list of actions to execute.
add(IndexRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
 
add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
Adds an UpdateRequest to the list of actions to execute.
add(UpdateRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
 
add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
Adds an DeleteRequest to the list of actions to execute.
add(DeleteRequest, Object) - Method in class org.elasticsearch.action.bulk.BulkRequest
 
add(byte[], int, int, boolean) - Method in class org.elasticsearch.action.bulk.BulkRequest
Adds a framed data in binary format
add(byte[], int, int, boolean, String, String) - Method in class org.elasticsearch.action.bulk.BulkRequest
Adds a framed data in binary format
add(BytesReference, boolean, String, String) - Method in class org.elasticsearch.action.bulk.BulkRequest
Adds a framed data in binary format
add(BytesReference, boolean, String, String, boolean) - Method in class org.elasticsearch.action.bulk.BulkRequest
Adds a framed data in binary format
add(BytesReference, boolean, String, String, String, Object, boolean) - Method in class org.elasticsearch.action.bulk.BulkRequest
 
add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
Adds an IndexRequest to the list of actions to execute.
add(IndexRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
Adds an IndexRequest to the list of actions to execute.
add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
Adds an DeleteRequest to the list of actions to execute.
add(DeleteRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
Adds an DeleteRequest to the list of actions to execute.
add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
Adds an DeleteRequest to the list of actions to execute.
add(UpdateRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
Adds an DeleteRequest to the list of actions to execute.
add(byte[], int, int, boolean) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
Adds a framed data in binary format
add(byte[], int, int, boolean, 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, 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(BytesReference, boolean, 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(TermVectorRequest) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
add(String, String, String) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
add(TermVectorRequest, BytesReference) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
add(String, String, Iterable<String>) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequestBuilder
 
add(String, String, String...) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequestBuilder
 
add(TermVectorRequest) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequestBuilder
 
add(int, TermVectorRequest) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsShardRequest
 
add(int, TermVectorResponse) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsShardResponse
 
add(int, MultiTermVectorsResponse.Failure) - Method in class org.elasticsearch.action.termvector.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(Class<? extends AllocationDecider>) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecidersModule
 
add(Decision) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
Add a decision to this Decision.Multidecision instance
add(RerouteExplanation) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
 
add(MutableShardRouting) - 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(E) - Method in class org.elasticsearch.common.collect.BoundedTreeSet
 
add(E) - Method in class org.elasticsearch.common.collect.IdentityHashSet
Adds the specified element to this set if it is not already present.
add(String, Object) - Method in class org.elasticsearch.common.inject.internal.ToStringBuilder
 
add(Module...) - Method in class org.elasticsearch.common.inject.ModulesBuilder
 
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(FilterClause) - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
Adds a new FilterClause to the Boolean Filter container
add(Filter, BooleanClause.Occur) - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
add(MulticastChannel.Listener) - Method in class org.elasticsearch.common.network.MulticastChannel.MultiListener
 
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(String, CompressedString) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
add(FilterCacheStats) - Method in class org.elasticsearch.index.cache.filter.FilterCacheStats
 
add(IdCacheStats) - Method in class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
add(QueryCacheStats) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
 
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(String) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.CopyTo.Builder
 
add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields.Builder
 
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(double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.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) - 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(FilterBuilder) - Method in class org.elasticsearch.index.query.AndFilterBuilder
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(FilterBuilder, 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(FilterBuilder) - Method in class org.elasticsearch.index.query.OrFilterBuilder
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.fs.BufferingFsTranslogFile
 
add(Translog.Operation) - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
add(BytesReference) - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
add(BytesReference) - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
add(Translog.Operation) - Method in interface org.elasticsearch.index.translog.Translog
Adds a create operation to the transaction log.
add(TranslogStats) - Method in class org.elasticsearch.index.translog.TranslogStats
 
add(long, long, long) - Method in class org.elasticsearch.index.warmer.WarmerStats
 
add(WarmerStats) - Method in class org.elasticsearch.index.warmer.WarmerStats
 
add(FsStats.Info) - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
add(RiverClusterStateListener) - Method in class org.elasticsearch.river.cluster.RiverClusterService
 
add(AggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
 
add(Aggregation) - Method in interface org.elasticsearch.search.aggregations.BucketCollector.BucketAnalysisCollector
Used to ask BucketCollectors for their analysis of the content collected in a bucket
add(FieldDataFieldsContext.FieldDataField) - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsContext
 
add(PartialFieldsContext.PartialField) - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsContext
 
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(AggregationBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
addAggregation(AggregationBuilder) - 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.
addAggregatorParser(Class<? extends Aggregator.Parser>) - Method in class org.elasticsearch.search.aggregations.AggregationModule
Enabling extending the get module by adding a custom aggregation parser.
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, FilterBuilder, 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, FilterBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
Adds an alias to the index.
addAlias(String, String, FilterBuilder) - 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
 
addAll(Collection<MutableShardRouting>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
 
addAll(Collection<? extends E>) - Method in class org.elasticsearch.common.collect.BoundedTreeSet
 
addAll(Map<String, IndexAlias>) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
addAnalyzer(String, Class<? extends AnalyzerProvider>) - Method in class org.elasticsearch.index.analysis.AnalysisModule
 
addAsNew(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
addAsNewRestore(IndexMetaData, RestoreSource, IntSet) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
addAsOld(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
add statistics that should be accumulated about old shards after they have been deleted or relocated
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() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder
Returns a binding builder used to add a new element in the set.
addBlocks(IndexMetaData) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
addCandidateGenerator(PhraseSuggestionBuilder.CandidateGenerator) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
Adds a CandidateGenerator to this suggester.
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
 
addClearPostAllocationFlag(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
Clears the post allocation flag for the provided shard id.
addConflict(String) - Method in class org.elasticsearch.index.mapper.MergeContext
 
addConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
 
addConsoleCtrlHandler(Kernel32Library.ConsoleCtrlHandler) - Method in class org.elasticsearch.common.jna.Kernel32Library
Adds a Console Ctrl Handler.
addConsoleCtrlHandler(Kernel32Library.ConsoleCtrlHandler) - Static method in class org.elasticsearch.common.jna.Natives
 
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
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
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
 
addDocValuesFormat(String, Class<? extends DocValuesFormatProvider>) - Method in class org.elasticsearch.index.codec.CodecModule
 
addDynamicSetting(String, Validator) - Method in class org.elasticsearch.cluster.settings.ClusterDynamicSettingsModule
 
addDynamicSetting(String, Validator) - Method in class org.elasticsearch.cluster.settings.DynamicSettings
 
addDynamicSetting(String) - Method in class org.elasticsearch.cluster.settings.DynamicSettings
 
addDynamicSetting(String, Validator) - Method in class org.elasticsearch.index.settings.IndexDynamicSettingsModule
 
addDynamicSettings(String...) - Method in class org.elasticsearch.cluster.settings.ClusterDynamicSettingsModule
 
addDynamicSettings(String...) - Method in class org.elasticsearch.cluster.settings.DynamicSettings
 
addDynamicSettings(String...) - Method in class org.elasticsearch.index.settings.IndexDynamicSettingsModule
 
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
 
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
 
addFacet(FacetBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Add a facet definition.
addFacet(FacetBuilder) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
Add a facet definition.
addFacet(FacetBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Deprecated.
Facets are deprecated and will be removed in a future release. Please use aggregations instead.
addFacetProcessor(Class<? extends FacetParser>) - Method in class org.elasticsearch.search.facet.FacetModule
 
addFailedEngineListener(Engine.FailedEngineListener) - Method in class org.elasticsearch.index.shard.IndexShard
 
addFailure(String) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
addFailureListener(MergeSchedulerProvider.FailureListener) - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
addFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
 
addFeatures(String[]) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
addFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
 
addFeatures(String...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
Deprecated.
use #addFeatures(Feature[]) instead
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(FieldInfo) - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsConsumer
Deprecated.
 
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.
addFieldMapperListener(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
addFieldMappers(List<FieldMapper<?>>) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
addFields(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Adds the fields to load and return as part of the search request.
addFieldStringsFromParameter(TermVectorRequest, String) - Static method in class org.elasticsearch.rest.action.termvector.RestTermVectorAction
 
addFileDetail(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
 
addFilter(SettingsFilter.Filter) - Method in class org.elasticsearch.common.settings.SettingsFilter
 
addFilter(Class<FilterParser>) - Method in class org.elasticsearch.indices.query.IndicesQueriesModule
 
addFilter(FilterParser) - Method in class org.elasticsearch.indices.query.IndicesQueriesModule
 
addFilterFacetAndGlobal(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.FacetBuilder
 
addFilterParser(String, Class<? extends FilterParser>) - Method in class org.elasticsearch.index.query.IndexQueryParserModule
Adds a custom filter parser.
addFilterParser(FilterParser) - Method in class org.elasticsearch.indices.query.IndicesQueriesRegistry
 
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
 
addFixedBitSetMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
 
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 class org.elasticsearch.rest.RestResponse
Add a custom header.
addHeaders(Map<String, List<String>>) - Method in class org.elasticsearch.rest.RestResponse
 
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
 
addHunspellDictionary(String, Dictionary) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisModule
 
addIds(String...) - Method in class org.elasticsearch.index.query.IdsFilterBuilder
Adds ids to the filter.
addIds(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
 
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
 
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
 
additionalSettings() - Method in class org.elasticsearch.plugins.AbstractPlugin
 
additionalSettings() - Method in interface 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
 
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(MergeSchedulerProvider.Listener) - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
addListener(IndexSettingsService.Listener) - Method in class org.elasticsearch.index.settings.IndexSettingsService
Only settings registered in IndexDynamicSettingsModule 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 ClusterDynamicSettingsModule can be changed dynamically.
addListener(ActionListener<RestoreService.RestoreCompletionResponse>) - Method in class org.elasticsearch.snapshots.RestoreService
Adds restore completion listener

This listener is called for each snapshot that finishes restore operation in the cluster.

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
addMainQueryCollector(Collector) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
Adds a query level collector that runs at ContextIndexSearcher.Stage.MAIN_QUERY.
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
Same as IPv4RangeBuilder.addMaskRange(String, String) but uses the mask itself as a key.
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
 
addMultiField(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
addNamedFilter(String, Filter) - Method in class org.elasticsearch.index.query.QueryParseContext
 
addNamedQuery(String, Query) - Method in class org.elasticsearch.index.query.QueryParseContext
 
addNeighbors(String, E) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Add all geohashes of the cells next to a given geohash to a list.
addNeighbors(String, int, E) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Add all geohashes of the cells next to a given geohash to a list.
addNode(DiscoveryNode) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
addNodeInfo(NodeInfo) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
 
addNodeInfo(NodeInfo) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
 
addNodeInfoStats(NodeInfo, NodeStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
 
addNodeStats(NodeStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
 
addObjectMapperListener(ObjectMapperListener) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
addObjectMappers(Collection<ObjectMapper>) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
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
 
addParam(String, Object) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
 
addPartialField(String, String, String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Deprecated.
addPartialField(String, String[], String[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Deprecated.
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 shard.
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
addPoint(double, double) - Method in class org.elasticsearch.index.query.GeoPolygonFilterBuilder
Adds a point with lat and lon
addPoint(String) - Method in class org.elasticsearch.index.query.GeoPolygonFilterBuilder
 
addPoint(GeoPoint) - Method in class org.elasticsearch.index.query.GeoPolygonFilterBuilder
 
addPostingFormat(String, Class<? extends PostingsFormatProvider>) - Method in class org.elasticsearch.index.codec.CodecModule
 
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
 
addProcessor(IndexQueryParserModule.QueryParsersProcessor) - Method in class org.elasticsearch.index.query.IndexQueryParserModule
 
addQuery(Class<QueryParser>) - Method in class org.elasticsearch.indices.query.IndicesQueriesModule
 
addQuery(QueryParser) - Method in class org.elasticsearch.indices.query.IndicesQueriesModule
 
addQueryParser(String, Class<? extends QueryParser>) - Method in class org.elasticsearch.index.query.IndexQueryParserModule
Adds a custom query parser.
addQueryParser(QueryParser) - Method in class org.elasticsearch.indices.query.IndicesQueriesRegistry
Adds a global query parser.
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
Same as #addRange(String, double, double) but the key will be automatically generated based on from and to.
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
Same as GeoDistanceBuilder.addRange(String, double, double) but the key will be automatically generated based on from and to.
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
Same as IPv4RangeBuilder.addRange(String, String, String) but the key will be automatically generated.
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
Same as RangeBuilder.addRange(String, double, double) but the key will be automatically generated based on from and to.
addRange(double, double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
Adds a range entry with explicit from and to.
addRange(double, double) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
Adds a range entry with explicit from and to.
addRange(String, String) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
 
addRange(double, double) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
Adds a range entry with explicit from and to.
addReaderKeyToClean(Object) - Method in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
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 class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
address() - Method in exception org.elasticsearch.transport.ActionTransportException
The target address to invoke the action on.
address() - Method in class org.elasticsearch.transport.TransportInfo
 
addressesFromString(String) - Method in class org.elasticsearch.transport.local.LocalTransport
 
addressesFromString(String) - Method in class org.elasticsearch.transport.netty.NettyTransport
 
addressesFromString(String) - Method in interface org.elasticsearch.transport.Transport
Returns an address from its string representation.
addressesFromString(String) - Method in class org.elasticsearch.transport.TransportService
 
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, String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Adds a script based field to load and return.
addScriptField(String, String, Map<String, Object>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Adds a script based field to load and return.
addScriptField(String, String, String, Map<String, Object>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Adds a script based field to load and return.
addScriptField(String, String) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
Adds a script based field to load and return.
addScriptField(String, String, Map<String, Object>) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
Adds a script based field to load and return.
addScriptField(String, String, String, Map<String, Object>) - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
Adds a script based field to load and return.
addScriptField(String, String) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
Adds a script based field to load and return.
addScriptField(String, String, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
Adds a script based field to load and return.
addScriptField(String, String, String, Map<String, Object>) - 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
Add a script parameter.
addScriptParam(String, Object) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Add a script parameter.
addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequest
 
addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
 
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(ImmutableShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
addShardFailure(int, SearchShardTarget, Throwable) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
addSimilarity(String, Class<? extends SimilarityProvider>) - Method in class org.elasticsearch.index.similarity.SimilarityModule
Registers the given SimilarityProvider with the given name
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
 
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
Adds an TermSuggestionBuilder instance under a user defined name.
addSuggestion(String, SuggestionSearchContext.SuggestionContext) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext
 
addSurface(BytesRef, BytesRef, long) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
 
addTargetThrottling(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
 
addTerm(T) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
 
addText(String, String, float) - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
addThrottleTime(long) - Method in class org.elasticsearch.index.recovery.RecoveryStats
 
addToBlacklist(String...) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
Appends the additional blacklisted methods to the current blacklist, returns true if the black list has changed
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
 
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
 
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
Same as #addUnboundedFrom(String, double) but the key will be computed automatically.
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
Same as GeoDistanceBuilder.addUnboundedFrom(String, double) but the key will be computed automatically.
addUnboundedFrom(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
Same as IPv4RangeBuilder.addRange(String, String, String) but there will be no upper bound.
addUnboundedFrom(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
Same as IPv4RangeBuilder.addUnboundedFrom(String, String) but the key will be generated automatically.
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
Same as RangeBuilder.addUnboundedFrom(String, double) but the key will be computed automatically.
addUnboundedFrom(double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
Adds a range entry with explicit to and unbounded from.
addUnboundedFrom(double) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
Adds a range entry with explicit to and unbounded from.
addUnboundedFrom(String) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
 
addUnboundedFrom(double) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
Adds a range entry with explicit to and unbounded from.
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
Same as #addUnboundedTo(String, double) but the key will be computed automatically.
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
Same as GeoDistanceBuilder.addUnboundedTo(String, double) but the key will be computed automatically.
addUnboundedTo(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
Same as IPv4RangeBuilder.addRange(String, String, String) but there will be no lower bound.
addUnboundedTo(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4RangeBuilder
Same as IPv4RangeBuilder.addUnboundedTo(String, String) but the key will be generated automatically.
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
Same as RangeBuilder.addUnboundedTo(String, double) but the key will be computed automatically.
addUnboundedTo(double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
Adds a range entry with explicit from and unbounded to.
addUnboundedTo(double) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
Adds a range entry with explicit from and unbounded to.
addUnboundedTo(String) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
 
addUnboundedTo(double) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
Adds a range entry with explicit from and unbounded to.
addUnicastHostProvider(Class<? extends UnicastHostsProvider>) - Method in class org.elasticsearch.discovery.zen.ZenDiscoveryModule
Adds a custom unicast hosts provider to build a dynamic list of unicast hosts list when doing unicast discovery.
addValidationError(String) - Method in exception org.elasticsearch.action.ActionRequestValidationException
 
addValidationError(String, ActionRequestValidationException) - Static method in class org.elasticsearch.action.ValidateActions
 
addValidationErrors(Iterable<String>) - Method in exception org.elasticsearch.action.ActionRequestValidationException
 
addValue(BytesRef, int) - Method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
addValue(BytesRef, int) - Method in class org.elasticsearch.search.facet.terms.strings.HashedScriptAggregator
 
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
Add fields so that they can later be fetched using ParseContext.Document.getByKey(Object).
addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
Add an exact number of bytes, not checking for tripping the circuit breaker.
addWithoutBreaking(long) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
Adjust the circuit breaker without tripping
addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.MemoryCircuitBreaker
Add an exact number of bytes, not checking for tripping the circuit breaker.
addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
 
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.FilterClient
 
admin() - Method in class org.elasticsearch.client.node.NodeClient
 
admin() - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
admin() - Method in class org.elasticsearch.client.transport.TransportClient
 
AdminClient - Interface in org.elasticsearch.client
Administrative actions/operations against the cluster or the indices.
advance(int) - Method in class org.elasticsearch.common.lucene.docset.AllDocIdSet.Iterator
 
advance(int) - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSetIterator
 
advance(int) - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.IteratorBasedIterator
 
advance(int) - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
advance(int) - Method in class org.elasticsearch.index.search.child.ConstantScorer
 
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
 
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.
afterMerge(OnGoingMerge) - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
A callback allowing for custom logic before an actual merge starts.
afterMerge(OnGoingMerge) - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
afterMerge(OnGoingMerge) - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
afterMerge(OnGoingMerge) - Method in interface org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider.Listener
A callback after a merge is going to execute.
afterMerge(OnGoingMerge) - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider.CustomSerialMergeScheduler
Deprecated.
 
afterRelease(boolean) - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
 
afterRelease(boolean) - Method in class org.elasticsearch.common.recycler.DequeRecycler
Called after a release.
afterRemove(DocumentMapper) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
 
afterRemove(DocumentMapper) - Method in interface org.elasticsearch.index.mapper.DocumentTypeListener
Invoked just after an existing document type has been removed.
afterStart() - Method in class org.elasticsearch.common.component.LifecycleListener
 
afterStop() - Method in class org.elasticsearch.common.component.LifecycleListener
 
afterUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
AggregatedDfs - Class in org.elasticsearch.search.dfs
 
AggregatedDfs(ObjectObjectOpenHashMap<Term, TermStatistics>, ObjectObjectOpenHashMap<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.
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
 
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
 
AggregationModule - Class in org.elasticsearch.search.aggregations
The main module for the get (binding all get components together)
AggregationModule() - Constructor for class org.elasticsearch.search.aggregations.AggregationModule
 
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
 
AggregationPhase - Class in org.elasticsearch.search.aggregations
 
AggregationPhase(AggregationParseElement, AggregationBinaryParseElement) - Constructor for class org.elasticsearch.search.aggregations.AggregationPhase
 
AggregationPhase.AggregationsCollector - Class in org.elasticsearch.search.aggregations
 
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() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
 
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
 
AggregationsCollector(Collection<Aggregator>, AggregationContext) - Constructor for class org.elasticsearch.search.aggregations.AggregationPhase.AggregationsCollector
 
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() - Constructor for class org.elasticsearch.index.mapper.FieldMapperListener.Aggregator
 
Aggregator() - Constructor for class org.elasticsearch.index.mapper.ObjectMapperListener.Aggregator
 
Aggregator - Class in org.elasticsearch.search.aggregations
 
Aggregator(String, Aggregator.BucketAggregationMode, AggregatorFactories, long, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.Aggregator
Constructs a new Aggregator.
Aggregator(GeoDistance.FixedSourceDistance, GeoDistanceFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetExecutor.Aggregator
 
Aggregator(GeoDistance.FixedSourceDistance, GeoDistanceFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetExecutor.Aggregator
 
Aggregator(DoubleObjectOpenHashMap<InternalTermsStatsDoubleFacet.DoubleEntry>) - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor.Aggregator
 
Aggregator(LongObjectOpenHashMap<InternalTermsStatsLongFacet.LongEntry>) - Constructor for class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor.Aggregator
 
Aggregator(ObjectObjectOpenHashMap<HashedBytesRef, InternalTermsStatsStringFacet.StringEntry>) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor.Aggregator
 
Aggregator.BucketAggregationMode - Enum in org.elasticsearch.search.aggregations
Defines the nature of the aggregator's aggregation execution when nested in other aggregators and the buckets they create.
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
 
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>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorParsers
Constructs the AggregatorParsers out of all the given parsers
AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor.AggregatorPriorityQueue
 
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.
AggregatorValueProc(DoubleIntOpenHashMap, Set<BytesRef>, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetExecutor.AggregatorValueProc
 
AggregatorValueProc(LongIntOpenHashMap, Set<BytesRef>, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongFacetExecutor.AggregatorValueProc
 
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() - Method in class org.elasticsearch.index.aliases.IndexAlias
 
alias(String) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
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(IndicesAliasesRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
aliases(IndicesAliasesRequest, ActionListener<IndicesAliasesResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
aliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
aliases() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
aliases() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
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.
aliasesExist(GetAliasesRequest, ActionListener<AliasesExistResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
aliasesExist(GetAliasesRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
AliasesExistAction - Class in org.elasticsearch.action.admin.indices.alias.exists
 
AliasesExistRequestBuilder - Class in org.elasticsearch.action.admin.indices.alias.exists
 
AliasesExistRequestBuilder(IndicesAdminClient, 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
 
AliasesMissingException - Exception in org.elasticsearch.rest.action.admin.indices.alias.delete
 
AliasesMissingException(String...) - Constructor for exception org.elasticsearch.rest.action.admin.indices.alias.delete.AliasesMissingException
 
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) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
 
AliasFilterParsingException(Index, String, String, Throwable) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
 
AliasMetaData - Class in org.elasticsearch.cluster.metadata
 
AliasMetaData.Builder - Class in org.elasticsearch.cluster.metadata
 
AliasValidator - Class in org.elasticsearch.cluster.metadata
Validator for an alias, to be used before adding an alias to the index metadata and make sure the alias is valid
AliasValidator(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() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
all() - Method in class org.elasticsearch.index.store.distributor.AbstractDistributor
 
all() - Method in interface org.elasticsearch.index.store.distributor.Distributor
Returns all directories
ALL_NODES - Static variable in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
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
 
AllDocIdSet - Class in org.elasticsearch.common.lucene.docset
A DocIdSet that matches all docs up to a maxDoc.
AllDocIdSet(int) - Constructor for class org.elasticsearch.common.lucene.docset.AllDocIdSet
 
AllDocIdSet.Iterator - Class in org.elasticsearch.common.lucene.docset
 
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() - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
AllFieldMapper(String, FieldType, NamedAnalyzer, NamedAnalyzer, EnabledAttributeMapper, boolean, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
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(IndexMetaData[], LocalAllocateDangledIndices.Listener) - Method in class org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
allocateUnassigned(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.GatewayAllocator
 
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.local.LocalGatewayAllocator
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.none.NoneGatewayAllocator
 
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
Factory to create AllocationCommands
AllocationCommands - Class in org.elasticsearch.cluster.routing.allocation.command
A simple AllocationCommand composite managing several AllocationCommand implementations
AllocationCommands(AllocationCommand...) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
Creates a new set of AllocationCommands
AllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
AllocationDecider is an abstract base class that allows to make dynamic cluster- or index-wide shard allocation decisions on a per-node basis.
AllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
Initializes a new AllocationDecider
AllocationDeciders - Class in org.elasticsearch.cluster.routing.allocation.decider
A composite AllocationDecider combining the "decision" of multiple AllocationDecider implementations into a single allocation decision.
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
 
AllocationDecidersModule - Class in org.elasticsearch.cluster.routing.allocation.decider
This module configures several AllocationDeciders that make configuration specific decisions if shards can be allocated on certain nodes.
AllocationDecidersModule(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecidersModule
 
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
AllocationModule - Class in org.elasticsearch.cluster.routing.allocation
The AllocationModule manages several modules related to the allocation process.
AllocationModule(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationModule
 
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_TYPE_WRAPPER - Static variable in class org.elasticsearch.index.mapper.DocumentMapper
 
ALLOW_UNMAPPED - Static variable in class org.elasticsearch.index.query.IndexQueryParserService
 
allowAliasesToMultipleIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
 
ALLOWED_CONTENT_FIELD_NAMES - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
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
 
allowValue() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
allowValue() - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
 
allPrimaryShardsActive() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
Returns true if all shards are primary and active.
allPrimaryShardsUnassigned() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
Returns true if all primary shards are in ShardRoutingState.UNASSIGNED state.
allReplicasActive(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
Returns true iff all replicas are active for the given shard routing.
allShards(String...) - Method in class org.elasticsearch.cluster.routing.RoutingTable
All the shards (replicas) for the provided indices.
allShardsGrouped(String...) - Method in class org.elasticsearch.cluster.routing.RoutingTable
All the shards (primary + replicas) for the provided indices grouped (each group is a single element, consisting of the shard).
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
 
AllTermQuery.AllTermWeight - Class in org.elasticsearch.common.lucene.all
 
AllTermQuery.AllTermWeight.AllTermSpanScorer - Class in org.elasticsearch.common.lucene.all
 
allTerms(boolean) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
Sets all possible terms to be loaded, even ones with 0 count.
allTerms() - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
Marks all terms to be returned, even ones with 0 counts.
AllTermSpanScorer(TermSpans, Weight, Similarity.SimScorer) - Constructor for class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
AllTermWeight(AllTermQuery, IndexSearcher) - Constructor for class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight
 
AllTokenStream - Class in org.elasticsearch.common.lucene.all
 
allTokenStream(String, AllEntries, Analyzer) - Static method in class org.elasticsearch.common.lucene.all.AllTokenStream
 
AlreadyExpiredException - Exception in org.elasticsearch.index
 
AlreadyExpiredException(String, String, String, long, long, long) - 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
 
ALWAYS_RANDOM_ACCESS_FILTER_STRATEGY - Static variable in class org.elasticsearch.common.lucene.search.XFilteredQuery
 
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) - Constructor for class org.elasticsearch.index.analysis.AnalysisModule
 
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
 
AnalysisService(Index, Settings) - Constructor for class org.elasticsearch.index.analysis.AnalysisService
 
AnalysisService(Index, Settings, 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
A marker annotation on CharFilterFactory, AnalyzerProvider, TokenFilterFactory, or @TokenizerFactory which will cause the provider/factory to only be created when explicit settings are provided.
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(AnalyzeRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
analyze(AnalyzeRequest, ActionListener<AnalyzeResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
 
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(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() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
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() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
analyzer() - Method in class org.elasticsearch.index.mapper.ParseContext
 
analyzer(Analyzer) - Method in class org.elasticsearch.index.mapper.ParseContext
 
analyzer() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
analyzer(Analyzer) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
analyzer() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
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.FuzzyLikeThisFieldQueryBuilder
The analyzer that will be used to analyze the text.
analyzer(String) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
The analyzer that will be used to analyze the text.
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.MoreLikeThisFieldQueryBuilder
Deprecated.
The analyzer that will be used to analyze the text.
analyzer(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
The analyzer that will be used to analyze the text.
analyzer(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
Explicitly set the analyzer to use.
analyzer(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
The optional analyzer used to analyze the query string.
analyzer(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
Specify an analyzer to use for the query
analyzer - Variable in class org.elasticsearch.index.search.MatchQuery
 
analyzer(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
 
analyzer() - Method in class org.elasticsearch.search.highlight.HighlighterContext
 
analyzer(Analyzer) - Method in class org.elasticsearch.search.highlight.HighlighterContext
 
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(String) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
Constructs a new analyzer request for the provided text.
AnalyzeRequest(String, String) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
Constructs a new analyzer request for the provided index and text.
AnalyzeRequestBuilder - Class in org.elasticsearch.action.admin.indices.analyze
 
AnalyzeRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
 
AnalyzeRequestBuilder(IndicesAdminClient, 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>) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
 
AnalyzeResponse.AnalyzeToken - Class in org.elasticsearch.action.admin.indices.analyze
 
analyzerMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
AnalyzerMapper - Class in org.elasticsearch.index.mapper.internal
 
AnalyzerMapper() - Constructor for class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
AnalyzerMapper(String) - Constructor for class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
AnalyzerMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
AnalyzerMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
AnalyzerMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
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) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
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.
AndDocIdSet - Class in org.elasticsearch.common.lucene.docset
 
AndDocIdSet(DocIdSet[]) - Constructor for class org.elasticsearch.common.lucene.docset.AndDocIdSet
 
AndFilter - Class in org.elasticsearch.common.lucene.search
 
AndFilter(List<? extends Filter>) - Constructor for class org.elasticsearch.common.lucene.search.AndFilter
 
andFilter(FilterBuilder...) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
AndFilterBuilder - Class in org.elasticsearch.index.query
A filter that matches documents matching boolean combinations of other filters.
AndFilterBuilder(FilterBuilder...) - Constructor for class org.elasticsearch.index.query.AndFilterBuilder
 
AndFilterParser - Class in org.elasticsearch.index.query
 
AndFilterParser() - Constructor for class org.elasticsearch.index.query.AndFilterParser
 
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() - Method in class org.elasticsearch.index.store.distributor.AbstractDistributor
 
any() - Method in interface org.elasticsearch.index.store.distributor.Distributor
Selects one of the directories based on distribution strategy
any(String, InternalAggregation.Type, SearchContext) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
 
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, Settings, 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(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.
apply(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(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(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
 
apply(double, double) - Method in enum org.elasticsearch.search.MultiValueMode
Applies the sort mode and returns the result.
apply(long, long) - Method in enum org.elasticsearch.search.MultiValueMode
Applies the sort mode and returns the result.
apply(BytesRef, BytesRef) - Method in enum org.elasticsearch.search.MultiValueMode
 
ApplyAcceptedDocsFilter - Class in org.elasticsearch.common.lucene.search
The assumption is that the underlying filter might not apply the accepted docs, so this filter helps to wrap the actual filter and apply the actual accepted docs.
ApplyAcceptedDocsFilter(Filter) - Constructor for class org.elasticsearch.common.lucene.search.ApplyAcceptedDocsFilter
 
applyFailedShard(ClusterState, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
 
applyFailedShards(ClusterState, List<ShardRouting>) - 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 class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
applyFailedShards(FailedRerouteAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.GatewayAllocator
 
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.local.LocalGatewayAllocator
 
applyFailedShards(FailedRerouteAllocation) - Method in class org.elasticsearch.gateway.none.NoneGatewayAllocator
 
applyMinimumShouldMatch(BooleanQuery, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
 
applyOrd(int, int) - Method in enum org.elasticsearch.search.MultiValueMode
 
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 class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
applyStartedShards(StartedRerouteAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.GatewayAllocator
Apply all shards
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.local.LocalGatewayAllocator
 
applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.gateway.none.NoneGatewayAllocator
 
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, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ArabicAnalyzerProvider
 
ArabicNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
 
ArabicNormalizationFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ArabicNormalizationFilterFactory
 
ArabicStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
ArabicStemTokenFilterFactory(Index, Settings, 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, Settings, 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.HashedBytesArray
 
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
 
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.HashedBytesArray
 
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.
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, Settings, 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
 
asFilter(String...) - Method in class org.elasticsearch.index.query.support.XContentStructure
Use the captured bytes to parse the inner filter using the specified types.
asFilter(String...) - Method in class org.elasticsearch.index.query.support.XContentStructure.InnerFilter
Return the filter as an XConstantScoreQuery represented by the XContentStructure object, returning the cached Query if it has already been parsed.
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
The list of Aggregations.
asList() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
The list of Aggregations.
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
Returns the Aggregations keyed by aggregation name.
asMap() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
Returns the Aggregations keyed by map.
asMap() - Method in class org.elasticsearch.search.lookup.SearchLookup
 
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.
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 MutableShardRoutings 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
 
assign(MutableShardRouting, String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
Assign a shard to a node.
assignedReplicasIncludingRelocating() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
assignedReplicasIncludingRelocating() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
Returns the number of replicas in this iterator that are not in the ShardRoutingState.UNASSIGNED.
assignedShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Returns a ImmutableList 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.
assignedShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
assignedShardsIt(int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
assignedShardsRandomIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
assignedToNode() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
assignedToNode() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
Returns true iff this shard is assigned to a node ie.
asSimilarity() - Method in class org.elasticsearch.common.unit.Fuzziness
 
asSimilarity(String) - Method in class org.elasticsearch.common.unit.Fuzziness
 
Assisted - Annotation Type in org.elasticsearch.common.inject.assistedinject
Annotates an injected parameter or field whose value comes from an argument to a factory method.
AssistedInject - Annotation Type in org.elasticsearch.common.inject.assistedinject
Deprecated.
FactoryProvider now works better with the standard @Inject annotation. When using that annotation, parameters are matched by name and type rather than by position. In addition, values that use the standard @Inject constructor annotation are eligible for method interception.
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
 
AsyncBroadcastAction(Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction.AsyncBroadcastAction
 
AsynchronousComputationException - Exception in org.elasticsearch.common.inject.internal
Wraps an exception that occured during a computation in a different thread.
AsynchronousComputationException(Throwable) - Constructor for exception org.elasticsearch.common.inject.internal.AsynchronousComputationException
 
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
A list backed by an AtomicReferenceArray with potential null values, easily allowing to get the concrete values as a list using AtomicArray.asList().
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 AtomicReader level cache of the data.
atomicFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
 
atomicFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
 
atomicFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
atomicFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
 
atomicFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
 
AtomicGeoPointFieldData - Interface in org.elasticsearch.index.fielddata
AtomicFieldData specialization for geo points.
AtomicNumericFieldData - Interface in org.elasticsearch.index.fielddata
Specialization of AtomicFieldData for numeric data.
AtomicOrdinalsFieldData - Interface in org.elasticsearch.index.fielddata
Specialization of AtomicFieldData for data that is indexed with ordinals.
AtomicParentChildFieldData - Interface in org.elasticsearch.index.fielddata
Specialization of AtomicFieldData for parent/child mappings.
attemptFails() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
attr - Variable in class org.elasticsearch.common.Table.Cell
 
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).
AUTO - Static variable in class org.elasticsearch.common.unit.Fuzziness
 
AutoCreateIndex - Class in org.elasticsearch.action.support
 
AutoCreateIndex(Settings) - 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.AdapterStreamInput
 
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.transport.netty.ChannelBufferStreamInput
 
availableCodecs() - Method in class org.elasticsearch.index.codec.CodecService
Returns all registered available codec names
availableProcessors() - Method in class org.elasticsearch.monitor.os.OsInfo
 
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, long, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
 
AvgAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.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
 
avgPrimariesPerNode() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
Returns the global average of primaries per node
avgPrimariesPerNode(String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
Returns the average of primaries per node for the given index
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
Creates a new AwarenessAllocationDecider instance
AwarenessAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
Creates a new AwarenessAllocationDecider instance from given settings
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

B

BACKGROUND_IS_SUPERSET - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
 
backgroundFilter(FilterBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
Set the background filter to compare to.
backgroundIsSuperset - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
 
backgroundIsSuperset - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
 
balance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
Balances the nodes on the cluster model according to the weight function.
BALANCED_ALLOCATOR_KEY - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
BalancedShardsAllocator - Class in org.elasticsearch.cluster.routing.allocation.allocator
The BalancedShardsAllocator re-balances the nodes allocations within an cluster based on a BalancedShardsAllocator.WeightFunction.
BalancedShardsAllocator(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
 
BalancedShardsAllocator(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
 
BalancedShardsAllocator.Balancer - Class in org.elasticsearch.cluster.routing.allocation.allocator
BalancedShardsAllocator.Operation - Enum in org.elasticsearch.cluster.routing.allocation.allocator
An enum that donates the actual operation the BalancedShardsAllocator.WeightFunction is applied to.
BalancedShardsAllocator.WeightFunction - Class in org.elasticsearch.cluster.routing.allocation.allocator
This class is the primary weight function used to create balanced over nodes and shards in the cluster.
Balancer(ESLogger, RoutingAllocation, BalancedShardsAllocator.WeightFunction, float) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
 
BarrierTimer() - Constructor for class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
 
base64UUID() - Static method in class org.elasticsearch.common.Strings
Generates a time-based UUID (similar to Flake IDs), which is preferred when generating an ID to be indexed into a Lucene index as primary key.
BaseAliasesRequestBuilder<Response extends ActionResponse,Builder extends BaseAliasesRequestBuilder<Response,Builder>> - Class in org.elasticsearch.action.admin.indices.alias.get
 
BaseAliasesRequestBuilder(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
 
BaseAsyncAction(SearchRequest, ActionListener<SearchResponse>) - Constructor for class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
BaseDateTime - Class in org.joda.time.base
BaseDateTime is an abstract implementation of ReadableDateTime that stores data in long and Chronology fields.
BaseDateTime() - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance set to the current system millisecond time using ISOChronology in the default time zone.
BaseDateTime(DateTimeZone) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance set to the current system millisecond time using ISOChronology in the specified time zone.
BaseDateTime(Chronology) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance set to the current system millisecond time using the specified chronology.
BaseDateTime(long) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance set to the milliseconds from 1970-01-01T00:00:00Z using ISOChronology in the default time zone.
BaseDateTime(long, DateTimeZone) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance set to the milliseconds from 1970-01-01T00:00:00Z using ISOChronology in the specified time zone.
BaseDateTime(long, Chronology) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance set to the milliseconds from 1970-01-01T00:00:00Z using the specified chronology.
BaseDateTime(Object, DateTimeZone) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance from an Object that represents a datetime, forcing the time zone to that specified.
BaseDateTime(Object, Chronology) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance from an Object that represents a datetime, using the specified chronology.
BaseDateTime(int, int, int, int, int, int, int) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance from datetime field values using ISOChronology in the default time zone.
BaseDateTime(int, int, int, int, int, int, int, DateTimeZone) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance from datetime field values using ISOChronology in the specified time zone.
BaseDateTime(int, int, int, int, int, int, int, Chronology) - Constructor for class org.joda.time.base.BaseDateTime
Constructs an instance from datetime field values using the specified chronology.
BaseFilterBuilder - Class in org.elasticsearch.index.query
 
BaseFilterBuilder() - Constructor for class org.elasticsearch.index.query.BaseFilterBuilder
 
BaseFuture<V> - Class in org.elasticsearch.common.util.concurrent
An abstract implementation of the ListenableFuture interface.
BaseFuture() - Constructor for class org.elasticsearch.common.util.concurrent.BaseFuture
 
BaseInnerHitBuilder<T extends BaseInnerHitBuilder> - Class in org.elasticsearch.index.query.support
 
BaseInnerHitBuilder() - Constructor for class org.elasticsearch.index.query.support.BaseInnerHitBuilder
 
BaseInnerHits(SearchContext, Query, Map<String, InnerHitsContext.BaseInnerHits>) - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.BaseInnerHits
 
BaseLineStringBuilder<E extends BaseLineStringBuilder<E>> - Class in org.elasticsearch.common.geo.builders
 
BaseLineStringBuilder() - Constructor for class org.elasticsearch.common.geo.builders.BaseLineStringBuilder
 
BaseLineStringBuilder(ArrayList<Coordinate>) - Constructor for class org.elasticsearch.common.geo.builders.BaseLineStringBuilder
 
basePath() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
Returns base path of the repository
basePath() - Method in class org.elasticsearch.repositories.fs.FsRepository
 
basePath() - Method in class org.elasticsearch.repositories.uri.URLRepository
 
BasePolygonBuilder<E extends BasePolygonBuilder<E>> - Class in org.elasticsearch.common.geo.builders
The BasePolygonBuilder implements the groundwork to create polygons.
BasePolygonBuilder(ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.BasePolygonBuilder
 
BasePolygonBuilder.Ring<P extends ShapeBuilder> - Class in org.elasticsearch.common.geo.builders
 
BaseQueryBuilder - Class in org.elasticsearch.index.query
 
BaseQueryBuilder() - Constructor for class org.elasticsearch.index.query.BaseQueryBuilder
 
BaseRestHandler - Class in org.elasticsearch.rest
Base handler for REST requests.
BaseRestHandler(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.BaseRestHandler
 
BaseTransportRequestHandler<T extends TransportRequest> - Class in org.elasticsearch.transport
A simple based class that always spawns.
BaseTransportRequestHandler() - Constructor for class org.elasticsearch.transport.BaseTransportRequestHandler
 
BaseTransportResponseHandler<T extends TransportResponse> - Class in org.elasticsearch.transport
A simple based class that always spawns.
BaseTransportResponseHandler() - Constructor for class org.elasticsearch.transport.BaseTransportResponseHandler
 
BasqueAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
BasqueAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.BasqueAnalyzerProvider
 
before(Version) - Method in class org.elasticsearch.Version
 
beforeBulk(long, BulkRequest) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
Callback before the bulk is executed.
beforeClose() - Method in class org.elasticsearch.common.component.LifecycleListener
 
beforeCreate(DocumentMapper) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
 
beforeCreate(DocumentMapper) - Method in interface org.elasticsearch.index.mapper.DocumentTypeListener
Invoked just before a new document type has been created.
beforeExecute(Thread, Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
 
beforeFieldAdded(FieldMapper, Field, ParseContext) - Method in interface org.elasticsearch.index.mapper.DocumentMapper.ParseListener
Called before a field is added to the document.
beforeFieldAdded(FieldMapper, Field, Object) - Method in class org.elasticsearch.index.mapper.DocumentMapper.ParseListenerAdapter
 
beforeIndexAddedToCluster(Index, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called on the Master node only before the index is created
beforeIndexAddedToCluster(Index, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexClosed(IndexService) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index get closed.
beforeIndexClosed(IndexService) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexCreated(Index, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index gets created.
beforeIndexCreated(Index, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexDeleted(IndexService) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index gets deleted.
beforeIndexDeleted(IndexService) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index shard gets closed.
beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexShardCreated(ShardId, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index shard gets created.
beforeIndexShardCreated(ShardId, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexShardDeleted(ShardId, Settings) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index shard gets deleted from disk Note: this method is only executed on the first attempt of deleting the shard.
beforeIndexShardDeleted(ShardId, Settings) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeLoad(Terms) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData.PerValueEstimator
Execute any pre-loading estimations for the terms.
beforeLoad(Terms) - Method in class org.elasticsearch.index.fielddata.plain.NonEstimatingEstimator
 
beforeLoad(Terms) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData.PackedArrayEstimator
 
beforeLoad(Terms) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
Determine whether the BlockTreeTermsReader.FieldReader can be used for estimating the field data, adding the estimate to the circuit breaker if it can, otherwise wrapping the terms in a RamAccountingTermsEnum to be estimated on a per-term basis.
beforeLoad(Terms) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.ParentChildEstimator
Wraps the already filtered TermsEnum in a RamAccountingTermsEnum and returns it
beforeLocalFork() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
Before we fork on a local thread, make sure we copy over the bytes if they are unsafe
beforeLocalFork() - Method in class org.elasticsearch.action.explain.ExplainRequest
 
beforeLocalFork() - Method in class org.elasticsearch.action.index.IndexRequest
Before we fork on a local thread, make sure we copy over the bytes if they are unsafe
beforeLocalFork() - Method in class org.elasticsearch.action.percolate.PercolateRequest
Before we fork on a local thread, make sure we copy over the bytes if they are unsafe
beforeLocalFork() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
beforeLocalFork() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Called before the request gets forked into a local thread.
beforeLocalFork() - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
beforeLocalFork() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
beforeLocalFork() - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
beforeMerge(OnGoingMerge) - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
A callback allowing for custom logic before an actual merge starts.
beforeMerge(OnGoingMerge) - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
beforeMerge(OnGoingMerge) - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
beforeMerge(OnGoingMerge) - Method in interface org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider.Listener
A callback before a merge is going to execute.
beforeMerge(OnGoingMerge) - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider.CustomSerialMergeScheduler
Deprecated.
 
beforeRelease() - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
 
beforeRelease() - Method in class org.elasticsearch.common.recycler.DequeRecycler
Called before releasing an object, returns true if the object should be recycled and false otherwise.
beforeStart() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
 
beforeStart() - Method in class org.elasticsearch.action.count.CountRequest
 
beforeStart() - Method in class org.elasticsearch.action.exists.ExistsRequest
 
beforeStart() - Method in class org.elasticsearch.action.search.SearchRequest
 
beforeStart() - Method in class org.elasticsearch.action.suggest.SuggestRequest
 
beforeStart() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
beforeStart() - Method in class org.elasticsearch.common.component.LifecycleListener
 
beforeStop() - Method in class org.elasticsearch.common.component.LifecycleListener
 
beforeUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
beginDownload() - Method in interface org.elasticsearch.common.http.client.HttpDownloadHelper.DownloadProgress
begin a download
beginDownload() - Method in class org.elasticsearch.common.http.client.HttpDownloadHelper.NullProgress
begin a download
beginDownload() - Method in class org.elasticsearch.common.http.client.HttpDownloadHelper.VerboseProgress
begin a download
BigArray - Interface in org.elasticsearch.common.util
Base abstraction of an array.
bigarrays - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
BigArrays - Class in org.elasticsearch.common.util
Utility class to work with arrays.
BigArrays(Settings, PageCacheRecycler, CircuitBreakerService) - Constructor for class org.elasticsearch.common.util.BigArrays
 
BigArrays(Settings, PageCacheRecycler, CircuitBreakerService, boolean) - Constructor for class org.elasticsearch.common.util.BigArrays
 
bigArrays - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
bigArrays - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
bigArrays() - Method in class org.elasticsearch.percolator.PercolateContext
 
bigArrays - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
bigArrays() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
 
bigArrays() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
bigArrays() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
bigArrays() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
bigArrays() - Method in class org.elasticsearch.search.internal.SearchContext
 
bigArrays - Variable in class org.elasticsearch.transport.netty.NettyTransport
 
BigArraysModule - Class in org.elasticsearch.common.util
 
BigArraysModule(Settings) - Constructor for class org.elasticsearch.common.util.BigArraysModule
 
BinaryDVAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
AtomicFieldData impl on top of Lucene's binary doc values.
BinaryDVAtomicFieldData(AtomicReader, String) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryDVAtomicFieldData
 
BinaryDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
BinaryDVIndexFieldData(Index, FieldMapper.Names, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
 
BinaryDVNumericIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
BinaryDVNumericIndexFieldData(Index, FieldMapper.Names, IndexNumericFieldData.NumericType, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryDVNumericIndexFieldData
 
binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
binaryField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
BinaryFieldMapper - Class in org.elasticsearch.index.mapper.core
 
BinaryFieldMapper(FieldMapper.Names, FieldType, Boolean, Boolean, long, PostingsFormatProvider, DocValuesFormatProvider, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
BinaryFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
BinaryFieldMapper.CustomBinaryDocValuesField - Class in org.elasticsearch.index.mapper.core
 
BinaryFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
BinaryFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
binarySearch(double[], double, double) - Static method in class org.elasticsearch.common.util.ArrayUtils
Return the index of value in array, or -1 if there is no such index.
binaryValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
binaryValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
Reads a plain binary value that was written via one of the following methods: XContentBuilder.field(String, org.elasticsearch.common.bytes.BytesReference) XContentBuilder.field(String, byte[], int, int)} XContentBuilder.field(String, byte[])} as well as via their XContentBuilderString variants of the separated value methods.
binaryValue() - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.CustomBinaryDocValuesField
 
binaryValue() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericDocValuesField
 
binaryValue() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericDocValuesField
 
binaryValue() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomLongNumericDocValuesField
 
binaryValue() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.CustomGeoPointDocValuesField
 
bind(Key<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
 
bind(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
 
bind(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
 
bind(Key<T>) - Method in interface org.elasticsearch.common.inject.Binder
See the EDSL examples at Binder.
bind(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.Binder
See the EDSL examples at Binder.
bind(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
See the EDSL examples at Binder.
bind(Key<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
 
bind(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
 
bind(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
 
bindConstant() - Method in class org.elasticsearch.common.inject.AbstractModule
 
bindConstant() - Method in interface org.elasticsearch.common.inject.Binder
See the EDSL examples at Binder.
bindConstant() - Method in class org.elasticsearch.common.inject.PrivateModule
 
bindDiscovery() - Method in class org.elasticsearch.discovery.zen.ZenDiscoveryModule
 
binder() - Method in class org.elasticsearch.common.inject.AbstractModule
Gets direct access to the underlying Binder.
Binder - Interface in org.elasticsearch.common.inject
Collects configuration information (primarily bindings) which will be used to create an Injector.
binder - Variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
binder() - Method in class org.elasticsearch.common.inject.PrivateModule
Returns the current binder.
binder() - Method in class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings
 
binder() - Method in class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings
 
bindHost - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
BindHttpException - Exception in org.elasticsearch.http
 
BindHttpException(String) - Constructor for exception org.elasticsearch.http.BindHttpException
 
BindHttpException(String, Throwable) - Constructor for exception org.elasticsearch.http.BindHttpException
 
Binding<T> - Interface in org.elasticsearch.common.inject
A mapping from a key (type and optional annotation) to the strategy for getting instances of the type.
BINDING_TO_NULL - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
bindingAlreadySet(Key<?>, Object) - Method in class org.elasticsearch.common.inject.internal.Errors
 
BindingAnnotation - Annotation Type in org.elasticsearch.common.inject
Annotates annotations which are used for binding.
BindingBuilder<T> - Class in org.elasticsearch.common.inject.internal
Bind a non-constant key.
BindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.BindingBuilder
 
BindingImpl<T> - Class in org.elasticsearch.common.inject.internal
 
BindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.BindingImpl
 
BindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.BindingImpl
 
BindingScopingVisitor<V> - Interface in org.elasticsearch.common.inject.spi
Visits each of the strategies used to scope an injection.
BindingTargetVisitor<T,V> - Interface in org.elasticsearch.common.inject.spi
Visits each of the strategies used to find an instance to satisfy an injection.
bindingToProvider() - Method in class org.elasticsearch.common.inject.internal.Errors
 
bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in class org.elasticsearch.common.inject.AbstractModule
 
bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in interface org.elasticsearch.common.inject.Binder
Registers a listener for injectable types.
bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in class org.elasticsearch.common.inject.PrivateModule
 
bindProperties(Binder, Map<String, String>) - Static method in class org.elasticsearch.common.inject.name.Names
Creates a constant binding to @Named(key) for each entry in properties.
bindProperties(Binder, Properties) - Static method in class org.elasticsearch.common.inject.name.Names
Creates a constant binding to @Named(key) for each property.
bindScope(Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.common.inject.AbstractModule
 
bindScope(Class<? extends Annotation>, Scope) - Method in interface org.elasticsearch.common.inject.Binder
Binds a scope to an annotation.
bindScope(Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.common.inject.PrivateModule
 
BindTransportException - Exception in org.elasticsearch.transport
 
BindTransportException(String) - Constructor for exception org.elasticsearch.transport.BindTransportException
 
BindTransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.BindTransportException
 
bits() - Method in class org.elasticsearch.common.lucene.docset.AllDocIdSet
 
bits() - Method in class org.elasticsearch.common.lucene.docset.AndDocIdSet
 
bits() - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSet
 
bits() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet
 
bits() - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet
 
BitsBasedIterator(Bits) - Constructor for class org.elasticsearch.common.lucene.docset.NotDocIdSet.BitsBasedIterator
 
BitsDocIdSetIterator - Class in org.elasticsearch.common.lucene.docset
A Bits based iterator.
BitsDocIdSetIterator(Bits) - Constructor for class org.elasticsearch.common.lucene.docset.BitsDocIdSetIterator
 
BitsDocIdSetIterator(int, Bits) - Constructor for class org.elasticsearch.common.lucene.docset.BitsDocIdSetIterator
 
BitsDocIdSetIterator.FilteredIterator - Class in org.elasticsearch.common.lucene.docset
 
blacklistAdditions() - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
blend(TermContext[], int, IndexReader) - Method in class org.apache.lucene.queries.BlendedTermQuery
 
BlendedTermQuery - Class in org.apache.lucene.queries
BlendedTermQuery can be used to unify term statistics across one or more fields in the index.
BlendedTermQuery(Term[]) - Constructor for class org.apache.lucene.queries.BlendedTermQuery
 
blendTerm(Term, FieldMapper) - Method in class org.elasticsearch.index.search.MultiMatchQuery.CrossFieldsQueryBuilder
 
blendTerm(Term, FieldMapper) - Method in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
 
blendTermQuery(Term, FieldMapper) - Method in class org.elasticsearch.index.search.MatchQuery
 
blendTermQuery(Term, FieldMapper) - Method in class org.elasticsearch.index.search.MultiMatchQuery
 
BlobContainer - Interface in org.elasticsearch.common.blobstore
 
blobContainer(BlobPath) - Method in interface org.elasticsearch.common.blobstore.BlobStore
 
blobContainer(BlobPath) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
blobContainer(BlobPath) - Method in class org.elasticsearch.common.blobstore.url.URLBlobStore
BlobContainer.BlobNameFilter - Interface in org.elasticsearch.common.blobstore
 
blobExists(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
blobExists(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
blobExists(String) - Method in class org.elasticsearch.common.blobstore.url.URLBlobContainer
This operation is not supported by URLBlobContainer
BlobMetaData - Interface in org.elasticsearch.common.blobstore
 
BlobPath - Class in org.elasticsearch.common.blobstore
 
BlobPath() - Constructor for class org.elasticsearch.common.blobstore.BlobPath
 
BlobStore - Interface in org.elasticsearch.common.blobstore
 
blobStore - Variable in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
blobStore - Variable in class org.elasticsearch.common.blobstore.url.URLBlobContainer
 
blobStore() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
Returns initialized and ready to use BlobStore

This method is first called in the BlobStoreRepository.doStart() method.

blobStore() - Method in class org.elasticsearch.repositories.fs.FsRepository
Returns initialized and ready to use BlobStore

This method is first called in the BlobStoreRepository.doStart() method.

blobStore() - Method in class org.elasticsearch.repositories.uri.URLRepository
Returns initialized and ready to use BlobStore

This method is first called in the BlobStoreRepository.doStart() method.

BlobStoreException - Exception in org.elasticsearch.common.blobstore
 
BlobStoreException(String) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
 
BlobStoreException(String, Throwable) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
 
BlobStoreIndexShardRepository - Class in org.elasticsearch.index.snapshots.blobstore
Blob store based implementation of IndexShardRepository
BlobStoreIndexShardRepository(Settings, RepositoryName, IndicesService, ClusterService) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
 
BlobStoreIndexShardRepository.RateLimiterListener - Interface in org.elasticsearch.index.snapshots.blobstore
 
BlobStoreIndexShardSnapshot - Class in org.elasticsearch.index.snapshots.blobstore
Shard snapshot metadata
BlobStoreIndexShardSnapshot(String, long, List<BlobStoreIndexShardSnapshot.FileInfo>, long, long, int, long) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
Constructs new shard snapshot metadata from snapshot metadata
BlobStoreIndexShardSnapshot.FileInfo - Class in org.elasticsearch.index.snapshots.blobstore
Information about snapshotted file
BlobStoreIndexShardSnapshots - Class in org.elasticsearch.index.snapshots.blobstore
Contains information about all snapshot for the given shard in repository

This class is used to find files that were already snapshoted and clear out files that no longer referenced by any snapshots

BlobStoreIndexShardSnapshots(List<BlobStoreIndexShardSnapshot>) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
 
BlobStoreRepository - Class in org.elasticsearch.repositories.blobstore
BlobStore - based implementation of Snapshot Repository

This repository works with any BlobStore implementation.

BlobStoreRepository(String, RepositorySettings, IndexShardRepository) - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreRepository
Constructs new BlobStoreRepository
BlobStoreSnapshot - Class in org.elasticsearch.repositories.blobstore
Immutable snapshot description for BlobStoreRepository

Stored in the the root of the repository, see BlobStoreRepository for more information.

BlobStoreSnapshot.Builder - Class in org.elasticsearch.repositories.blobstore
BlobStoreSnapshot builder
blockingClient - Variable in class org.elasticsearch.transport.netty.NettyTransport
 
BlockingClusterStatePublishResponseHandler - Class in org.elasticsearch.discovery
Handles responses obtained when publishing a new cluster state from master to all non master nodes.
BlockingClusterStatePublishResponseHandler(Set<DiscoveryNode>) - Constructor for class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
Creates a new BlockingClusterStatePublishResponseHandler
blockingServer - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
blocks() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
blocks(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
blocks(Set<ClusterBlock>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
 
blocks() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
 
blocks() - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
 
blocks(ClusterBlocks) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
blocks() - Method in class org.elasticsearch.cluster.ClusterState
 
blocks(ClusterBlocks.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
blocks(ClusterBlocks) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
blocks() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
blocksChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
BLOOM_CODEC_NAME - Static variable in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
Deprecated.
 
BLOOM_CODEC_VERSION - Static variable in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
Deprecated.
 
BLOOM_CODEC_VERSION_CHECKSUM - Static variable in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
Deprecated.
 
BLOOM_CODEC_VERSION_CURRENT - Static variable in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
Deprecated.
 
BloomFilter - Class in org.elasticsearch.common.util
A bloom filter.
BloomFilter.Factory - Class in org.elasticsearch.common.util
A factory that can use different fpp based on size.
BloomFilter.Factory.Entry - Class in org.elasticsearch.common.util
 
BloomFilteredFieldsConsumer(FieldsConsumer, SegmentWriteState, PostingsFormat) - Constructor for class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsConsumer
Deprecated.
 
BloomFilteredFieldsProducer(SegmentReadState) - Constructor for class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
Deprecated.
 
BloomFilteredTerms(Terms, BloomFilter) - Constructor for class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredTerms
Deprecated.
 
BloomFilterPostingsFormat - Class in org.elasticsearch.index.codec.postingsformat
Deprecated.
only for reading old segments
BloomFilterPostingsFormat(PostingsFormat, BloomFilter.Factory) - Constructor for class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
Deprecated.
Creates Bloom filters for a selection of fields created in the index.
BloomFilterPostingsFormat() - Constructor for class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat
Deprecated.
 
BloomFilterPostingsFormat.BloomFilteredFieldsConsumer - Class in org.elasticsearch.index.codec.postingsformat
Deprecated.
 
BloomFilterPostingsFormat.BloomFilteredFieldsProducer - Class in org.elasticsearch.index.codec.postingsformat
Deprecated.
 
BloomFilterPostingsFormat.BloomFilteredTerms - Class in org.elasticsearch.index.codec.postingsformat
Deprecated.
 
BloomFilterPostingsFormatProvider - Class in org.elasticsearch.index.codec.postingsformat
Deprecated.
only for reading old segments
BloomFilterPostingsFormatProvider(Settings, Map<String, PostingsFormatProvider.Factory>, String, Settings) - Constructor for class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormatProvider
Deprecated.
 
bloomPostings - Variable in class org.elasticsearch.index.codec.postingsformat.Elasticsearch090PostingsFormat
Deprecated.
 
BM25SimilarityProvider - Class in org.elasticsearch.index.similarity
SimilarityProvider for the BM25Similarity.
BM25SimilarityProvider(String, Settings) - Constructor for class org.elasticsearch.index.similarity.BM25SimilarityProvider
 
BOOLEAN - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
booleanBlendedQuery(Term[], boolean) - Static method in class org.apache.lucene.queries.BlendedTermQuery
 
booleanBlendedQuery(Term[], float[], boolean) - Static method in class org.apache.lucene.queries.BlendedTermQuery
 
booleanField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
BooleanFieldMapper - Class in org.elasticsearch.index.mapper.core
 
BooleanFieldMapper(FieldMapper.Names, float, FieldType, Boolean, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
BooleanFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
BooleanFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
BooleanFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
BooleanFieldMapper.Values - Class in org.elasticsearch.index.mapper.core
 
Booleans - Class in org.elasticsearch.common
 
Booleans() - Constructor for class org.elasticsearch.common.Booleans
 
booleanValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
booleanValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
boolFilter() - Static method in class org.elasticsearch.index.query.FilterBuilders
 
BoolFilterBuilder - Class in org.elasticsearch.index.query
A filter that matches documents matching boolean combinations of other filters.
BoolFilterBuilder() - Constructor for class org.elasticsearch.index.query.BoolFilterBuilder
 
BoolFilterParser - Class in org.elasticsearch.index.query
 
BoolFilterParser() - Constructor for class org.elasticsearch.index.query.BoolFilterParser
 
boolQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
A Query that matches documents matching boolean combinations of other queries.
BoolQueryBuilder - Class in org.elasticsearch.index.query
A Query that matches documents matching boolean combinations of other queries.
BoolQueryBuilder() - Constructor for class org.elasticsearch.index.query.BoolQueryBuilder
 
BoolQueryParser - Class in org.elasticsearch.index.query
 
BoolQueryParser(Settings) - Constructor for class org.elasticsearch.index.query.BoolQueryParser
 
boost() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
boost(float) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
boost(int) - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
boost() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
 
boost - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
boost() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
boost - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
boost(float) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
BOOST - Static variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
boost() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
 
boost() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.ValueAndBoost
Boost either parsed from the document or defaulted.
boost() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
BOOST - Static variable in class org.elasticsearch.index.mapper.internal.VersionFieldMapper.Defaults
 
boost(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
boost(float) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Sets the boost for this query.
boost(float) - Method in interface org.elasticsearch.index.query.BoostableQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
Set the boost to apply to the query.
boost(float) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.FilteredQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.HasParentQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
Set the boost to apply to the query.
boost(float) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
 
boost(float) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
Set the boost to apply to the query.
boost(float) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.SpanTermQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.TermQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.TopChildrenQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
Sets the boost for this query.
BOOST_TERMS - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
BOOST_WEIGHT_ERROR_MESSAGE - Static variable in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
Deprecated.
 
BoostableQueryBuilder<B extends BoostableQueryBuilder<B>> - Interface in org.elasticsearch.index.query
Query builder which allow setting some boost
boostFactor(float) - Method in class org.elasticsearch.index.query.functionscore.factor.FactorBuilder
Deprecated.
Sets the boost factor for this query.
boostFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
BoostFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
BoostFieldMapper(Settings) - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
BoostFieldMapper(String, String, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
BoostFieldMapper(String, String, int, float, FieldType, Boolean, Float, PostingsFormatProvider, DocValuesFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
BoostFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
BoostFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
BoostFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
boostingQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
The BoostingQuery class can be used to effectively demote results that match a given query.
BoostingQueryBuilder - Class in org.elasticsearch.index.query
The BoostingQuery class can be used to effectively demote results that match a given query.
BoostingQueryBuilder() - Constructor for class org.elasticsearch.index.query.BoostingQueryBuilder
 
BoostingQueryParser - Class in org.elasticsearch.index.query
 
BoostingQueryParser() - Constructor for class org.elasticsearch.index.query.BoostingQueryParser
 
boostMode(String) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
Score mode defines how the combined result of score functions will influence the final score together with the sub query score.
boostMode(CombineFunction) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
Score mode defines how the combined result of score functions will influence the final score together with the sub query score.
boosts() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
boosts(ObjectFloatOpenHashMap<String>) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
BoostScoreFunction - Class in org.elasticsearch.common.lucene.search.function
Deprecated.
BoostScoreFunction(float) - Constructor for class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
Deprecated.
 
boostTerms(float) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The boost factor to use when boosting terms.
boostTerms() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The boost factor to use when boosting terms.
boostTerms(float) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Sets the boost factor to use when boosting terms.
boostTerms(float) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the boost factor to use when boosting terms.
bootClassPath() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
Bootstrap - Class in org.elasticsearch.bootstrap
A main entry point when starting from the command line.
Bootstrap() - Constructor for class org.elasticsearch.bootstrap.Bootstrap
 
BOTTOM - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
BOTTOM_LEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
BOTTOM_RIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
BOTTOM_RIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
bottomLeft(double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
Adds bottom left corner.
bottomLeft(GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
bottomLeft(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
BOTTOMLEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
bottomRight - Variable in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
 
bottomRight(Coordinate) - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
 
bottomRight(double, double) - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
 
bottomRight() - Method in interface org.elasticsearch.common.geo.GeoDistance.DistanceBoundingCheck
 
bottomRight() - Method in class org.elasticsearch.common.geo.GeoDistance.Meridian180DistanceBoundingCheck
 
bottomRight() - Method in class org.elasticsearch.common.geo.GeoDistance.SimpleDistanceBoundingCheck
 
bottomRight(double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
Adds bottom right corner.
bottomRight(GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
bottomRight(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
BOTTOMRIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
bottomRight() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
bottomRight() - Method in interface org.elasticsearch.search.aggregations.metrics.geobounds.GeoBounds
Get the bottom-right location of the bounding box.
bottomRight() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
 
boundAddress() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
 
boundAddress() - Method in interface org.elasticsearch.http.HttpServerTransport
 
boundAddress - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
boundAddress() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
boundAddress() - Method in class org.elasticsearch.transport.local.LocalTransport
 
boundAddress - Variable in class org.elasticsearch.transport.netty.NettyTransport
 
boundAddress() - Method in class org.elasticsearch.transport.netty.NettyTransport
 
boundAddress() - Method in interface org.elasticsearch.transport.Transport
The address the transport is bound on.
boundAddress() - Method in class org.elasticsearch.transport.TransportService
 
boundaryChars(char[]) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
When using the highlighterType fast-vector-highlighter this setting defines what constitutes a boundary for highlighting.
boundaryChars(char[]) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 
boundaryChars() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
boundaryMaxScan(Integer) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
When using the highlighterType fast-vector-highlighter this setting controls how far to look for boundary characters, and defaults to 20.
boundaryMaxScan(int) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 
boundaryMaxScan() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
boundedNumberOfProcessors(Settings) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
Returns the number of processors available but at most 32.
BoundedTreeSet<E> - Class in org.elasticsearch.common.collect
A TreeSet that is bounded by size.
BoundedTreeSet(int) - Constructor for class org.elasticsearch.common.collect.BoundedTreeSet
 
BoundedTreeSet(Comparator<? super E>, int) - Constructor for class org.elasticsearch.common.collect.BoundedTreeSet
 
BoundTransportAddress - Class in org.elasticsearch.common.transport
A bounded transport address is a tuple of two TransportAddress, one that represents the address the transport is bounded on, the the published one represents the one clients should communicate on.
BoundTransportAddress(TransportAddress, TransportAddress) - Constructor for class org.elasticsearch.common.transport.BoundTransportAddress
 
BrazilianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
BrazilianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.BrazilianAnalyzerProvider
 
BrazilianStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
BrazilianStemTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.BrazilianStemTokenFilterFactory
 
breaker() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
 
breaker(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node's circuit breaker stats be returned.
breakerService - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
 
BreakerSettings - Class in org.elasticsearch.indices.breaker
Settings for a CircuitBreaker
BreakerSettings(CircuitBreaker.Name, long, double) - Constructor for class org.elasticsearch.indices.breaker.BreakerSettings
 
BreakerSettings(CircuitBreaker.Name, long, double, CircuitBreaker.Type) - Constructor for class org.elasticsearch.indices.breaker.BreakerSettings
 
broadcastDeleteShards(ClusterState, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
broadcastDeleteShards(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
BroadcastOperationRequest<T extends BroadcastOperationRequest> - Class in org.elasticsearch.action.support.broadcast
 
BroadcastOperationRequest() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
BroadcastOperationRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
BroadcastOperationRequest(String[]) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
BroadcastOperationRequestBuilder<Request extends BroadcastOperationRequest<Request>,Response extends BroadcastOperationResponse,RequestBuilder extends BroadcastOperationRequestBuilder<Request,Response,RequestBuilder,Client>,Client extends ElasticsearchClient> - Class in org.elasticsearch.action.support.broadcast
 
BroadcastOperationRequestBuilder(Client, Request) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
 
BroadcastOperationResponse - Class in org.elasticsearch.action.support.broadcast
Base class for all broadcast operation based responses.
BroadcastOperationResponse() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationResponse
 
BroadcastOperationResponse(int, int, int, List<ShardOperationFailedException>) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationResponse
 
BroadcastShardOperationFailedException - Exception in org.elasticsearch.action.support.broadcast
An exception indicating that a failure occurred performing an operation on the shard.
BroadcastShardOperationFailedException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
 
BroadcastShardOperationFailedException(ShardId, Throwable) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
 
BroadcastShardOperationFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
 
BroadcastShardOperationRequest - Class in org.elasticsearch.action.support.broadcast
 
BroadcastShardOperationRequest() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
BroadcastShardOperationRequest(ShardId, BroadcastOperationRequest) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
BroadcastShardOperationRequest(ShardId, OriginalIndices) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
BroadcastShardOperationResponse - Class in org.elasticsearch.action.support.broadcast
 
BroadcastShardOperationResponse() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardOperationResponse
 
BroadcastShardOperationResponse(ShardId) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardOperationResponse
 
Bucket(String, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters.Bucket
 
Bucket(long, long, ValueFormatter, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
 
Bucket(String, double, double, long, List<InternalAggregation>, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Bucket
 
Bucket(String, double, double, long, InternalAggregations, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.Bucket
 
Bucket(String, double, double, long, InternalAggregations, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
 
Bucket(String, double, double, long, List<InternalAggregation>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Bucket
 
Bucket(String, double, double, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range.Bucket
 
Bucket(long, long, long, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
 
Bucket(BytesRef, long, long, long, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
 
Bucket(BytesRef, long, long, long, long, InternalAggregations, double) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
 
Bucket(long, InternalAggregations, boolean, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
 
Bucket(BytesRef, long, InternalAggregations, boolean, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
 
Bucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.Terms.Bucket
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.CountHistogramFacetExecutor
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.FullHistogramFacetExecutor
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.ScriptHistogramFacetExecutor
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.ValueScriptHistogramFacetExecutor
 
bucketAggregationMode - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
bucketAggregationMode() - Method in class org.elasticsearch.search.aggregations.Aggregator
 
bucketAggregations(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
Required method to build the child aggregations of the given bucket (identified by the bucket ordinal).
BucketCollector - Class in org.elasticsearch.search.aggregations
A Collector that can collect data in separate buckets.
BucketCollector() - Constructor for class org.elasticsearch.search.aggregations.BucketCollector
 
BucketCollector.BucketAnalysisCollector - Interface in org.elasticsearch.search.aggregations
Used to gather a summary from a bucket
bucketCountThresholds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
 
BucketCountThresholds(long, long, int, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
BucketCountThresholds() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
BucketCountThresholds(TermsAggregator.BucketCountThresholds) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
bucketDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
Utility method to return the number of documents that fell in the given bucket (identified by the bucket ordinal)
bucketEmptyAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
Utility method to build empty aggregations of the sub aggregators.
bucketMap - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
 
bucketMap - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
 
bucketMap - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
 
BucketPriorityQueue - Class in org.elasticsearch.search.aggregations.bucket.terms.support
 
BucketPriorityQueue(int, Comparator<Terms.Bucket>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.support.BucketPriorityQueue
 
buckets - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
 
buckets - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
 
buckets - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
BUCKETS - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
 
BucketsAggregator - Class in org.elasticsearch.search.aggregations.bucket
 
BucketsAggregator(String, Aggregator.BucketAggregationMode, AggregatorFactories, long, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
 
BucketSignificancePriorityQueue - Class in org.elasticsearch.search.aggregations.bucket.significant
 
BucketSignificancePriorityQueue(int) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.BucketSignificancePriorityQueue
 
BucketUtils - Class in org.elasticsearch.search.aggregations.bucket
Helper functions for common Bucketing functions
BucketUtils() - Constructor for class org.elasticsearch.search.aggregations.bucket.BucketUtils
 
buf - Variable in class org.elasticsearch.common.io.FastCharArrayReader
The character buffer.
buf - Variable in class org.elasticsearch.common.io.FastCharArrayWriter
The buffer where data is stored.
buf - Variable in class org.elasticsearch.common.io.stream.BytesStreamInput
 
BUFFER_SIZE - Static variable in class org.elasticsearch.common.io.Streams
 
BufferedChecksumStreamInput - Class in org.elasticsearch.index.translog
Similar to Lucene's BufferedChecksumIndexInput, however this wraps a StreamInput so anything read will update the checksum
BufferedChecksumStreamInput(StreamInput) - Constructor for class org.elasticsearch.index.translog.BufferedChecksumStreamInput
 
BufferedChecksumStreamOutput - Class in org.elasticsearch.index.translog
Similar to Lucene's BufferedChecksumIndexOutput, however this wraps a StreamOutput so anything written will update the checksum
BufferedChecksumStreamOutput(StreamOutput) - Constructor for class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
 
BufferingFsTranslogFile - Class in org.elasticsearch.index.translog.fs
 
BufferingFsTranslogFile(ShardId, long, RafReference, int) - Constructor for class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
BufferPool(String, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
bufferSize - Variable in class org.elasticsearch.common.network.MulticastChannel.Config
 
bufferSizeInBytes() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
bufferSizeInBytes() - Method in class org.elasticsearch.common.blobstore.url.URLBlobStore
Returns read buffer size
build(InputIterator) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
 
build() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
 
build() - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
Builds a new bulk processor.
Build - Class in org.elasticsearch
 
build() - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
build() - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
build() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
 
build() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
build() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
build() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
build() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
build() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
build() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
build() - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
build() - Method in class org.elasticsearch.common.cli.CliToolConfig.Builder
 
build() - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd.Builder
 
build() - Method in class org.elasticsearch.common.cli.CliToolConfig.OptionBuilder
 
build() - Method in class org.elasticsearch.common.cli.CliToolConfig.OptionGroupBuilder
 
build() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
Builds a new instance of the
build() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
Builds a new instance of the
build() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
Builds a new instance of the
build() - Method in class org.elasticsearch.common.geo.builders.BaseLineStringBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.CircleBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.MultiPointBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
 
build() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new Shape from this builder.
build() - Method in interface org.elasticsearch.common.recycler.Recycler.Factory
 
build() - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
build() - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Builds a Settings (underlying uses ImmutableSettings) based on everything set on this builder.
build() - Method in interface org.elasticsearch.common.settings.Settings.Builder
Builds the settings.
build(Object) - Static method in class org.elasticsearch.common.unit.Fuzziness
 
build() - Method in class org.elasticsearch.index.analysis.CharMatcher.Builder
 
build(AnalysisService) - Method in class org.elasticsearch.index.analysis.CustomAnalyzerProvider
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Builder
 
build(IndexReader, IndexOrdinalsFieldData, Settings, CircuitBreakerService, ESLogger) - Static method in enum org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
Build global ordinals for the provided IndexReader.
build(Settings) - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
Builds an Ordinals instance from the builders current state.
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.DisabledIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.DoubleArrayIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.FloatArrayIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.FSTBytesIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.GeoPointBinaryDVIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.GeoPointCompressedIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.IndexIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.Builder
 
build(Index, Settings, FieldMapper<?>, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.Builder
 
build() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.CopyTo.Builder
 
build(AbstractFieldMapper.Builder, Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.Murmur3FieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper.Builder
 
build(DocumentMapperParser) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.Mapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
build() - Method in class org.elasticsearch.index.query.NestedQueryParser.ToBlockJoinQueryBuilder
 
build() - Method in class org.elasticsearch.index.store.DirectoryService
 
build() - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
build() - Method in class org.elasticsearch.index.store.ram.RamDirectoryService
 
build() - Method in class org.elasticsearch.node.NodeBuilder
Builds the node without starting it.
build() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Builds new BlobStoreSnapshot
build() - Method in class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
build() - Method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
build() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
 
build(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
 
build() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData.Builder
 
build() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser.Builder
 
build() - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping.Builder
 
build() - Method in class org.elasticsearch.search.suggest.context.ContextBuilder
 
build() - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
 
build - Variable in class org.elasticsearch.Version
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.Aggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTermsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
 
buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
 
buildAsBytes(XContentType) - Method in class org.elasticsearch.action.support.QuerySourceBuilder
 
buildAsBytes() - Method in class org.elasticsearch.index.query.BaseFilterBuilder
 
buildAsBytes(XContentType) - Method in class org.elasticsearch.index.query.BaseFilterBuilder
 
buildAsBytes() - Method in class org.elasticsearch.index.query.BaseQueryBuilder
 
buildAsBytes(XContentType) - Method in class org.elasticsearch.index.query.BaseQueryBuilder
 
buildAsBytes() - Method in interface org.elasticsearch.index.query.FilterBuilder
 
buildAsBytes(XContentType) - Method in interface org.elasticsearch.index.query.FilterBuilder
 
buildAsBytes() - Method in interface org.elasticsearch.index.query.QueryBuilder
 
buildAsBytes(XContentType) - Method in interface org.elasticsearch.index.query.QueryBuilder
 
buildAsBytes() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
buildAsBytes(XContentType) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
buildAsBytes() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
Returns a BytesReference representing the suggest lookup request.
buildAsBytes(XContentType) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
Returns a BytesReference representing the suggest lookup request.
buildAsBytes() - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
 
buildAsBytes(XContentType) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
 
buildAsString(String) - Method in class org.elasticsearch.common.blobstore.BlobPath
 
buildAttributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeService
 
buildAttributes() - Method in interface org.elasticsearch.cluster.node.DiscoveryNodeService.CustomAttributesProvider
 
buildBroadcastShardsHeader(XContentBuilder, BroadcastOperationResponse) - Static method in class org.elasticsearch.rest.action.support.RestActions
 
buildConflicts() - Method in class org.elasticsearch.index.mapper.MergeContext
 
buildDocsWithValuesSet() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
Builds a FixedBitSet where each documents bit is that that has one or more ordinals associated with it.
buildDynamicNodes() - Method in interface org.elasticsearch.discovery.zen.ping.unicast.UnicastHostsProvider
Builds the dynamic list of unicast hosts to be used for unicast discovery.
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.Aggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Unmapped
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTermsAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
 
buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
 
buildEmptySubAggregations() - Method in class org.elasticsearch.search.aggregations.Aggregator
 
builder(Client, BulkProcessor.Listener) - Static method in class org.elasticsearch.action.bulk.BulkProcessor
 
Builder(Client, BulkProcessor.Listener) - Constructor for class org.elasticsearch.action.bulk.BulkProcessor.Builder
Creates a builder of bulk processor with the client to use and the listener that will be used to be notified on the completion of bulk requests.
builder() - Static method in class org.elasticsearch.cluster.block.ClusterBlocks
 
Builder() - Constructor for class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
builder(ClusterName) - Static method in class org.elasticsearch.cluster.ClusterState
 
builder(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterState
 
Builder(ClusterState) - Constructor for class org.elasticsearch.cluster.ClusterState.Builder
 
Builder(ClusterName) - Constructor for class org.elasticsearch.cluster.ClusterState.Builder
 
builder(String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
 
Builder(AliasMetaData) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
 
builder(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
builder(IndexMetaData) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
Builder(IndexMetaData) - Constructor for class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
builder(String) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
Builder(IndexTemplateMetaData) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
builder() - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
builder(MetaData) - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
Builder() - Constructor for class org.elasticsearch.cluster.metadata.MetaData.Builder
 
Builder(MetaData) - Constructor for class org.elasticsearch.cluster.metadata.MetaData.Builder
 
builder() - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
builder(DiscoveryNodes) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
Builder() - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
Builder(DiscoveryNodes) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
builder(String) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
Builder(String) - Constructor for class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
Builder(IndexShardRoutingTable) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
Builder(ShardId, boolean) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
builder() - Static method in class org.elasticsearch.cluster.routing.RoutingTable
 
builder(RoutingTable) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
 
Builder() - Constructor for class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
Builder(RoutingTable) - Constructor for class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
builder() - Static method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
 
builder(int) - Static method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
 
builder(ImmutableOpenIntMap<VType>) - Static method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
 
Builder() - Constructor for class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
 
Builder(int) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
 
Builder(ImmutableOpenIntMap<VType>) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
 
builder() - Static method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
builder(int) - Static method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
builder(ImmutableOpenLongMap<VType>) - Static method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
Builder() - Constructor for class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
Builder(int) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
Builder(ImmutableOpenLongMap<VType>) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
builder() - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
 
builder(int) - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
 
builder(ImmutableOpenMap<KType, VType>) - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
 
Builder() - Constructor for class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
 
Builder(int) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
 
Builder(ImmutableOpenMap<KType, VType>) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
 
builder(DateTimeUnit) - Static method in class org.elasticsearch.common.rounding.TimeZoneRounding
 
builder(TimeValue) - Static method in class org.elasticsearch.common.rounding.TimeZoneRounding
 
Builder(DateTimeUnit) - Constructor for class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
Builder(TimeValue) - Constructor for class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
builder() - Static method in class org.elasticsearch.common.settings.ImmutableSettings
 
builder(XContent) - Static method in class org.elasticsearch.common.xcontent.XContentBuilder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.DisabledIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.DoubleArrayIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.FloatArrayIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.FSTBytesIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointBinaryDVIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointCompressedIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.IndexIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.Builder
 
Builder() - Constructor for class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.Builder
 
Builder(String, FieldType) - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper.CopyTo.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.Murmur3FieldMapper.Builder
 
Builder(String, FieldType, int) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.TokenCountFieldMapper.Builder
 
Builder(String, Settings, RootObjectMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.AnalyzerMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper.Builder
 
Builder() - Constructor for class org.elasticsearch.index.mapper.internal.VersionFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.Mapper.Builder
 
builder - Variable in class org.elasticsearch.index.mapper.Mapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
 
Builder(String) - Constructor for class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
Builder(String, GeoPoint) - Constructor for class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
Builder(String, String) - Constructor for class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
Builder(String, String, boolean) - Constructor for class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
builder() - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Creates new BlobStoreSnapshot builder
Builder() - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
 
builder() - Static method in class org.elasticsearch.river.cluster.RiverClusterState
 
Builder() - Constructor for class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
builder() - Static method in class org.elasticsearch.river.routing.RiversRouting
 
Builder() - Constructor for class org.elasticsearch.river.routing.RiversRouting.Builder
 
builder() - Static method in class org.elasticsearch.search.aggregations.AggregatorFactories
 
Builder() - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
 
builder() - Static method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData
 
builder(ValuesSource.MetaData) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData
 
builder() - Method in interface org.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttribute
Return the builder from which the term is derived.
builder() - Method in class org.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttributeImpl
 
Builder(String) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping.Builder
 
Builder(String, String) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping.Builder
 
Builder(String) - Constructor for class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
 
Builder(String, boolean, int...) - Constructor for class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
 
BuilderContext(Settings, ContentPath) - Constructor for class org.elasticsearch.index.mapper.Mapper.BuilderContext
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.FacetExecutor
Builds the facet.
buildFacet(String) - Method in class org.elasticsearch.search.facet.filter.FilterFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.histogram.CountHistogramFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.histogram.FullHistogramFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.histogram.ScriptHistogramFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.histogram.ValueHistogramFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.histogram.ValueScriptHistogramFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.query.QueryFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.range.KeyValueRangeFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.range.RangeFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.range.ScriptRangeFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.statistical.ScriptStatisticalFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetExecutor
 
buildFacet(String, int, int, long, long, TermsFacet.ComparatorType, HashedAggregator) - Static method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.terms.strings.ScriptTermsStringFieldFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.terms.unmapped.UnmappedFieldExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor
 
buildFacet(String) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor
 
buildFactory(SearchContext, String, ValuesSourceConfig<ValuesSource.Numeric>, double[], double, boolean) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesParser
 
buildFactory(SearchContext, String, ValuesSourceConfig<ValuesSource.Numeric>, double[], double, boolean) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksParser
 
buildFactory(SearchContext, String, ValuesSourceConfig<ValuesSource.Numeric>, double[], double, boolean) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesParser
 
buildFailureMessage() - Method in class org.elasticsearch.action.bulk.BulkResponse
 
buildFromKeyValue(DiscoveryNodeFilters.OpType, Map<String, String>) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
 
buildFromSettings(DiscoveryNodeFilters.OpType, String, Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
 
buildFromSimplifiedDef(String, Object...) - Static method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
 
buildFromString(String) - Static method in class org.elasticsearch.common.util.BloomFilter.Factory
Supports just passing fpp, as in "0.01", and also ranges, like "50k=0.01,1m=0.05".
buildFromTerms(TermsEnum) - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
This method iterates all terms in the given TermsEnum and associates each terms ordinal with the terms documents.
buildFullName(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
buildGeometry(GeometryFactory, boolean) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
 
buildGroupedQueries(MultiMatchQueryBuilder.Type, Map<String, Float>, Object, String) - Method in class org.elasticsearch.index.search.MultiMatchQuery.CrossFieldsQueryBuilder
 
buildGroupedQueries(MultiMatchQueryBuilder.Type, Map<String, Float>, Object, String) - Method in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
 
buildHelpWidths(Table, RestRequest) - Static method in class org.elasticsearch.rest.action.support.RestTable
 
buildIndexFieldDataCache(IndexService, Index, FieldMapper.Names, FieldDataType) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
 
buildIndexName(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
buildLockFactory() - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
buildMergeScheduler() - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
buildMergeScheduler() - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
buildMergeScheduler() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
Deprecated.
 
buildNamedAnalyzer(FormatDateTimeFormatter, int) - Static method in class org.elasticsearch.index.analysis.NumericDateAnalyzer
 
buildNamedAnalyzer(int) - Static method in class org.elasticsearch.index.analysis.NumericDoubleAnalyzer
 
buildNamedAnalyzer(int) - Static method in class org.elasticsearch.index.analysis.NumericFloatAnalyzer
 
buildNamedAnalyzer(int) - Static method in class org.elasticsearch.index.analysis.NumericIntegerAnalyzer
 
buildNamedAnalyzer(int) - Static method in class org.elasticsearch.index.analysis.NumericLongAnalyzer
 
buildNames(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
buildPayload(BytesRef, long, BytesRef) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
buildPayload(BytesRef, long, BytesRef) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionLookupProvider
 
buildRecoveryTable(RestRequest, RecoveryResponse) - Method in class org.elasticsearch.rest.action.cat.RestRecoveryAction
buildRecoveryTable will build a table of recovery information suitable for displaying at the command line.
buildResponse(T, XContentBuilder) - Method in class org.elasticsearch.rest.action.support.AcknowledgedRestListener
 
buildResponse(Response) - Method in class org.elasticsearch.rest.action.support.RestBuilderListener
 
buildResponse(Response, XContentBuilder) - Method in class org.elasticsearch.rest.action.support.RestBuilderListener
Builds a response to send back over the channel.
buildResponse(Response) - Method in class org.elasticsearch.rest.action.support.RestResponseListener
Builds the response to send back through the channel.
buildResponse(Response) - Method in class org.elasticsearch.rest.action.support.RestStatusToXContentListener
 
buildResponse(Response, XContentBuilder) - Method in class org.elasticsearch.rest.action.support.RestStatusToXContentListener
 
buildResponse(Table, RestChannel) - Static method in class org.elasticsearch.rest.action.support.RestTable
 
buildResponse(Response) - Method in class org.elasticsearch.rest.action.support.RestToXContentListener
 
buildResponse(Response, XContentBuilder) - Method in class org.elasticsearch.rest.action.support.RestToXContentListener
 
buildScrollId(SearchType, AtomicArray<? extends SearchPhaseResult>, Map<String, String>) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
buildScrollId(String, AtomicArray<? extends SearchPhaseResult>, Map<String, String>) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
buildShardFailures() - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
buildText() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
buildTextPlainResponse(Table, RestChannel) - Static method in class org.elasticsearch.rest.action.support.RestTable
 
buildTookInMillis() - Method in class org.elasticsearch.action.search.type.AbstractAsyncAction
Builds how long it took to execute the search.
buildWeight(XContentBuilder) - Method in class org.elasticsearch.index.query.functionscore.factor.FactorBuilder
Deprecated.
 
buildWeight(XContentBuilder) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
 
buildXContentBuilder(Table, RestChannel) - Static method in class org.elasticsearch.rest.action.support.RestTable
 
BulgarianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
BulgarianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.BulgarianAnalyzerProvider
 
bulk(BulkRequest) - Method in interface org.elasticsearch.client.Client
Executes a bulk of index / delete operations.
bulk(BulkRequest, ActionListener<BulkResponse>) - Method in interface org.elasticsearch.client.Client
Executes a bulk of index / delete operations.
bulk(BulkRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
bulk(BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
bulk(BulkRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
bulk(BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
BULK - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
BulkAction - Class in org.elasticsearch.action.bulk
 
BulkItemRequest - Class in org.elasticsearch.action.bulk
 
BulkItemRequest(int, ActionRequest) - Constructor for class org.elasticsearch.action.bulk.BulkItemRequest
 
BulkItemResponse - Class in org.elasticsearch.action.bulk
Represents a single item response for an action executed as part of the bulk API.
BulkItemResponse(int, String, ActionResponse) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse
 
BulkItemResponse(int, String, BulkItemResponse.Failure) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse
 
BulkItemResponse.Failure - Class in org.elasticsearch.action.bulk
Represents a failure.
BulkProcessor - Class in org.elasticsearch.action.bulk
A bulk processor is a thread safe bulk processing class, allowing to easily set when to "flush" a new bulk request (either based on number of actions, based on the size, or time), and to easily control the number of concurrent bulk requests allowed to be executed in parallel.
BulkProcessor.Builder - Class in org.elasticsearch.action.bulk
A builder used to create a build an instance of a bulk processor.
BulkProcessor.Listener - Interface in org.elasticsearch.action.bulk
A listener for the execution.
BulkRequest - Class in org.elasticsearch.action.bulk
A bulk request holds an ordered IndexRequests and DeleteRequests and allows to executes it in a single batch.
BulkRequest() - Constructor for class org.elasticsearch.action.bulk.BulkRequest
 
bulkRequest() - Static method in class org.elasticsearch.client.Requests
Creats a new bulk request.
BulkRequestBuilder - Class in org.elasticsearch.action.bulk
A bulk request holds an ordered IndexRequests and DeleteRequests and allows to executes it in a single batch.
BulkRequestBuilder(Client) - Constructor for class org.elasticsearch.action.bulk.BulkRequestBuilder
 
BulkResponse - Class in org.elasticsearch.action.bulk
A response of a bulk execution.
BulkResponse(BulkItemResponse[], long) - Constructor for class org.elasticsearch.action.bulk.BulkResponse
 
BulkShardRequest - Class in org.elasticsearch.action.bulk
 
BulkShardResponse - Class in org.elasticsearch.action.bulk
 
BulkUdpModule - Class in org.elasticsearch.bulk.udp
 
BulkUdpModule() - Constructor for class org.elasticsearch.bulk.udp.BulkUdpModule
 
BulkUdpService - Class in org.elasticsearch.bulk.udp
 
BulkUdpService(Settings, Client, NetworkService) - Constructor for class org.elasticsearch.bulk.udp.BulkUdpService
 
busiestThreads(int) - Method in class org.elasticsearch.monitor.jvm.HotThreads
 
BYTE_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.BigArrays
 
bytearray - Variable in class org.elasticsearch.common.bytes.PagedBytesReference
 
ByteArray - Interface in org.elasticsearch.common.util
Abstraction of an array of byte values.
ByteBufferStreamInput - Class in org.elasticsearch.common.io.stream
 
ByteBufferStreamInput(ByteBuffer) - Constructor for class org.elasticsearch.common.io.stream.ByteBufferStreamInput
 
byteField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
ByteFieldMapper - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper(FieldMapper.Names, int, float, FieldType, Boolean, Byte, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
ByteFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper.CustomByteNumericField - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
bytePage(boolean) - Method in class org.elasticsearch.cache.recycler.PageCacheRecycler
 
bytes() - Method in interface org.elasticsearch.common.io.BytesStream
 
bytes() - Method in interface org.elasticsearch.common.io.ReleasableBytesStream
 
bytes - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
bytes() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
bytes() - Method in class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
 
bytes - Variable in class org.elasticsearch.common.lucene.HashedBytesRef
 
bytes() - Method in class org.elasticsearch.common.text.BytesText
 
bytes() - Method in class org.elasticsearch.common.text.StringAndBytesText
 
bytes() - Method in class org.elasticsearch.common.text.StringText
 
bytes() - Method in interface org.elasticsearch.common.text.Text
The UTF8 bytes representing the the text, might be converted on the fly, see Text.hasBytes()
bytes() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
bytes() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
bytes() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
bytes() - Method in interface org.elasticsearch.common.xcontent.XContentParser
Deprecated.
bytes() - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
bytes(BytesReference) - Method in class org.elasticsearch.index.query.support.XContentStructure
Set the bytes to be used for parsing
bytes() - Method in class org.elasticsearch.index.query.support.XContentStructure
Return the bytes that are going to be used for parsing
Bytes() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes
 
bytes(String, InternalAggregation.Type, SearchContext) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
 
bytes() - Method in class org.elasticsearch.transport.BytesTransportRequest
 
BYTES_SIZE - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
BYTES_SIZE_OR_PERCENTAGE - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
BytesArray - Class in org.elasticsearch.common.bytes
 
BytesArray(String) - Constructor for class org.elasticsearch.common.bytes.BytesArray
 
BytesArray(BytesRef) - Constructor for class org.elasticsearch.common.bytes.BytesArray
 
BytesArray(BytesRef, boolean) - Constructor for class org.elasticsearch.common.bytes.BytesArray
 
BytesArray(byte[]) - Constructor for class org.elasticsearch.common.bytes.BytesArray
 
BytesArray(byte[], int, int) - Constructor for class org.elasticsearch.common.bytes.BytesArray
 
bytesAsInt() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
BytesBinaryDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
BytesBinaryDVIndexFieldData(Index, FieldMapper.Names, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData
 
BytesBinaryDVIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
 
bytesEqual(BytesReference, BytesReference) - Static method in class org.elasticsearch.common.bytes.BytesReference.Helper
 
BytesFieldDataFilter(IndexFieldData, ObjectOpenHashSet<BytesRef>) - Constructor for class org.elasticsearch.index.search.FieldDataTermsFilter.BytesFieldDataFilter
 
bytesFilter(BytesReference) - Static method in class org.elasticsearch.index.query.FilterBuilders
Constructs a bytes filter to generate a filter from a BytesReference source
BytesFilterBuilder - Class in org.elasticsearch.index.query
FilterBuilder that constructs filters from BytesReference source
BytesFilterBuilder(BytesReference) - Constructor for class org.elasticsearch.index.query.BytesFilterBuilder
 
bytesHashCode(BytesReference) - Static method in class org.elasticsearch.common.bytes.BytesReference.Helper
 
byteSizeField(XContentBuilderString, XContentBuilderString, ByteSizeValue) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
byteSizeField(XContentBuilderString, XContentBuilderString, long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
ByteSizeUnit - Enum in org.elasticsearch.common.unit
A SizeUnit represents size at a given unit of granularity and provides utility methods to convert across units.
ByteSizeValue - Class in org.elasticsearch.common.unit
 
ByteSizeValue(long) - Constructor for class org.elasticsearch.common.unit.ByteSizeValue
 
ByteSizeValue(long, ByteSizeUnit) - Constructor for class org.elasticsearch.common.unit.ByteSizeValue
 
bytesOrNull() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
bytesOrNull() - Method in interface org.elasticsearch.common.xcontent.XContentParser
Deprecated.
bytesOutput() - Method in class org.elasticsearch.rest.RestChannel
A channel level bytes output that can be reused.
bytesPerValue(BytesRef) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData.PerValueEstimator
 
bytesPerValue(BytesRef) - Method in class org.elasticsearch.index.fielddata.plain.NonEstimatingEstimator
 
bytesPerValue(BytesRef) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData.PackedArrayEstimator
 
bytesPerValue(BytesRef) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
 
bytesPerValue(BytesRef) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData.ParentChildEstimator
General overhead for ids is 2 times the length of the ID
BytesReference - Interface in org.elasticsearch.common.bytes
A reference to bytes.
BytesReference.Helper - Class in org.elasticsearch.common.bytes
 
BytesRefFieldComparatorSource - Class in org.elasticsearch.index.fielddata.fieldcomparator
Comparator source for string/binary values.
BytesRefFieldComparatorSource(IndexFieldData<?>, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
 
BytesRefHash - Class in org.elasticsearch.common.util
Specialized hash table implementation similar to Lucene's BytesRefHash that maps BytesRef values to ids.
BytesRefHash(long, BigArrays) - Constructor for class org.elasticsearch.common.util.BytesRefHash
 
BytesRefHash(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.BytesRefHash
 
BytesRefs - Class in org.elasticsearch.common.lucene
 
BytesRefs() - Constructor for class org.elasticsearch.common.lucene.BytesRefs
 
BytesRestResponse - Class in org.elasticsearch.rest
 
BytesRestResponse(RestStatus) - Constructor for class org.elasticsearch.rest.BytesRestResponse
 
BytesRestResponse(RestStatus, XContentBuilder) - Constructor for class org.elasticsearch.rest.BytesRestResponse
Creates a new response based on XContentBuilder.
BytesRestResponse(RestStatus, String) - Constructor for class org.elasticsearch.rest.BytesRestResponse
Creates a new plain text response.
BytesRestResponse(RestStatus, String, String) - Constructor for class org.elasticsearch.rest.BytesRestResponse
Creates a new plain text response.
BytesRestResponse(RestStatus, String, byte[]) - Constructor for class org.elasticsearch.rest.BytesRestResponse
Creates a binary response.
BytesRestResponse(RestStatus, String, BytesReference, boolean) - Constructor for class org.elasticsearch.rest.BytesRestResponse
Creates a binary response.
BytesRestResponse(RestChannel, Throwable) - Constructor for class org.elasticsearch.rest.BytesRestResponse
 
BytesRestResponse(RestChannel, RestStatus, Throwable) - Constructor for class org.elasticsearch.rest.BytesRestResponse
 
BytesStream - Interface in org.elasticsearch.common.io
 
bytesStream() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
Returns the actual stream used.
BytesStreamInput - Class in org.elasticsearch.common.io.stream
 
BytesStreamInput(BytesReference) - Constructor for class org.elasticsearch.common.io.stream.BytesStreamInput
 
BytesStreamInput(byte[], boolean) - Constructor for class org.elasticsearch.common.io.stream.BytesStreamInput
 
BytesStreamInput(byte[], int, int, boolean) - Constructor for class org.elasticsearch.common.io.stream.BytesStreamInput
 
BytesStreamOutput - Class in org.elasticsearch.common.io.stream
A @link StreamOutput that usesBigArrays to acquire pages of bytes, which avoids frequent reallocation & copying of the internal data.
BytesStreamOutput() - Constructor for class org.elasticsearch.common.io.stream.BytesStreamOutput
Create a non recycling BytesStreamOutput with 1 initial page acquired.
BytesStreamOutput(int) - Constructor for class org.elasticsearch.common.io.stream.BytesStreamOutput
Create a non recycling BytesStreamOutput with enough initial pages acquired to satisfy the capacity given by expected size.
BytesStreamOutput(int, BigArrays) - Constructor for class org.elasticsearch.common.io.stream.BytesStreamOutput
 
BytesText - Class in org.elasticsearch.common.text
A BytesReference representation of the text, will always convert on the fly to a String.
BytesText(BytesReference) - Constructor for class org.elasticsearch.common.text.BytesText
 
bytesToDouble(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to double.
bytesToDouble(BytesRef) - Static method in class org.elasticsearch.common.Numbers
 
bytesToFloat(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to float.
bytesToFloat(BytesRef) - Static method in class org.elasticsearch.common.Numbers
 
bytesToInt(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to an int.
bytesToInt(BytesRef) - Static method in class org.elasticsearch.common.Numbers
 
bytesToLong(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to a long.
bytesToLong(BytesRef) - Static method in class org.elasticsearch.common.Numbers
 
bytesToShort(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to an short.
bytesToShort(BytesRef) - Static method in class org.elasticsearch.common.Numbers
 
BytesTransportRequest - Class in org.elasticsearch.transport
A specialized, bytes only request, that can potentially be optimized on the network layer, specifically for teh same large buffer send to several nodes.
BytesTransportRequest() - Constructor for class org.elasticsearch.transport.BytesTransportRequest
 
BytesTransportRequest(BytesReference, Version) - Constructor for class org.elasticsearch.transport.BytesTransportRequest
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
Get the current ValuesSource.WithScript.BytesValues.
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
 
bytesValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.WithScript
 
ByteTermAttributeImpl() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttributeImpl
 
ByteUtils - Enum in org.elasticsearch.common.util
Utility methods to do byte-level encoding.

C

cache(Filter) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
cache(Filter) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
cache(Filter) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
cache - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
 
cache() - Method in class org.elasticsearch.index.IndexService
 
cache(boolean) - Method in class org.elasticsearch.index.query.AndFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.GeohashCellFilter.Builder
Should the filter be cached or not.
CACHE - Static variable in class org.elasticsearch.index.query.GeohashCellFilter
 
cache(boolean) - Method in class org.elasticsearch.index.query.GeoPolygonFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.GeoShapeFilterBuilder
Sets whether the filter will be cached.
cache(boolean) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
This is a noop since has_child can't be cached.
cache(boolean) - Method in class org.elasticsearch.index.query.HasParentFilterBuilder
This is a noop since has_parent can't be cached.
cache(boolean) - Method in class org.elasticsearch.index.query.NestedFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.NotFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.OrFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.PrefixFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.QueryFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.RegexpFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.TermFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.TermsFilterBuilder
Should the filter be cached or not.
cache(boolean) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
 
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.indices.cache.filter.IndicesFilterCache
 
cache() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
CACHE_IMPL - Static variable in class org.elasticsearch.cache.recycler.PageCacheRecyclerModule
 
CACHE_KEY - Static variable in class org.elasticsearch.index.query.GeohashCellFilter
 
CachedDfSource - Class in org.elasticsearch.search.dfs
 
CachedDfSource(IndexReader, AggregatedDfs, Similarity) - Constructor for class org.elasticsearch.search.dfs.CachedDfSource
 
CachedFilter - Class in org.elasticsearch.common.lucene.search
A marker indicating that this is a cached filter.
CachedFilter() - Constructor for class org.elasticsearch.common.lucene.search.CachedFilter
 
cachedHandles(StreamInput) - Static method in class org.elasticsearch.common.io.stream.CachedStreamInput
 
cachedHandlesCompressed(Compressor, StreamInput) - Static method in class org.elasticsearch.common.io.stream.CachedStreamInput
 
CachedPositionIterator - Class in org.elasticsearch.search.lookup
 
CachedPositionIterator(IndexFieldTerm) - Constructor for class org.elasticsearch.search.lookup.CachedPositionIterator
 
CachedStreamInput - Class in org.elasticsearch.common.io.stream
 
CachedStreamInput() - Constructor for class org.elasticsearch.common.io.stream.CachedStreamInput
 
CachedStreams - Class in org.elasticsearch.common.io
 
CachedStreams() - Constructor for class org.elasticsearch.common.io.CachedStreams
 
cacheFilter(Filter, CacheKeyFilter.Key) - Method in class org.elasticsearch.index.query.QueryParseContext
 
cacheKey() - Method in interface org.elasticsearch.index.cache.filter.support.CacheKeyFilter
 
cacheKey() - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
cacheKey(String) - Method in class org.elasticsearch.index.query.AndFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.GeoPolygonFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.GeoShapeFilterBuilder
Sets the key used for the filter if it is cached
cacheKey(String) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
This is a noop since has_child can't be cached.
cacheKey(String) - Method in class org.elasticsearch.index.query.HasParentFilterBuilder
This is a noop since has_parent can't be cached.
cacheKey(String) - Method in class org.elasticsearch.index.query.NestedFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
 
cacheKey(String) - Method in class org.elasticsearch.index.query.OrFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.PrefixFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.RegexpFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.TermFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.TermsFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
 
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
 
CacheKeyFilter - Interface in org.elasticsearch.index.cache.filter.support
 
CacheKeyFilter.Key - Class in org.elasticsearch.index.cache.filter.support
 
CacheKeyFilter.Wrapper - Class in org.elasticsearch.index.cache.filter.support
 
CacheRecycler - Class in org.elasticsearch.cache.recycler
 
CacheRecycler(Settings) - Constructor for class org.elasticsearch.cache.recycler.CacheRecycler
 
cacheRecycler() - Method in class org.elasticsearch.index.query.QueryParseContext
 
cacheRecycler() - Method in class org.elasticsearch.percolator.PercolateContext
 
cacheRecycler() - Method in class org.elasticsearch.search.facet.InternalFacet.ReduceContext
 
cacheRecycler() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
cacheRecycler() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
cacheRecycler() - Method in class org.elasticsearch.search.internal.SearchContext
 
CacheRecycler.Type - Enum in org.elasticsearch.cache.recycler
 
CacheRecyclerModule - Class in org.elasticsearch.cache.recycler
 
CacheRecyclerModule(Settings) - Constructor for class org.elasticsearch.cache.recycler.CacheRecyclerModule
 
cacheSize() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
calcHighFreqMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
 
calcLowFreqMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
 
calcMinimumNumberShouldMatch(String, int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
 
calculate(double, double) - 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
Returns a Decision whether the given shard routing can be allocated at all at this state of the RoutingAllocation.
canAllocate(RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
Returns a Decision whether the given node can allow any allocation at all at this state of the RoutingAllocation.
canAllocate(ShardRouting, 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(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(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
 
canBindToMcastAddress() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
canCache(ShardSearchRequest, SearchContext) - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache
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.
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
Factory creating CancelAllocationCommands
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
 
cancelRecoveriesForShard(ShardId, String) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
cancel all ongoing recoveries for the given shard.
cancelRecovery(long, String) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
cancel the recovery with the given id (if found) and remove it from the recovery collection
cancelRelocation(MutableShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
Cancels a relocation of a shard that shard must relocating.
canDeleteIndexContents(Index, Settings) - 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.ShardReplicationOperationRequest
Is this request can potentially be dup on a single shard.
canHaveDuplicates() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
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
canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
Returns a Decision whether the given shard routing can be re-balanced to the given allocation.
canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
 
canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
 
canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
 
canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.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
Returns a string that is equivalent to the specified string with its first character converted to uppercase as by String.toUpperCase(java.util.Locale).
capitalize(String) - Static method in class org.elasticsearch.common.Strings
Capitalize a String, changing the first letter to upper case as per Character.toUpperCase(char).
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, long, ValuesSource, boolean, int, ValueFormatter, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
CardinalityBuilder - Class in org.elasticsearch.search.aggregations.metrics.cardinality
Builder for the Cardinality aggregation.
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
Wrap the provided SortedNumericDoubleValues instance to cast all values to longs.
CatalanAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
CatalanAnalyzerProvider(Index, Settings, 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
The CategoryContextMapping is used to define a ContextMapping that references a field within a document.
CategoryContextMapping(String) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping
Create a new CategoryContextMapping with the default field [_type]
CategoryContextMapping(String, String) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping
Create a new CategoryContextMapping with the default field [_type]
CategoryContextMapping(String, Iterable<? extends CharSequence>) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping
Create a new CategoryContextMapping with the default field [_type]
CategoryContextMapping(String, String, Iterable<? extends CharSequence>) - Constructor for class org.elasticsearch.search.suggest.context.CategoryContextMapping
Create a new CategoryContextMapping with the default field [_type]
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
cborBuilder() - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Returns a content builder using CBOR format (XContentType.CBOR.
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) - 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
changed() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
determine whether the actual RoutingTable has been changed
changesAllowed() - Method in class org.elasticsearch.indices.IndicesService
Returns true if changes (adding / removing) indices, shards and so on are allowed.
channel() - Method in class org.elasticsearch.index.translog.fs.RafReference
 
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
A Netty ChannelBuffer based StreamInput.
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
 
Channels - Class in org.elasticsearch.common.io
 
channelScore(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
 
charAt(int) - Method in class org.elasticsearch.common.io.FastStringReader
 
charFilter(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
 
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.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
 
CHARSET_UTF_8 - Static variable in class org.apache.lucene.util.XIOUtils
Deprecated.
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
Called periodically by ResourceWatcherService so resource watcher can check the resource
checkArgument(boolean) - Static method in class org.elasticsearch.common.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, Object) - Static method in class org.elasticsearch.common.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object...) - Static method in class org.elasticsearch.common.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkBlock(ClusterHealthRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
checkBlock(NodesShutdownRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
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(DeleteMappingRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
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(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(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.TransportMasterNodeOperationAction
 
checkBlock(MappingUpdatedAction.MappingUpdatedRequest, ClusterState) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
checkChronology(Chronology) - Method in class org.joda.time.base.BaseDateTime
Checks the specified chronology before storing it, potentially altering it.
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.
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, FlushRequest) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
checkGlobalBlock(ClusterState, OptimizeRequest) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
checkGlobalBlock(ClusterState, RecoveryRequest) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
checkGlobalBlock(ClusterState, RefreshRequest) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
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, IndicesStatusRequest) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
checkGlobalBlock(ClusterState, ValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
checkGlobalBlock(ClusterState, CountRequest) - Method in class org.elasticsearch.action.count.TransportCountAction
 
checkGlobalBlock(ClusterState, DeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
checkGlobalBlock(ClusterState, IndexDeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
checkGlobalBlock(ClusterState, ExistsRequest) - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
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.TransportBroadcastOperationAction
 
checkGlobalBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
checkGlobalBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
checkGlobalBlock(ClusterState) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
checkGlobalBlock(ClusterState) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
checkGlobalBlock(ClusterState) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
checkGlobalBlock(ClusterState) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
checkIndexTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Start
 
checkIndexTime(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Start
 
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) - Method in class org.elasticsearch.index.store.Store
 
checkIntegrity(StoreFileMetaData, Directory) - Static method in class org.elasticsearch.index.store.Store
 
checkLuceneCompatibility(Class<? extends Plugin>, Settings, ESLogger, String) - Static method in class org.elasticsearch.plugins.PluginsService
Check that a plugin is Lucene compatible with the current running node using `lucene` property in `es-plugin.properties` file.
checkNotAnnotated() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
checkNotAnnotated() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
 
checkNotNull(T) - Static method in class org.elasticsearch.common.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, Object) - Static method in class org.elasticsearch.common.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object...) - Static method in class org.elasticsearch.common.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
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
checkRequestBlock(ClusterState, TransportSingleCustomOperationAction<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, FlushRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
checkRequestBlock(ClusterState, OptimizeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
checkRequestBlock(ClusterState, RecoveryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
checkRequestBlock(ClusterState, RefreshRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
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, IndicesStatusRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
checkRequestBlock(ClusterState, ValidateQueryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
checkRequestBlock(ClusterState, CountRequest, String[]) - Method in class org.elasticsearch.action.count.TransportCountAction
 
checkRequestBlock(ClusterState, DeleteByQueryRequest, String[]) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
checkRequestBlock(ClusterState, IndexDeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
checkRequestBlock(ClusterState, ExistsRequest, String[]) - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
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.TransportBroadcastOperationAction
 
checkRequestBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
checkRequestBlock(ClusterState, Request, String[]) - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
checkRequestBlock(ClusterState, TransportShardReplicationOperationAction<Request, ReplicaRequest, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
checkRequestBlock(ClusterState, TransportSingleCustomOperationAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
checkRequestBlock(ClusterState, TransportInstanceSingleOperationAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
checkRequestBlock(ClusterState, TransportShardSingleOperationAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
checkSegmentInfoIntegrity(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
 
checkState(boolean) - Static method in class org.elasticsearch.common.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, Object) - Static method in class org.elasticsearch.common.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object...) - Static method in class org.elasticsearch.common.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkStateMeetsSettingsAndMaybeRecover(ClusterState, boolean) - Method in class org.elasticsearch.gateway.GatewayService
 
checksum() - Method in class org.elasticsearch.index.gateway.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
 
CHECKSUMMED_TRANSLOG_STREAM - Static variable in class org.elasticsearch.index.translog.TranslogStreams
V1, header, with per-op checksums
ChecksummedTranslogStream - Class in org.elasticsearch.index.translog
Version 1 of the translog file format.
CHECKSUMS_PREFIX - Static variable in class org.elasticsearch.index.store.Store
 
checkWriteConsistency() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
checkWriteConsistency() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
checkWriteConsistency() - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
checkWriteConsistency() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
checkWriteConsistency() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
checkWriteConsistency() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
childBindingAlreadySet(Key<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
childDocumentMapper - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
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, CircuitBreaker.Name) - 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, CircuitBreaker.Name) - Constructor for class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
Create a circuit breaker that will break if the number of estimated bytes grows above the limit.
children - Variable in class org.elasticsearch.common.geo.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
Builder for the Children aggregation.
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, FixedBitSetFilter) - Constructor for class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
 
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
A query implementation that executes the wrapped child query and connects all the matching child docs to the related parent documents using ParentChildIndexFieldData.
ChildrenQuery(ParentChildIndexFieldData, String, String, Filter, Query, ScoreType, int, int, int, FixedBitSetFilter) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery
 
ChildrenQuery.ParentCollector - Class in org.elasticsearch.index.search.child
 
ChildrenQuery.ParentScoreCollector - Class in org.elasticsearch.index.search.child
 
ChildrenQuery.ParentScoreCountCollector - Class in org.elasticsearch.index.search.child
 
ChildrenQuery.ParentWeight - Class in org.elasticsearch.index.search.child
 
childType - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
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
 
ChineseAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ChineseAnalyzerProvider(Index, Settings, 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(AtomicReader, 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.
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.Name - Enum in org.elasticsearch.common.breaker
Enum used for specifying different types of circuit breakers
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(CircuitBreaker.Name, 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(String, long, long) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
 
CjkAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
CjkAnalyzerProvider(Index, Settings, 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, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CJKBigramFilterFactory
 
CJKWidthFilterFactory - Class in org.elasticsearch.index.analysis
 
CJKWidthFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CJKWidthFilterFactory
 
Classes - Class in org.elasticsearch.common
 
ClassicFilterFactory - Class in org.elasticsearch.index.analysis
Factory for ClassicFilter
ClassicFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ClassicFilterFactory
 
ClassicTokenizerFactory - Class in org.elasticsearch.index.analysis
Factory for ClassicTokenizer
ClassicTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ClassicTokenizerFactory
 
classLoader(ClassLoader) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets the class loader associated with the settings built.
classPath() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
clause(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
 
clause(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
 
clauses() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
Returns the list of clauses
CLEAN_FILES - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
 
cleanCaches(Injector) - Static method in class org.elasticsearch.common.inject.Injectors
 
cleanHandles() - Method in class org.elasticsearch.common.io.stream.HandlesStreamInput
 
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.
cleanup(String, Set<String>) - 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.
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.cluster.routing.RoutingNodes.UnassignedShards
 
clear() - Method in class org.elasticsearch.common.collect.IdentityHashSet
Removes all of the elements from this set.
clear() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
 
clear() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
clear() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
 
clear() - Method in class org.elasticsearch.common.collect.MapBuilder
 
clear() - Static method in class org.elasticsearch.common.io.CachedStreams
 
clear() - Static method in class org.elasticsearch.common.io.stream.CachedStreamInput
 
clear() - Method in class org.elasticsearch.common.io.stream.HandlesStreamOutput
 
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 interface org.elasticsearch.index.cache.docset.DocSetCache
 
clear(IndexReader) - Method in interface org.elasticsearch.index.cache.docset.DocSetCache
 
clear(String) - Method in class org.elasticsearch.index.cache.docset.none.NoneDocSetCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.docset.none.NoneDocSetCache
 
clear(String) - Method in class org.elasticsearch.index.cache.docset.simple.SimpleDocSetCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.docset.simple.SimpleDocSetCache
 
clear(Object) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
clear(String) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
clear(String, String[]) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
clear(String) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
clear(String, String[]) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
clear(Object) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
clear(String) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
clear(String, String[]) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
clear(Object) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
clear(String) - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
clear(String) - Method in class org.elasticsearch.index.cache.IndexCache
 
clear() - Method in class org.elasticsearch.index.cache.query.parser.none.NoneQueryParserCache
 
clear() - Method in interface org.elasticsearch.index.cache.query.parser.QueryParserCache
 
clear() - Method in class org.elasticsearch.index.cache.query.parser.resident.ResidentQueryParserCache
 
clear() - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
Clears any resources associated with this field data.
clear(IndexReader) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
 
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(Object) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
 
clear() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
clear(String) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
clear(Object) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
clear() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
 
clear(String) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
 
clear(Object) - 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(IndexReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
 
clear() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
 
clear(IndexReader) - 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(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.IndexIndexFieldData
 
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.ShardSearchService
 
clear() - Method in class org.elasticsearch.index.store.Store.LegacyChecksums
 
clear(String) - Method in class org.elasticsearch.indices.cache.filter.terms.IndicesTermsFilterCache
 
clear(String, String[]) - Method in class org.elasticsearch.indices.cache.filter.terms.IndicesTermsFilterCache
 
clear(IndexShard) - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache
 
clear() - Method in class org.elasticsearch.search.lookup.DocLookup
 
clear() - Method in class org.elasticsearch.search.lookup.FieldLookup
 
clear() - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
clear() - Method in class org.elasticsearch.search.lookup.SourceLookup
 
clear() - Method in class org.elasticsearch.search.scan.ScanContext
 
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.
clearCache(ClearIndicesCacheRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
clearCache(ClearIndicesCacheRequest, ActionListener<ClearIndicesCacheResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
clearCache() - Method in class org.elasticsearch.script.ScriptService
Clear both the in memory and on disk compiled script caches.
clearCandidateGenerators() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
Clear the candidate generators.
clearField(String) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
 
ClearIndicesCacheAction - Class in org.elasticsearch.action.admin.indices.cache.clear
 
ClearIndicesCacheRequest - Class in org.elasticsearch.action.admin.indices.cache.clear
 
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(IndicesAdminClient) - 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.
clearPostAllocationFlag(ShardId) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
Clears the post allocation flag for the specified shard
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
 
ClearScrollRequest - Class in org.elasticsearch.action.search
 
ClearScrollRequest() - Constructor for class org.elasticsearch.action.search.ClearScrollRequest
 
ClearScrollRequestBuilder - Class in org.elasticsearch.action.search
 
ClearScrollRequestBuilder(Client) - 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.
clearUnreferenced() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
clearUnreferenced() - Method in interface org.elasticsearch.index.translog.Translog
Clears unreferenced transaction logs.
clearUnreferencedTranslogs() - Method in class org.elasticsearch.index.shard.IndexShard
 
clearUnreferencedTranslogs() - Method in class org.elasticsearch.index.shard.ShadowIndexShard
 
clearWithinNewMapper() - Method in class org.elasticsearch.index.mapper.ParseContext
 
clearWithinNewMapper() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
CLibrary - Class in org.elasticsearch.common.jna
 
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.internal.InternalNode
 
client() - Method in interface 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_TYPE_SETTING - Static variable in interface org.elasticsearch.client.Client
 
ClientAction<Request extends ActionRequest,Response extends ActionResponse,RequestBuilder extends ActionRequestBuilder<Request,Response,RequestBuilder,Client>> - Class in org.elasticsearch.action
Action (used with Client API).
ClientAction(String) - Constructor for class org.elasticsearch.action.ClientAction
 
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.apache.lucene.index.TrackingConcurrentMergeScheduler
 
clone() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
 
clone() - Method in class org.elasticsearch.common.collect.IdentityHashSet
Returns a shallow copy of this HashSet instance: the elements themselves are not cloned.
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.common.lucene.search.XFilteredQuery
 
clone() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
 
clone() - Method in class org.elasticsearch.index.merge.EnableMergeScheduler
 
clone() - Method in class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
 
clone() - Method in class org.elasticsearch.index.search.child.ChildrenQuery
 
clone() - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
 
clone() - Method in class org.elasticsearch.index.search.child.ParentQuery
 
clone() - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
clone() - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
 
close() - Method in class org.apache.lucene.store.RateLimitedFSDirectory
 
close(Closeable...) - Static method in class org.apache.lucene.util.XIOUtils
Closes all given Closeables.
close(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.XIOUtils
Closes all given Closeables.
close() - Method in class org.elasticsearch.action.bulk.BulkProcessor
Closes the processor.
close(String[]) - Static method in class org.elasticsearch.bootstrap.Bootstrap
 
close(String[]) - Static method in class org.elasticsearch.bootstrap.Elasticsearch
 
close(String[]) - Static method in class org.elasticsearch.bootstrap.ElasticsearchF
 
close() - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
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(CloseIndexRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
close(CloseIndexRequest, ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
close() - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
close() - Method in class org.elasticsearch.client.transport.TransportClient
Closes the client.
close() - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
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.compress.CompressedStreamOutput
 
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.AdapterStreamInput
 
close() - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
close() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
 
close() - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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.InputStreamStreamInput
 
close() - Method in class org.elasticsearch.common.io.stream.NoopStreamOutput
 
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
Release the provided Releasables.
close(Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
Release the provided Releasables.
close(boolean, Iterable<Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
Release the provided Releasables, ignoring exceptions if success is false.
close(boolean, Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
Release the provided Releasables, ignoring exceptions if success is false.
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.FilterIndexOutput
 
close() - Method in class org.elasticsearch.common.lucene.store.OutputStreamIndexOutput
 
close() - Method in class org.elasticsearch.common.netty.OpenChannelsHandler
 
close() - Method in class org.elasticsearch.common.network.MulticastChannel
Close the channel.
close(MulticastChannel.Listener) - Method in class org.elasticsearch.common.network.MulticastChannel
 
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 interface org.elasticsearch.common.xcontent.XContentGenerator
 
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.index.analysis.AnalysisService
 
close() - Method in class org.elasticsearch.index.analysis.NumericTokenizer
 
close() - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
close() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
close() - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
close() - Method in class org.elasticsearch.index.cache.IndexCache
 
close() - Method in class org.elasticsearch.index.cache.query.parser.none.NoneQueryParserCache
 
close() - Method in class org.elasticsearch.index.cache.query.parser.resident.ResidentQueryParserCache
 
close() - Method in interface org.elasticsearch.index.CloseableIndexComponent
Closes the index component.
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 interface org.elasticsearch.index.engine.IndexEngine
 
close() - Method in class org.elasticsearch.index.engine.internal.InternalIndexEngine
 
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.FSTBytesAtomicFieldData
 
close() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointCompressedAtomicFieldData
 
close() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayAtomicFieldData
 
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() - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
 
close() - Method in class org.elasticsearch.index.gateway.local.LocalIndexGateway
 
close() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
close() - Method in class org.elasticsearch.index.gateway.none.NoneIndexGateway
 
close() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
close(String, boolean) - Method in class org.elasticsearch.index.IndexService
 
close() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
close() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields
 
close() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
close() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
close() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
close() - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
close() - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
close() - Method in interface org.elasticsearch.index.mapper.Mapper
 
close() - Method in class org.elasticsearch.index.mapper.MapperService
 
close() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
close() - Method in class org.elasticsearch.index.merge.EnableMergeScheduler
 
close() - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
close() - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
close() - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
close() - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
close() - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
close() - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
close() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
Deprecated.
 
close() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider.CustomSerialMergeScheduler
Deprecated.
 
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
 
close() - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCollector
 
close() - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCountCollector
 
close() - Method in class org.elasticsearch.index.search.child.CustomQueryWrappingFilter
 
close(String, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
 
close() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
 
close() - Method in class org.elasticsearch.index.store.DistributorDirectory
 
close() - Method in class org.elasticsearch.index.store.Store
 
close() - Method in class org.elasticsearch.index.store.Store.StoreDirectory
 
close() - Method in class org.elasticsearch.index.store.support.AbstractIndexStore
 
close() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
 
close() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
 
close(boolean) - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
close() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
close() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
close(boolean) - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
close(boolean) - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
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.filter.IndicesFilterCache
 
close() - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache
 
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.internal.InternalNode
 
close() - Method in interface org.elasticsearch.node.Node
Closes the node (and Node.stop()s if its running).
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.river.cluster.PublishRiverClusterStateAction
 
close() - Method in class org.elasticsearch.river.dummy.DummyRiver
 
close() - Method in interface org.elasticsearch.river.River
Called when the river is closed on a node, which can happen when: 1) the river is deleted by deleting its type through the delete mapping api 2) the node where the river is allocated is shut down or the river gets rerouted to another node
close() - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
close() - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
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.Aggregator
Called upon release of the aggregator.
close() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
 
close() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
 
close() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
 
close() - Method in class org.elasticsearch.search.aggregations.FilteringBucketCollector
 
close() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
close() - Method in class org.elasticsearch.search.aggregations.RecordingPerReaderBucketCollector
 
close() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor.ReaderAggregator
 
close() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
close() - Method in class org.elasticsearch.search.internal.DocIdSetCollector
 
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
 
CloseableIndexComponent - Interface in org.elasticsearch.index
 
closed() - Method in class org.elasticsearch.common.component.Lifecycle
Returns true if the state is closed.
closed() - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
closed() - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
closed() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
CloseEngineException - Exception in org.elasticsearch.index.engine
An exception indicating that an Engine close failed.
CloseEngineException(ShardId, String) - Constructor for exception org.elasticsearch.index.engine.CloseEngineException
 
CloseEngineException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.CloseEngineException
 
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(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(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
 
CloseIndexRequestBuilder(IndicesAdminClient, 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
 
closeRiver(RiverName) - Method in class org.elasticsearch.river.RiversService
 
closeWhileHandlingException(Closeable...) - Static method in class org.apache.lucene.util.XIOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.XIOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(Iterable<Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
Release the provided Releasables, ignoring exceptions.
closeWhileHandlingException(Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
Release the provided Releasables, ignoring exceptions.
closeWithDelete() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
closeWithDelete() - Method in interface org.elasticsearch.index.translog.Translog
 
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() - Method in class org.elasticsearch.client.FilterClient
 
cluster() - Method in class org.elasticsearch.client.node.NodeAdminClient
 
cluster() - Method in class org.elasticsearch.client.transport.support.InternalTransportAdminClient
 
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_REQUIRE_GROUP - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
 
CLUSTER_SERVICE_IMPL - Static variable in class org.elasticsearch.cluster.ClusterModule
 
ClusterAction<Request extends ActionRequest,Response extends ActionResponse,RequestBuilder extends ActionRequestBuilder<Request,Response,RequestBuilder,ClusterAdminClient>> - Class in org.elasticsearch.action.admin.cluster
Cluster action (used with ClusterAdminClient API).
ClusterAction(String) - Constructor for class org.elasticsearch.action.admin.cluster.ClusterAction
 
ClusterAdmin(ClusterAdminClient) - Constructor for class org.elasticsearch.client.FilterClient.ClusterAdmin
Creates a new ClusterAdmin
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
 
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.GatewayService
 
clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.local.LocalGateway
 
clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.local.state.meta.LocalGatewayMetaState
 
clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.local.state.shards.LocalGatewayShardsState
 
clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.index.cache.IndexCache
 
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.river.routing.RiversRouter
 
clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.RestoreService
 
clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.SnapshotsService
 
ClusterChangedEvent - Class in org.elasticsearch.cluster
 
ClusterChangedEvent(String, ClusterState, ClusterState) - Constructor for class org.elasticsearch.cluster.ClusterChangedEvent
 
ClusterDynamicSettings - Annotation Type in org.elasticsearch.cluster.settings
 
ClusterDynamicSettingsModule - Class in org.elasticsearch.cluster.settings
 
ClusterDynamicSettingsModule() - Constructor for class org.elasticsearch.cluster.settings.ClusterDynamicSettingsModule
 
ClusterHealthAction - Class in org.elasticsearch.action.admin.cluster.health
 
ClusterHealthRequest - Class in org.elasticsearch.action.admin.cluster.health
 
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(ClusterAdminClient) - 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) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
ClusterHealthStatus - Enum in org.elasticsearch.action.admin.cluster.health
 
ClusterIndexHealth - Class in org.elasticsearch.action.admin.cluster.health
 
ClusterIndexHealth(IndexMetaData, IndexRoutingTable) - Constructor for class org.elasticsearch.action.admin.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(ImmutableMap<String, DiskUsage>, ImmutableMap<String, Long>) - Constructor for class org.elasticsearch.cluster.ClusterInfo
 
clusterInfo() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
ClusterInfoRequest<T extends ClusterInfoRequest> - 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(IndicesAdminClient, 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
ClusterInfoUpdateJob(boolean) - Constructor for class org.elasticsearch.cluster.InternalClusterInfoService.ClusterInfoUpdateJob
 
ClusterModule - Class in org.elasticsearch.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.TransportNodesOperationAction
 
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(ClusterAdminClient) - 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(ClusterAdminClient) - 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.search.type.TransportSearchTypeAction
 
clusterService - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
ClusterService - Interface in org.elasticsearch.cluster
The cluster service allowing to both register for cluster state events (ClusterStateListener) and submit state update tasks (ClusterStateUpdateTask.
ClusterShardHealth - Class in org.elasticsearch.action.admin.cluster.health
 
clusterState - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
ClusterState - Class in org.elasticsearch.cluster
 
ClusterState(long, ClusterState) - Constructor for class org.elasticsearch.cluster.ClusterState
 
ClusterState(ClusterName, long, MetaData, RoutingTable, DiscoveryNodes, ClusterBlocks, ImmutableOpenMap<String, ClusterState.Custom>) - 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.Custom.Factory<T extends ClusterState.Custom> - Interface in org.elasticsearch.cluster
 
ClusterState.Metric - Enum in org.elasticsearch.cluster
 
ClusterStateAction - Class in org.elasticsearch.action.admin.cluster.state
 
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.AckedClusterStateUpdateTask
 
clusterStateProcessed(String, ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.ProcessedClusterStateUpdateTask
Called when the result of the ClusterStateUpdateTask.execute(ClusterState) have been processed properly by all listeners.
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(ClusterAdminClient) - 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
 
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
 
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
clusterStats(ClusterStatsRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
clusterStats(ClusterStatsRequest, ActionListener<ClusterStatsResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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
 
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(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(ClusterAdminClient) - 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(ClusterAdminClient) - 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.
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
 
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
 
CodecModule - Class in org.elasticsearch.index.codec
The CodecModule creates and loads the CodecService, PostingsFormatService and DocValuesFormatService, allowing low level data-structure specialization on a Lucene Segment basis.
CodecModule(Settings) - Constructor for class org.elasticsearch.index.codec.CodecModule
 
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, Settings, PostingsFormatService, DocValuesFormatService, 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
 
collateFilter(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
Sets a filter used for filtering out suggested phrases (collation).
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
collatePreference(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
Sets routing preferences for executing filter query (collation).
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).
collect(int) - Method in class org.elasticsearch.common.lucene.Lucene.EarlyTerminatingCollector
 
collect(int) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
 
collect(int) - Method in class org.elasticsearch.common.lucene.MultiCollector
 
collect(int) - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
 
collect(int) - Method in class org.elasticsearch.common.lucene.search.NoopCollector
 
collect(int) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
collect(int) - Method in class org.elasticsearch.search.aggregations.AggregationPhase.AggregationsCollector
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator.WithHash
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.BucketCollector
Called during the query phase, to collect & aggregate the given document.
collect(int, long) - Method in class org.elasticsearch.search.aggregations.FilteringBucketCollector
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
collect(long, long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
 
collect(int, long) - Method in class org.elasticsearch.search.aggregations.RecordingPerReaderBucketCollector
 
collect(int) - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Collector
 
collect(int) - Method in class org.elasticsearch.search.internal.DocIdSetCollector
 
COLLECT_MODE - Static variable in class org.elasticsearch.search.aggregations.Aggregator
 
collectableSubAggregators - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
collectBucket(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)
collectBucketNoCounts(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
Utility method to collect the given doc in the given bucket but not to update the doc counts of the bucket
collectExistingBucket(int, long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
Same as BucketsAggregator.collectBucket(int, long), but doesn't check if the docCounts needs to be re-sized.
collectGeoPoint(GeoDistanceFacet.Entry, int, double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetExecutor.Aggregator
 
collectGeoPoint(GeoDistanceFacet.Entry, int, double) - Method in class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetExecutor.ScriptAggregator
 
collectGeoPoint(GeoDistanceFacet.Entry, int, double) - Method in class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetExecutor.Aggregator
 
collectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
collectionStatistics(String) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
collectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
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(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
 
collector - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
 
collector() - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.FacetExecutor
A collector based facet implementation, collection the facet as hits match.
Collector() - Constructor for class org.elasticsearch.search.facet.FacetExecutor.Collector
 
Collector(FacetExecutor.Collector) - Constructor for class org.elasticsearch.search.facet.FacetExecutor.Post.Collector
 
collector() - Method in class org.elasticsearch.search.facet.filter.FilterFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.histogram.CountHistogramFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.histogram.FullHistogramFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.histogram.ScriptHistogramFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.histogram.ValueHistogramFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.histogram.ValueScriptHistogramFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor
 
Collector(NestedFacetExecutor.Collector, Filter) - Constructor for class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Collector
 
Collector(Collector, Filter, Filter) - Constructor for class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Collector
 
collector() - Method in class org.elasticsearch.search.facet.query.QueryFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.range.KeyValueRangeFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.range.RangeFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.range.ScriptRangeFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.statistical.ScriptStatisticalFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.terms.strings.ScriptTermsStringFieldFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.terms.unmapped.UnmappedFieldExecutor
 
collector() - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor
 
collector() - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor
 
collectors() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
 
collectPayloads(boolean) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
 
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, double) - Method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
 
COMBINE_SCRIPT - 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
 
combineNamedFilters(QueryParseContext) - Method in class org.elasticsearch.index.query.QueryParseContext
 
combineScript(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the combine script.
combineScriptFile(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the combine script file.
combineScriptId(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the indexed combine script id.
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
CommitPoint - Class in org.elasticsearch.index.gateway
 
CommitPoint(long, String, CommitPoint.Type, List<CommitPoint.FileInfo>, List<CommitPoint.FileInfo>) - Constructor for class org.elasticsearch.index.gateway.CommitPoint
 
CommitPoint.FileInfo - Class in org.elasticsearch.index.gateway
 
CommitPoint.Type - Enum in org.elasticsearch.index.gateway
 
CommitPoints - Class in org.elasticsearch.index.gateway
 
CommitPoints(List<CommitPoint>) - Constructor for class org.elasticsearch.index.gateway.CommitPoints
 
commits() - Method in class org.elasticsearch.index.gateway.CommitPoints
 
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, Settings, 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
 
commonTerms(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
by commonTermsQuery(String, Object) Will be removed in elasticsearch 2.0.0
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
 
comparator() - Method in enum org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.ComparatorType
 
comparator(DateHistogramFacet.ComparatorType) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
 
comparator() - Method in enum org.elasticsearch.search.facet.histogram.HistogramFacet.ComparatorType
 
comparator(HistogramFacet.ComparatorType) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
 
comparator(HistogramFacet.ComparatorType) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
comparator() - Method in enum org.elasticsearch.search.facet.terms.TermsFacet.ComparatorType
 
comparator() - Method in enum org.elasticsearch.search.facet.termsstats.TermsStatsFacet.ComparatorType
 
Comparators - Enum in org.elasticsearch.common.util
Comparator-related utility methods.
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.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.DisabledIndexFieldData
 
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.GeoPointBinaryDVIndexFieldData
 
comparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.NumericDVIndexFieldData
 
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.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(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(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.BytesText
 
compareTo(Text) - Method in class org.elasticsearch.common.text.StringAndBytesText
 
compareTo(Text) - Method in class org.elasticsearch.common.text.StringText
 
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(Snapshot) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Compares two snapshots by their start time
compareTo(Number) - Method in class org.elasticsearch.script.ScoreAccessor
 
compareTo(TermsFacet.Entry) - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
compareTo(TermsFacet.Entry) - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
compareTo(TermsFacet.Entry) - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.TermEntry
 
compareTo(TermsStatsFacet.Entry) - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
compareTo(TermsStatsFacet.Entry) - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
compareTo(TermsStatsFacet.Entry) - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
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
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) - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
compile(String) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
compile(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) - Method in class org.elasticsearch.script.NativeScriptEngineService
 
compile(String) - Method in interface org.elasticsearch.script.ScriptEngineService
 
compile(String, String, ScriptService.ScriptType) - 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.
compiled() - Method in class org.elasticsearch.script.CompiledScript
 
CompiledScript - Class in org.elasticsearch.script
 
CompiledScript(String, Object) - Constructor for class org.elasticsearch.script.CompiledScript
 
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.metadata.RestoreMetaData.State
Returns true if restore process completed (either successfully or with failure)
completed() - Method in enum org.elasticsearch.cluster.metadata.SnapshotMetaData.State
 
completed() - Method in enum org.elasticsearch.snapshots.SnapshotState
Returns true if snapshot completed (successfully or not)
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(FieldMapper.Names, NamedAnalyzer, NamedAnalyzer, PostingsFormatProvider, SimilarityProvider, boolean, boolean, boolean, int, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo, SortedMap<String, ContextMapping>) - Constructor for class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
CompletionFieldMapper.Builder - 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
 
CompletionLookupProvider() - Constructor for class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionLookupProvider
 
CompletionPostingsFormatProvider - Class in org.elasticsearch.search.suggest.completion
 
CompletionPostingsFormatProvider(String, PostingsFormatProvider, Completion090PostingsFormat.CompletionLookupProvider) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionPostingsFormatProvider
 
completionStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
 
completionStats(IndexReader, String...) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
 
CompletionStats - Class in org.elasticsearch.search.suggest.completion
 
CompletionStats() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionStats
 
CompletionStats(long, ObjectLongOpenHashMap<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
A form of CompletionSuggestionBuilder that supports fuzzy queries allowing matches on typos.
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
 
componentSettings - Variable in class org.elasticsearch.common.component.AbstractComponent
 
componentSettings - Variable in class org.elasticsearch.index.AbstractIndexComponent
 
componentSettings - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
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(byte[], int, int, StreamOutput) - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
Compresses the data into the output
compress(byte[], int, int) - Method in interface org.elasticsearch.common.compress.Compressor
Compresses the provided data, data can be detected as compressed using Compressor.isCompressed(byte[], int, int).
compress(byte[], int, int, StreamOutput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedStreamOutput
 
compress(byte[], int, int) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
compress(boolean) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Builder
 
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.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.core.BinaryFieldMapper.Defaults
 
COMPRESS_THRESHOLD - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
compressed() - Method in class org.elasticsearch.common.compress.CompressedString
 
compressed(Compressor, StreamInput) - Static method in class org.elasticsearch.common.io.stream.CachedStreamInput
 
CompressedIndexInput<T extends CompressorContext> - Class in org.elasticsearch.common.compress
Deprecated.
Used only for backward comp. to read old compressed files, since we now use codec based compression
CompressedIndexInput(IndexInput, T) - Constructor for class org.elasticsearch.common.compress.CompressedIndexInput
Deprecated.
 
CompressedStreamInput<T extends CompressorContext> - Class in org.elasticsearch.common.compress
 
CompressedStreamInput(StreamInput, T) - Constructor for class org.elasticsearch.common.compress.CompressedStreamInput
 
CompressedStreamOutput<T extends CompressorContext> - Class in org.elasticsearch.common.compress
 
CompressedStreamOutput(StreamOutput, T) - Constructor for class org.elasticsearch.common.compress.CompressedStreamOutput
 
CompressedString - Class in org.elasticsearch.common.compress
 
CompressedString(byte[]) - Constructor for class org.elasticsearch.common.compress.CompressedString
Constructor assuming the data provided is compressed (UTF8).
CompressedString(BytesReference) - Constructor for class org.elasticsearch.common.compress.CompressedString
 
CompressedString(byte[], int, int) - Constructor for class org.elasticsearch.common.compress.CompressedString
Constructs a new compressed string, assuming the bytes are UTF8, by copying it over.
CompressedString(String) - Constructor for class org.elasticsearch.common.compress.CompressedString
 
compression - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
compression - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
compression(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksBuilder
Expert: set the compression.
compression(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesBuilder
Expert: set the compression.
compression() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
 
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(byte[]) - Static method in class org.elasticsearch.common.compress.CompressorFactory
 
compressor(byte[], int, int) - 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
 
compressor(String) - Static method in class org.elasticsearch.common.compress.CompressorFactory
 
CompressorContext - Interface in org.elasticsearch.common.compress
 
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.core.BinaryFieldMapper.Builder
 
compressThreshold(long) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
 
ComputationException - Exception in org.elasticsearch.common.inject.internal
Wraps an exception that occured during a computation.
ComputationException(Throwable) - Constructor for exception org.elasticsearch.common.inject.internal.ComputationException
 
computeBoundingBox(Collection<? extends Shape>, SpatialContext) - Method in class org.elasticsearch.common.geo.XShapeCollection
 
computeNxys(long, long, long, long, String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
 
conbineGrouped(List<? extends Query>) - Method in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
 
concat(FieldMapper) - Method in class org.elasticsearch.index.mapper.FieldMappers
Concats and returns a new FieldMappers.
concat(ObjectMapper) - Method in class org.elasticsearch.index.mapper.ObjectMappers
Concats and returns a new ObjectMappers.
concat(ObjectMappers) - Method in class org.elasticsearch.index.mapper.ObjectMappers
Concats and returns a new ObjectMappers.
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.replication.TransportShardReplicationOperationAction.InternalRequest
 
concreteIndex() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.InternalRequest
 
concreteIndex() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction.InternalRequest
 
concreteIndex() - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction.InternalRequest
 
concreteIndices(String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
Deprecated.
use MetaData.concreteIndices(org.elasticsearch.action.support.IndicesOptions, String...) instead and be explicit about indices options to be used for indices resolution
concreteIndices(IndicesOptions, String...) - Method in class org.elasticsearch.cluster.metadata.MetaData
Translates the provided indices or aliases, eventually containing wildcard expressions, into actual indices.
concreteSingleIndex(String, IndicesOptions) - Method in class org.elasticsearch.cluster.metadata.MetaData
Utility method that allows to resolve an index or alias 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
A Recycler implementation based on a concurrent Deque.
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
 
ConcurrentMergeSchedulerProvider - Class in org.elasticsearch.index.merge.scheduler
 
ConcurrentMergeSchedulerProvider(ShardId, Settings, ThreadPool, IndexSettingsService) - Constructor for class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler - Class in org.elasticsearch.index.merge.scheduler
 
ConcurrentRebalanceAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
Similar to the ClusterRebalanceAllocationDecider this AllocationDecider controls the number of currently in-progress re-balance (relocation) operations and restricts node allocations if the configured threashold is reached.
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(SnapshotId, String, Throwable) - 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
 
Conf() - Constructor for class org.elasticsearch.river.RiverIndexName.Conf
 
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(int, String, int, int, InetAddress) - Constructor for class org.elasticsearch.common.network.MulticastChannel.Config
 
config() - Method in class org.elasticsearch.index.engine.Engine
 
config - Variable in class org.elasticsearch.index.shard.IndexShard
 
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.bulk.udp.BulkUdpModule
 
configure() - Method in class org.elasticsearch.cache.recycler.CacheRecyclerModule
 
configure() - Method in class org.elasticsearch.cache.recycler.DefaultPageCacheRecyclerModule
 
configure() - Method in class org.elasticsearch.cache.recycler.PageCacheRecyclerModule
 
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() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationModule
 
configure() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
configure() - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecidersModule
 
configure() - Method in class org.elasticsearch.cluster.routing.operation.OperationRoutingModule
 
configure() - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRoutingModule
 
configure() - Method in class org.elasticsearch.cluster.settings.ClusterDynamicSettingsModule
 
configure(Settings) - Method in interface org.elasticsearch.common.compress.Compressor
 
configure(Settings) - Static method in class org.elasticsearch.common.compress.CompressorFactory
 
configure(Settings) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
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.PrivateModule
 
configure() - Method in class org.elasticsearch.common.inject.PrivateModule
Creates bindings and other configurations private to this module.
configure(Settings) - Static method in class org.elasticsearch.common.logging.log4j.LogConfigurator
 
configure() - Method in class org.elasticsearch.common.network.NetworkModule
 
configure() - Method in class org.elasticsearch.common.settings.SettingsModule
 
configure() - Method in class org.elasticsearch.common.util.BigArraysModule
 
configure() - Method in class org.elasticsearch.common.util.DefaultBigArraysModule
 
configure() - Method in class org.elasticsearch.discovery.DiscoveryModule
 
configure() - Method in class org.elasticsearch.discovery.local.LocalDiscoveryModule
 
configure() - Method in class org.elasticsearch.discovery.zen.ZenDiscoveryModule
 
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.gateway.local.LocalGatewayModule
 
configure() - Method in class org.elasticsearch.gateway.none.NoneGatewayModule
 
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.docset.DocSetCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.filter.FilterCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.filter.ShardFilterCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.fixedbitset.ShardFixedBitSetFilterCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.IndexCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.query.parser.QueryParserCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.query.ShardQueryCacheModule
 
configure() - Method in class org.elasticsearch.index.codec.CodecModule
 
configure() - Method in class org.elasticsearch.index.deletionpolicy.DeletionPolicyModule
 
configure() - Method in class org.elasticsearch.index.engine.IndexEngineModule
 
configure() - Method in class org.elasticsearch.index.engine.internal.InternalIndexEngineModule
 
configure() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataModule
 
configure() - Method in class org.elasticsearch.index.fielddata.ShardFieldDataModule
 
configure() - Method in class org.elasticsearch.index.gateway.IndexGatewayModule
 
configure() - Method in class org.elasticsearch.index.gateway.IndexShardGatewayModule
 
configure() - Method in class org.elasticsearch.index.gateway.local.LocalIndexGatewayModule
 
configure() - Method in class org.elasticsearch.index.gateway.none.NoneIndexGatewayModule
 
configure() - Method in class org.elasticsearch.index.get.ShardGetModule
 
configure() - Method in class org.elasticsearch.index.indexing.ShardIndexingModule
 
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.merge.policy.MergePolicyModule
 
configure() - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerModule
 
configure() - Method in class org.elasticsearch.index.percolator.PercolatorShardModule
 
configure() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreModule
 
configure() - Method in class org.elasticsearch.index.query.IndexQueryParserModule
 
configure() - Method in class org.elasticsearch.index.search.shape.ShapeModule
 
configure() - Method in class org.elasticsearch.index.search.stats.ShardSearchModule
 
configure() - Method in class org.elasticsearch.index.settings.IndexDynamicSettingsModule
 
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.snapshots.IndexShardSnapshotModule
 
configure() - Method in class org.elasticsearch.index.store.fs.DefaultFsIndexStoreModule
 
configure() - Method in class org.elasticsearch.index.store.fs.MmapFsIndexStoreModule
 
configure() - Method in class org.elasticsearch.index.store.fs.NioFsIndexStoreModule
 
configure() - Method in class org.elasticsearch.index.store.fs.SimpleFsIndexStoreModule
 
configure() - Method in class org.elasticsearch.index.store.IndexStoreModule
 
configure() - Method in class org.elasticsearch.index.store.ram.RamIndexStoreModule
 
configure() - Method in class org.elasticsearch.index.store.StoreModule
 
configure() - Method in class org.elasticsearch.index.suggest.SuggestShardModule
 
configure() - Method in class org.elasticsearch.index.termvectors.ShardTermVectorModule
 
configure() - Method in class org.elasticsearch.index.translog.TranslogModule
 
configure() - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisModule
 
configure() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerModule
 
configure() - Method in class org.elasticsearch.indices.IndicesModule
 
configure() - Method in class org.elasticsearch.indices.query.IndicesQueriesModule
 
configure() - Method in class org.elasticsearch.monitor.MonitorModule
 
configure() - Method in class org.elasticsearch.node.internal.NodeModule
 
configure() - Method in class org.elasticsearch.percolator.PercolatorModule
 
configure() - Method in class org.elasticsearch.plugins.IndexPluginsModule
 
configure() - Method in class org.elasticsearch.plugins.PluginsModule
 
configure() - Method in class org.elasticsearch.plugins.ShardsPluginsModule
 
configure() - Method in class org.elasticsearch.repositories.fs.FsRepositoryModule
Configures a Binder via the exposed methods.
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.repositories.uri.URLRepositoryModule
Configures a Binder via the exposed methods.
configure() - Method in class org.elasticsearch.rest.action.RestActionModule
 
configure() - Method in class org.elasticsearch.rest.RestModule
 
configure() - Method in class org.elasticsearch.river.dummy.DummyRiverModule
 
configure() - Method in class org.elasticsearch.river.RiverModule
 
configure() - Method in class org.elasticsearch.river.RiverNameModule
 
configure() - Method in class org.elasticsearch.river.RiversModule
 
configure() - Method in class org.elasticsearch.river.RiversPluginsModule
 
configure() - Method in class org.elasticsearch.script.ScriptModule
 
configure() - Method in class org.elasticsearch.search.aggregations.AggregationModule
 
configure() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificantTermsHeuristicModule
 
configure() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.TransportSignificantTermsHeuristicModule
 
configure() - Method in class org.elasticsearch.search.aggregations.TransportAggregationModule
 
configure() - Method in class org.elasticsearch.search.facet.FacetModule
 
configure() - Method in class org.elasticsearch.search.facet.TransportFacetModule
 
configure() - Method in class org.elasticsearch.search.highlight.HighlightModule
 
configure() - Method in class org.elasticsearch.search.SearchModule
 
configure() - Method in class org.elasticsearch.search.suggest.SuggestModule
 
configure() - Method in class org.elasticsearch.search.TransportSearchModule
 
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
 
configureClientChannelPipelineFactory() - Method in class org.elasticsearch.transport.netty.NettyTransport
 
configureServerChannelPipelineFactory() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
configureServerChannelPipelineFactory(String, Settings) - Method in class org.elasticsearch.transport.netty.NettyTransport
 
conflicts() - Method in class org.elasticsearch.index.mapper.DocumentMapper.MergeResult
The merge conflicts.
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
 
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.IndexReplicationOperationRequest
 
consistencyLevel - Variable in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
consistencyLevel() - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
consistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
Sets the consistency level of write.
consistencyLevel() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
consistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
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.
consoleLoggingEnabled() - Static method in class org.elasticsearch.common.logging.Loggers
 
CONSTANT_VALUE_ALREADY_SET - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
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(FilterBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that wraps a filter and simply returns a constant score equal to the query boost for every document in the filter.
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(FilterBuilder) - Constructor for class org.elasticsearch.index.query.ConstantScoreQueryBuilder
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(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.gateway.CommitPoint
 
containPhysicalIndexFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
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.collect.IdentityHashSet
Returns true if this set contains the specified element.
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(long) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
containsKey(long) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
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.DocLookup
 
containsKey(Object) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
containsKey(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
containsSetting(String) - Method in class org.elasticsearch.index.settings.IndexDynamicSettingsModule
Returns true iff the given setting is in the dynamic settings map.
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.DocLookup
 
containsValue(Object) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
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.Murmur3FieldMapper
 
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.GeoPointFieldMapper
 
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.AnalyzerMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
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.SizeFieldMapper
 
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
 
contentThreadSafe() - Method in class org.elasticsearch.rest.BytesRestResponse
 
contentThreadSafe() - Method in class org.elasticsearch.rest.RestResponse
Can the content byte[] be used only with this thread (false), or by any thread (true).
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.AbstractFieldMapper
 
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.Murmur3FieldMapper
 
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.geo.GeoPointFieldMapper
 
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.BoostFieldMapper
 
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.SizeFieldMapper
 
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.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.
contentUnsafe() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
contentUnsafe() - Method in class org.elasticsearch.rest.RestRequest
Is the byte array content safe or unsafe for usage on other threads
context() - Method in class org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
context() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData.Factory
 
context - Variable in class org.elasticsearch.common.compress.CompressedIndexInput
Deprecated.
 
context - Variable in class org.elasticsearch.common.compress.CompressedStreamInput
 
context - Variable in class org.elasticsearch.common.compress.CompressedStreamOutput
 
context - Variable in class org.elasticsearch.common.lucene.docset.ContextDocIdSet
 
context - Variable in class org.elasticsearch.common.lucene.uid.Versions.DocIdAndVersion
 
CONTEXT - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
 
context - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
context() - Method in class org.elasticsearch.search.aggregations.Aggregator
 
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_MODE_GATEWAY - Static variable in class org.elasticsearch.cluster.metadata.MetaData
 
CONTEXT_MODE_PARAM - Static variable in class org.elasticsearch.cluster.metadata.MetaData
 
CONTEXT_MODE_SNAPSHOT - Static variable in class org.elasticsearch.cluster.metadata.MetaData
 
ContextBuilder<E extends ContextMapping> - Class in org.elasticsearch.search.suggest.context
 
ContextBuilder(String) - Constructor for class org.elasticsearch.search.suggest.context.ContextBuilder
 
ContextConfig() - Constructor for class org.elasticsearch.search.suggest.context.ContextMapping.ContextConfig
 
ContextDocIdSet - Class in org.elasticsearch.common.lucene.docset
A holder for a DocIdSet and the AtomicReaderContext it is associated with.
ContextDocIdSet(AtomicReaderContext, DocIdSet) - Constructor for class org.elasticsearch.common.lucene.docset.ContextDocIdSet
 
ContextHolder - Class in org.elasticsearch.common
 
ContextHolder() - Constructor for class org.elasticsearch.common.ContextHolder
 
ContextIndexSearcher - Class in org.elasticsearch.search.internal
Context-aware extension of IndexSearcher.
ContextIndexSearcher(SearchContext, Engine.Searcher) - Constructor for class org.elasticsearch.search.internal.ContextIndexSearcher
 
ContextIndexSearcher.Stage - Enum in org.elasticsearch.search.internal
 
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
A collection of ContextMappings, their ContextMapping.ContextConfiguration and a Document form a complete ContextMapping.Context.
ContextMapping.ContextConfig - Class in org.elasticsearch.search.suggest.context
A ContextMapping combined with the information provided by a document form a ContextMapping.ContextConfig which is used to build the underlying FST.
ContextMapping.ContextQuery - Class in org.elasticsearch.search.suggest.context
A ContextMapping.ContextQuery defines the context information for a specific ContextMapping defined within a suggestion request.
ContextQuery(String) - Constructor for class org.elasticsearch.search.suggest.context.ContextMapping.ContextQuery
 
contextSize() - Method in class org.elasticsearch.common.ContextHolder
 
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
Converts a DistanceUnit.Distance value given in a specific DistanceUnit into a value equal to the specified value but in a other DistanceUnit.
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.StringAndBytesText
 
convertFromStringArray(String[]) - Static method in class org.elasticsearch.common.text.StringText
 
convertFromWildcards(String[], IndicesOptions) - Method in class org.elasticsearch.cluster.metadata.MetaData
Converts a list of indices or aliases wildcards, and special +/- signs, into their respective full matches.
convertResponses(GetAliasesResponse, GetMappingsResponse, GetSettingsResponse, GetWarmersResponse) - Static method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
 
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
 
convertToMap(byte[], boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
 
convertToMap(byte[], int, int, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
 
convertToRuntime(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
 
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
builds an array of coordinates to a XContentBuilder
copy(File, File) - Static method in class org.elasticsearch.common.io.Streams
Copy the contents of the given input File to the given output File.
copy(byte[], File) - Static method in class org.elasticsearch.common.io.Streams
Copy the contents of the given byte array to the given output File.
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.
copyAndAddAll(Collection<? extends Map.Entry<String, Analyzer>>) - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
Return a new instance that contains the union of this and of the provided analyzers.
copyAndAddAll(Collection<? extends FieldMapper<?>>) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
Return a new instance that contains the union of this instance and the provided mappers.
copyAndAllAll(Collection<? extends FieldMapper<?>>) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
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
Same as CopyOnWriteHashMap.copyAndPut(Object, Object) but for an arbitrary number of entries.
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
Same as CopyOnWriteHashMap.copyAndRemove(Object) but for an arbitrary number of entries.
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.
copyAndRemoveAll(Collection<?>) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
Return a new instance that contains this instance minus the provided mappers.
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.HashedBytesArray
 
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.HashedBytesArray
 
copyBytesRef() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
 
copyContextFrom(ContextHolder) - Method in class org.elasticsearch.common.ContextHolder
Copies the context from the given context holder to this context holder.
copyCurrent() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor.ReaderAggregator
 
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(File, File) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Copy recursively a dir to a new location
copyNamedFilters() - 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
Set implementation based on CopyOnWriteHashMap.
CopyOnWriteHashSet() - Constructor for class org.elasticsearch.common.collect.CopyOnWriteHashSet
Create a new empty set.
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.core.AbstractFieldMapper.Builder
 
copyTo(AbstractFieldMapper.CopyTo) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
copyTo - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
copyTo() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
copyTo() - Method in interface 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
 
copyToByteArray(File) - Static method in class org.elasticsearch.common.io.Streams
Copy the contents of the given input File into a new byte array.
copyToByteArray(InputStream) - Static method in class org.elasticsearch.common.io.Streams
Copy the contents of the given InputStream into a new byte array.
copyToBytesFromClasspath(String) - Static method in class org.elasticsearch.common.io.Streams
 
copyToFields() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.CopyTo
 
copyToString(Reader) - Static method in class org.elasticsearch.common.io.Streams
Copy the contents of the given Reader into a String.
copyToStringFromClasspath(ClassLoader, String) - Static method in class org.elasticsearch.common.io.Streams
 
copyToStringFromClasspath(String) - Static method in class org.elasticsearch.common.io.Streams
 
coresPerSocket() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
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.local.state.meta
This exception is thrown when Elasticsearch detects an inconsistency in one of it's persistent states.
CorruptStateException(String) - Constructor for exception org.elasticsearch.gateway.local.state.meta.CorruptStateException
Creates a new CorruptStateException
CorruptStateException(CorruptIndexException) - Constructor for exception org.elasticsearch.gateway.local.state.meta.CorruptStateException
Creates a new CorruptStateException with the given exceptions stacktrace.
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.elasticsearch.common.lucene.docset.AllDocIdSet.Iterator
 
cost() - Method in class org.elasticsearch.common.lucene.docset.BitsDocIdSetIterator
 
cost() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.BitsBasedIterator
 
cost() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.IteratorBasedIterator
 
cost() - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
cost() - Method in class org.elasticsearch.index.search.child.ConstantScorer
 
count() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
 
count(CountRequest) - Method in interface org.elasticsearch.client.Client
A count of all the documents matching a specific query.
count(CountRequest, ActionListener<CountResponse>) - Method in interface org.elasticsearch.client.Client
A count of all the documents matching a specific query.
count(CountRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
count(CountRequest, ActionListener<CountResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
count(CountRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
count(CountRequest, ActionListener<CountResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
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(IndexSearcher, Query) - Static method in class org.elasticsearch.common.lucene.Lucene
 
count(IndexSearcher, Query, int) - Static method in class org.elasticsearch.common.lucene.Lucene
Performs a count on the searcher for query.
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.filter.FilterCache.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 - Variable in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
 
count() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
 
count() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
count() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
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 - Variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
count() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor.StatsProc
 
count() - Method in interface org.elasticsearch.search.facet.terms.strings.HashedAggregator.BytesRefCountIterator
 
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
 
CountDateHistogramFacetExecutor - Class in org.elasticsearch.search.facet.datehistogram
A date histogram facet collector that uses the same field as the key as well as the value.
CountDateHistogramFacetExecutor(IndexNumericFieldData, Rounding, DateHistogramFacet.ComparatorType, CacheRecycler) - Constructor for class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetExecutor
 
CountDateHistogramFacetExecutor.DateHistogramProc - Class in org.elasticsearch.search.facet.datehistogram
 
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
CountEntry(long, long) - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
CountEntry(long, long) - Constructor for class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet.CountEntry
 
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
 
CountHistogramFacetExecutor - Class in org.elasticsearch.search.facet.histogram
A histogram facet collector that uses the same field as the key as well as the value.
CountHistogramFacetExecutor(IndexNumericFieldData, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.CountHistogramFacetExecutor
 
CountHistogramFacetExecutor.HistogramProc - Class in org.elasticsearch.search.facet.histogram
 
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
A request to count the number of documents matching a specific query.
CountRequest(String...) - Constructor for class org.elasticsearch.action.count.CountRequest
Constructs a new count request against the provided indices.
countRequest(String...) - Static method in class org.elasticsearch.client.Requests
Creates a count request which counts the hits matched against a query.
CountRequestBuilder - Class in org.elasticsearch.action.count
A count action request builder.
CountRequestBuilder(Client) - Constructor for class org.elasticsearch.action.count.CountRequestBuilder
 
CountResponse - Class in org.elasticsearch.action.count
The response of the count action.
Counts() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
 
counts() - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetExecutor.DateHistogramProc
 
counts() - Method in class org.elasticsearch.search.facet.histogram.CountHistogramFacetExecutor.HistogramProc
 
countWithEarlyTermination(IndexSearcher, Query, Lucene.EarlyTerminatingCollector) - Static method in class org.elasticsearch.common.lucene.Lucene
Calls countWithEarlyTermination(searcher, null, query, collector)
countWithEarlyTermination(IndexSearcher, Filter, Query, Lucene.EarlyTerminatingCollector) - Static method in class org.elasticsearch.common.lucene.Lucene
Performs a count on query and filter with early termination using searcher.
countWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Returns the number of shards in a specific state
cpu() - Method in class org.elasticsearch.monitor.os.OsInfo
 
cpu() - Method in class org.elasticsearch.monitor.os.OsStats
 
cpu() - Method in class org.elasticsearch.monitor.process.ProcessStats
 
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
Set to true to force this index to use IndexRequest.OpType.CREATE.
create(boolean) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
Set to true to force this index to use IndexRequest.OpType.CREATE.
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(CreateIndexRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
create(CreateIndexRequest, ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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 Keys.
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, CompressedString) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
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(Reader) - 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.DelimitedPayloadTokenFilterFactory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.DutchStemTokenFilterFactory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.EdgeNGramTokenFilterFactory
 
create(Reader) - 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(Reader) - 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(Reader) - 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(Reader) - 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(Reader) - Method in class org.elasticsearch.index.analysis.NGramTokenizerFactory
 
create(Reader) - 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(Reader) - 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.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(Reader) - 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(Reader) - 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(Reader) - 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(Reader) - 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(Reader) - Method in class org.elasticsearch.index.analysis.WhitespaceTokenizerFactory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.WordDelimiterTokenFilterFactory
 
create(String, Settings) - Method in interface org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatProvider.Factory
 
create(String, Settings) - Method in class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider.Factory
 
create(String, Settings) - Method in interface org.elasticsearch.index.codec.postingsformat.PostingsFormatProvider.Factory
 
create(String, Settings) - Method in class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider.Factory
 
create(Engine.Create) - Method in class org.elasticsearch.index.engine.Engine
 
Create(DocumentMapper, Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long, boolean, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.Create
 
Create(DocumentMapper, Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long) - Constructor for class org.elasticsearch.index.engine.Engine.Create
 
Create(DocumentMapper, 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(String, Settings) - Method in interface org.elasticsearch.index.query.FilterParserFactory
 
create(QueryParseContext, GeoPointFieldMapper, String, List<CharSequence>) - Static method in class org.elasticsearch.index.query.GeohashCellFilter
Create a new geohash filter for a given set of geohashes.
create(String, Settings) - Method in interface org.elasticsearch.index.query.QueryParserFactory
 
create(DocIdSetIterator, Weight, float) - Static method in class org.elasticsearch.index.search.child.ConstantScorer
 
create(GeoPoint, GeoPoint, GeoPointFieldMapper) - Static method in class org.elasticsearch.index.search.geo.IndexedGeoBoundingBoxFilter
 
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
Creates a new SimilarityProvider instance
create(ShardId, long, RafReference, int) - Method in enum org.elasticsearch.index.translog.fs.FsTranslogFile.Type
 
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(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(Reader, Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
 
create(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
Creates the aggregator
create(ValuesSource.Bytes.ParentChild, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator.Factory
 
create(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator.Factory
 
create(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator.Factory
 
create(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator.Factory
 
create(ValuesSource, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator.Factory
 
create(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator.Factory
 
create(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator.Factory
 
create(String, List<B>, ValueFormatter, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Factory
 
create(ValuesSource, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
 
create(ValuesSource, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator.Factory
 
create(ValuesSource.GeoPoint, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregator.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregator.Factory
 
create(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator.Factory
 
create(ValuesSource.Numeric, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator.Factory
 
create(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator.Factory
 
create(VS, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator.Factory
 
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(AggregationContext, Aggregator, long) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
 
create(VS, long, AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
 
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(long, long, InternalAggregations, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
 
createBucket(long, long, InternalAggregations, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
 
createBucket(String, double, double, long, InternalAggregations, ValueFormatter) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
 
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, Reader) - Method in class org.apache.lucene.analysis.PrefixAnalyzer
 
createComponents(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
createComponents(String, Reader) - Method in class org.elasticsearch.index.analysis.NumericAnalyzer
 
createComponents(String, Reader) - 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.
createCountBasedEarlyTerminatingCollector(int) - Static method in class org.elasticsearch.common.lucene.Lucene
Creates count based early termination collector with a threshold of maxCountHits
created() - Method in class org.elasticsearch.index.engine.Engine.Index
 
created(boolean) - Method in class org.elasticsearch.index.engine.Engine.Index
 
createExistsCollector() - Static method in class org.elasticsearch.common.lucene.Lucene
Creates an Lucene.EarlyTerminatingCollector with a threshold of 1
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, Engine.Create, Throwable) - Constructor for exception org.elasticsearch.index.engine.CreateFailedEngineException
 
createFetchRequest(QuerySearchResult, AtomicArray.Entry<IntArrayList>, ScoreDoc[]) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
createFilter(int) - Method in class org.elasticsearch.common.util.BloomFilter.Factory
 
createGenerator(OutputStream) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
 
createGenerator(Writer) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContent
 
createGenerator(OutputStream) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
 
createGenerator(Writer) - Method in class org.elasticsearch.common.xcontent.json.JsonXContent
 
createGenerator(OutputStream) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContent
 
createGenerator(Writer) - 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(Writer) - Method in interface org.elasticsearch.common.xcontent.XContent
Creates a new generator using the provided writer.
createGenerator(OutputStream) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContent
 
createGenerator(Writer) - 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
createIndexNameTerm(String) - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
Creates a new index term based on the provided value.
createIndexNameTerm(BytesRef) - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
Creates a new index term based on the provided value.
CreateIndexRequest - Class in org.elasticsearch.action.admin.indices.create
A request to create an index.
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(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
 
CreateIndexRequestBuilder(IndicesAdminClient, 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
 
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
 
createModule(String, Settings) - Static method in class org.elasticsearch.common.inject.Modules
 
createModule(Class<? extends Module>, Settings) - Static method in class org.elasticsearch.common.inject.Modules
 
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) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
createNumericTokenizer(Reader, char[]) - Method in class org.elasticsearch.index.analysis.NumericAnalyzer
 
createNumericTokenizer(Reader, char[]) - Method in class org.elasticsearch.index.analysis.NumericDateAnalyzer
 
createNumericTokenizer(Reader, char[]) - Method in class org.elasticsearch.index.analysis.NumericDoubleAnalyzer
 
createNumericTokenizer(Reader, char[]) - Method in class org.elasticsearch.index.analysis.NumericFloatAnalyzer
 
createNumericTokenizer(Reader, char[]) - Method in class org.elasticsearch.index.analysis.NumericIntegerAnalyzer
 
createNumericTokenizer(Reader, char[]) - Method in class org.elasticsearch.index.analysis.NumericLongAnalyzer
 
createNumericTokenizer(Reader, 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 interface org.elasticsearch.common.blobstore.BlobContainer
Creates a new OutputStream for the given blob name
createOutput(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
createOutput(String) - Method in class org.elasticsearch.common.blobstore.url.URLBlobContainer
 
createOutput(String, IOContext) - Method in class org.elasticsearch.index.store.DistributorDirectory
 
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(byte[], int, int) - 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
 
createProxy(Errors, Class<?>) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
 
createReduced(String, double[], TDigestState, boolean) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentileRanks
 
createReduced(String, double[], TDigestState, boolean) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
createRiver(RiverName, Map<String, Object>) - Method in class org.elasticsearch.river.RiversService
 
createShard(int, boolean) - Method in class org.elasticsearch.index.IndexService
 
createSnapshot(CreateSnapshotRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Creates a new snapshot.
createSnapshot(CreateSnapshotRequest, ActionListener<CreateSnapshotResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Creates a new snapshot.
createSnapshot(CreateSnapshotRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
createSnapshot(CreateSnapshotRequest, ActionListener<CreateSnapshotResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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

The only mandatory parameter is repository name.

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(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
Constructs a new create snapshot request builder
CreateSnapshotRequestBuilder(ClusterAdminClient, 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, long) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
Create all aggregators so that they can be consumed with multiple buckets.
createTopLevelAggregators(AggregationContext) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
 
createTypeUids(Collection<String>, Object) - Static method in class org.elasticsearch.index.mapper.Uid
 
createTypeUids(Collection<String>, List<? extends Object>) - Static method in class org.elasticsearch.index.mapper.Uid
 
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
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator.Factory
 
createUnmapped(AggregationContext, Aggregator) - 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) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
Returns a Weight that applies the filter to the enclosed query's Weight.
createWeight(IndexSearcher) - Method in class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.index.search.child.ChildrenQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.index.search.child.ParentQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
createWeight(IndexSearcher) - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
 
creationDate(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
creationDate() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
creationDate() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
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.common.jna.Kernel32Library.ConsoleCtrlHandler
 
CURRENT - Static variable in class org.elasticsearch.Build
 
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
 
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 source
currentDocFreq - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
currentEngineReference - Variable in class org.elasticsearch.index.shard.IndexShard
 
currentId() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
currentId() - Method in interface org.elasticsearch.index.translog.Translog
Returns the id of the current transaction log.
currentMerges() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
currentMergesNumDocs() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
currentMergesSizeInBytes() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
currentName() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
currentName() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
currentNodeId - Variable in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
currentNodeId() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
currentNodeId() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
The current node id the shard is allocated on.
currentOrdinal() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
Retruns the current ordinal or 0 if this build has not been advanced via OrdinalsBuilder.nextOrdinal().
currentReader() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
currentScorer() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
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.SnapshotsService
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
 
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
 
currEstab() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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.metadata.IndexMetaData
 
custom(String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
custom(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
CUSTOM_FILTER_STRATEGY - Static variable in class org.elasticsearch.common.lucene.search.XFilteredQuery
 
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 TokenFilters.
CustomAnalyzerProvider(Index, Settings, 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.AbstractFieldMapper
Derived classes can override it to specify that boost value is set by derived classes.
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
 
CustomByteNumericField(NumberFieldMapper, byte, FieldType) - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.CustomByteNumericField
 
CustomDoubleNumericDocValuesField(String, double) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericDocValuesField
 
CustomDoubleNumericField(NumberFieldMapper, double, FieldType) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericField
 
customFactories - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
 
customFactories - Static variable in class org.elasticsearch.cluster.metadata.MetaData
 
customFieldDataSettings - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
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.
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(NumberFieldMapper, float, FieldType) - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericField
 
CustomGeoPointDocValuesField(String, double, double) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.CustomGeoPointDocValuesField
 
customHeaders - Variable in class org.elasticsearch.rest.RestResponse
 
CustomIntegerNumericField(NumberFieldMapper, int, FieldType) - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.CustomIntegerNumericField
 
CustomLongNumericDocValuesField(String, long) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomLongNumericDocValuesField
 
CustomLongNumericField(NumberFieldMapper, long, FieldType) - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.CustomLongNumericField
 
CustomNumericDocValuesField(String) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
 
CustomNumericField(NumberFieldMapper, Number, FieldType) - 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 XPostingsHighlighter that works for a single field in a single document.
CustomPostingsHighlighter(CustomPassageFormatter, List<Object>, boolean, int, int) - Constructor for class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
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
 
CustomQueryWrappingFilter - Class in org.elasticsearch.index.search.child
Forked from QueryWrapperFilter to make sure the weight is only created once.
CustomQueryWrappingFilter(Query) - Constructor for class org.elasticsearch.index.search.child.CustomQueryWrappingFilter
Constructs a filter which only matches documents matching query.
CustomRandomAccessFilterStrategy() - Constructor for class org.elasticsearch.common.lucene.search.XFilteredQuery.CustomRandomAccessFilterStrategy
 
CustomRandomAccessFilterStrategy(int) - Constructor for class org.elasticsearch.common.lucene.search.XFilteredQuery.CustomRandomAccessFilterStrategy
 
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() - Method in class org.elasticsearch.cluster.ClusterState
 
customs() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
customs() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
customs() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
customs(Map<String, IndexMetaData.Custom>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
 
CustomShortNumericField(NumberFieldMapper, short, FieldType) - 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, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CzechAnalyzerProvider
 
CzechStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
CzechStemTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CzechStemTokenFilterFactory
 

D

daemonThreadFactory(Settings, String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
daemonThreadFactory(Settings, String...) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
daemonThreadFactory(String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
DanishAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
DanishAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.DanishAnalyzerProvider
 
data(boolean) - Method in class org.elasticsearch.node.NodeBuilder
Is the node going to be allowed to allocate data (shards) to it or not.
dataFiles() - Method in class org.elasticsearch.env.Environment
The data location.
dataNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
 
dataNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
Should this node hold data (shards) or not.
dataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Get a Map of the discovered data nodes arranged by their ids
DataOutputStreamOutput - Class in org.elasticsearch.common.io.stream
 
DataOutputStreamOutput(DataOutput) - Constructor for class org.elasticsearch.common.io.stream.DataOutputStreamOutput
 
dataWithClusterFiles() - Method in class org.elasticsearch.env.Environment
The data location with the cluster name as a sub directory.
DATE_DETECTION - Static variable in class org.elasticsearch.index.mapper.object.RootObjectMapper.Defaults
 
DATE_TIME_FORMATTER - Static variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
 
DATE_TIME_FORMATTER - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
 
dateDetection - Variable in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
 
dateDetection() - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
 
dateField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
DateFieldMapper - Class in org.elasticsearch.index.mapper.core
 
DateFieldMapper(FieldMapper.Names, FormatDateTimeFormatter, int, float, FieldType, Boolean, String, TimeUnit, boolean, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper
 
DateFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
DateFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
DateFieldMapper.LateParsingQuery - Class in org.elasticsearch.index.mapper.core
 
DateFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
dateHistogram(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new DateHistogram aggregation with the given name.
DateHistogram - Interface in org.elasticsearch.search.aggregations.bucket.histogram
A date_histogram aggregation.
DateHistogram.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.histogram
 
DateHistogram.Interval - Class in org.elasticsearch.search.aggregations.bucket.histogram
The interval the date histogram is based on.
DateHistogramBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
Builder for the DateHistogram aggregation.
DateHistogramBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Sole constructor.
DateHistogramFacet - Interface in org.elasticsearch.search.facet.datehistogram
A date histogram facet.
dateHistogramFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
DateHistogramFacet.ComparatorType - Enum in org.elasticsearch.search.facet.datehistogram
 
DateHistogramFacet.Entry - Interface in org.elasticsearch.search.facet.datehistogram
 
DateHistogramFacetBuilder - Class in org.elasticsearch.search.facet.datehistogram
A facet builder of date histogram facets.
DateHistogramFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Constructs a new date histogram facet with the provided facet logical name.
DateHistogramFacetParser - Class in org.elasticsearch.search.facet.datehistogram
 
DateHistogramFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetParser
 
DateHistogramParser - Class in org.elasticsearch.search.aggregations.bucket.histogram
 
DateHistogramParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramParser
 
DateHistogramProc(LongLongOpenHashMap, Rounding) - Constructor for class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetExecutor.DateHistogramProc
 
DateHistogramProc(Rounding, LongObjectOpenHashMap<InternalFullDateHistogramFacet.FullEntry>) - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetExecutor.DateHistogramProc
 
DateHistogramProc(Rounding, SearchScript, LongObjectOpenHashMap<InternalFullDateHistogramFacet.FullEntry>) - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetExecutor.DateHistogramProc
 
DATELINE - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
 
DateMath(String, TimeUnit) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueParser.DateMath
 
DateMath(DateMathParser) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueParser.DateMath
 
DateMathParser - Class in org.elasticsearch.common.joda
 
DateMathParser(FormatDateTimeFormatter, TimeUnit) - Constructor for class org.elasticsearch.common.joda.DateMathParser
 
dateMathParser() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
dateRange(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new DateRange aggregation with the given name.
DateRange - Interface in org.elasticsearch.search.aggregations.bucket.range.date
A range aggregation on date values.
DateRange.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.range.date
 
DateRangeBuilder - Class in org.elasticsearch.search.aggregations.bucket.range.date
Builder for the DateRange aggregation.
DateRangeBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
Sole constructor.
DateRangeParser - Class in org.elasticsearch.search.aggregations.bucket.range.date
 
DateRangeParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeParser
 
DateTime(String, ValueFormatter, ValueParser) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormat.DateTime
 
DateTime(String) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
 
DateTime(FormatDateTimeFormatter) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
 
DateTime(String) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueParser.DateTime
 
DateTime(FormatDateTimeFormatter) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueParser.DateTime
 
dateTimeFormatter() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
dateTimeFormatter - Variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
dateTimeFormatter(FormatDateTimeFormatter) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
dateTimeFormatter - Variable in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
dateTimeFormatter() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
dateTimeFormatter(FormatDateTimeFormatter) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
 
dateTimeFormatter() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
DateTimeUnit - Enum in org.elasticsearch.common.rounding
 
dateValueField(XContentBuilderString, XContentBuilderString, long) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
DAY - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
days() - Method in class org.elasticsearch.common.unit.TimeValue
 
days(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
daysFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
deactivate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
Deactivate throttling, which switches the lock to be an always-acquirable NoOpLock
deactivateThrottling() - Method in class org.elasticsearch.index.engine.InternalEngine
 
Deadlock(ThreadInfo[]) - Constructor for class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
DeadlockAnalyzer - Class in org.elasticsearch.monitor.jvm
 
deadlockAnalyzer() - Static method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer
 
DeadlockAnalyzer.Deadlock - Class in org.elasticsearch.monitor.jvm
 
debug(String, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
Logs a DEBUG level message.
debug(String, Throwable, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
Logs a DEBUG level message.
debug(String, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
 
debug(String, Throwable, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
 
debug(String) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
debug(String, Throwable) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
DEBUG_SYSTEM_PROPERTY - Static variable in class org.elasticsearch.common.cli.Terminal
 
debugDecision(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
debugDecision() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
debugEnabled() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
 
dec() - Method in class org.elasticsearch.common.metrics.CounterMetric
 
dec(long) - Method in class org.elasticsearch.common.metrics.CounterMetric
 
dec(long) - Method in class org.elasticsearch.common.metrics.MeanMetric
 
DECAY - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
 
DecayFunction - Interface in org.elasticsearch.index.query.functionscore
Implement this interface to provide a decay function that is executed on a distance.
DecayFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
 
DecayFunctionBuilder(String, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
 
DecayFunctionParser - Class in org.elasticsearch.index.query.functionscore
This class provides the basic functionality needed for adding a decay function.
DecayFunctionParser() - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionParser
 
DecayFunctionParser.AbstractDistanceScoreFunction - Class in org.elasticsearch.index.query.functionscore
This is the base class for scoring a single field.
decCurrentAsSource() - Method in class org.elasticsearch.index.recovery.RecoveryStats
 
decCurrentAsTarget() - Method in class org.elasticsearch.index.recovery.RecoveryStats
 
deciders() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
Get AllocationDeciders used for allocation
Decision - Class in org.elasticsearch.cluster.routing.allocation.decider
This abstract class defining basic Decision used during shard allocation process.
Decision() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision
 
decision(Decision, String, String, Object...) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
Create a routing decision, including the reason if the debug flag is turned on
Decision.Multi - Class in org.elasticsearch.cluster.routing.allocation.decider
Simple class representing a list of decisions
Decision.Single - Class in org.elasticsearch.cluster.routing.allocation.decider
Simple class representing a single decision
Decision.Type - Enum in org.elasticsearch.cluster.routing.allocation.decider
This enumeration defines the possible types of decisions
decisions() - Method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
 
decode(String) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Decodes the given geohash
decode(String, GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Decodes the given geohash into a latitude and longitude
decode(long) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
 
decode(long, GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Decodes the given long-format geohash into a latitude and longitude
decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in class org.elasticsearch.common.netty.KeepFrameDecoder
 
decode(String) - Method in interface org.elasticsearch.common.path.PathTrie.Decoder
 
decode(byte[], int, GeoPoint) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
Decode a geo point from a byte-array, reading GeoPointFieldMapper.Encoding.numBytes() bytes.
decode(long, long, GeoPoint) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
Decode a geo point from the bits of the encoded latitude and longitudes.
decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in class org.elasticsearch.transport.netty.SizeHeaderFrameDecoder
 
decodeComponent(String) - Static method in class org.elasticsearch.rest.support.RestUtils
Decodes a bit of an URL encoded by a browser.
decodeComponent(String, Charset) - Static method in class org.elasticsearch.rest.support.RestUtils
Decodes a bit of an URL encoded by a browser.
decodeCoordinate(long) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
Decode a sequence of bits into the original coordinate.
decodeQueryString(String, int, Map<String, String>) - Static method in class org.elasticsearch.rest.support.RestUtils
 
decoder - Static variable in class org.elasticsearch.common.netty.KeepFrameDecoder
 
decodeWeight(long) - Static method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
cost -> weight
decompose(GeometryFactory, Coordinate[], ArrayList<LineString>) - Static method in class org.elasticsearch.common.geo.builders.BaseLineStringBuilder
 
decompose(double, Coordinate[]) - Static method in class org.elasticsearch.common.geo.builders.BaseLineStringBuilder
Decompose a linestring given as array of coordinates at a vertical line.
decreaseRefCount(boolean) - Method in class org.elasticsearch.index.translog.fs.RafReference
 
decRef() - Method in class org.elasticsearch.common.util.concurrent.AbstractRefCounted
 
decRef() - Method in interface org.elasticsearch.common.util.concurrent.RefCounted
Decreases the refCount of this instance.
decRef() - Method in class org.elasticsearch.index.store.Store
Decreases the refCount of this Store instance.If the refCount drops to 0, then this store is closed.
decrement() - Method in class jsr166e.LongAdder
Equivalent to add(-1).
dedup() - Method in class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
 
deduplicateSorted(Iterator<? extends T>, Comparator<? super T>) - Static method in enum org.elasticsearch.common.collect.Iterators2
Remove duplicated elements from an iterator over sorted content.
deepCopy() - Method in class org.elasticsearch.common.lucene.HashedBytesRef
 
deepCopyOf(HashedBytesRef) - Static method in class org.elasticsearch.common.lucene.HashedBytesRef
 
DEFAULT - Static variable in enum org.elasticsearch.action.search.SearchType
The default search type (SearchType.QUERY_THEN_FETCH.
DEFAULT - Static variable in class org.elasticsearch.cluster.ClusterName
 
DEFAULT - Static variable in class org.elasticsearch.common.cli.Terminal
 
DEFAULT - Static variable in enum org.elasticsearch.common.geo.GeoDistance
Default GeoDistance function.
DEFAULT - Static variable in enum org.elasticsearch.common.unit.DistanceUnit
 
DEFAULT - Static variable in class org.elasticsearch.common.util.BloomFilter.Factory
 
DEFAULT - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
DEFAULT - Static variable in class org.elasticsearch.index.merge.scheduler.MergeSchedulerModule
 
DEFAULT - Static variable in class org.elasticsearch.search.aggregations.support.format.ValueFormat.DateTime
 
DEFAULT - Static variable in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
 
DEFAULT - Static variable in class org.elasticsearch.search.aggregations.support.format.ValueParser.DateMath
 
DEFAULT - Static variable in class org.elasticsearch.search.aggregations.support.format.ValueParser.DateTime
 
DEFAULT_ACCEPTABLE_OVERHEAD_RATIO - Static variable in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
Default acceptable overhead ratio.
DEFAULT_ACK_TIMEOUT - Static variable in class org.elasticsearch.action.support.master.AcknowledgedRequest
 
DEFAULT_ALLOCATION_DECIDERS - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecidersModule
 
DEFAULT_ALLOW_LEADING_WILDCARD - Static variable in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
DEFAULT_ANALYZE_WILDCARD - Static variable in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
DEFAULT_BOOST - Static variable in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
DEFAULT_BOOST - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Boost terms in query based on score.
DEFAULT_BREAKER_TYPE - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
DEFAULT_CLUSTER_ROUTING_ALLOCATION_NODE_CONCURRENT_RECOVERIES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
 
DEFAULT_CLUSTER_ROUTING_ALLOCATION_NODE_INITIAL_PRIMARIES_RECOVERIES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
 
DEFAULT_CODEC - Static variable in class org.elasticsearch.index.codec.CodecService
 
DEFAULT_CONSUME_ALL_TOKENS - Static variable in class org.elasticsearch.index.analysis.LimitTokenCountFilterFactory
 
DEFAULT_DATE_TIME_FORMAT - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
DEFAULT_DELIMITER - Static variable in class org.elasticsearch.index.analysis.DelimitedPayloadTokenFilterFactory
 
DEFAULT_ENCODER - Static variable in class org.elasticsearch.index.analysis.DelimitedPayloadTokenFilterFactory
 
DEFAULT_EXISTENCE_VALUE - Static variable in class org.elasticsearch.index.query.MissingFilterParser
 
DEFAULT_EXPUNGE_DELETES_ALLOWED - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
DEFAULT_FIELD - Static variable in class org.elasticsearch.index.query.IndexQueryParserService
 
DEFAULT_FIELD_NAMES - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Default field names.
DEFAULT_FIELDDATA_BREAKER_LIMIT - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
DEFAULT_FIELDDATA_OVERHEAD_CONSTANT - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
DEFAULT_FLOOR_SEGMENT - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
DEFAULT_FORMAT - Static variable in class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatService
 
DEFAULT_FORMAT - Static variable in class org.elasticsearch.index.codec.postingsformat.PostingsFormatService
 
DEFAULT_GATHERING - Static variable in class org.elasticsearch.common.netty.NettyUtils
Here we go....
DEFAULT_GC_DELETES - Static variable in class org.elasticsearch.index.engine.EngineConfig
 
DEFAULT_HAS_PAYLOADS - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Defaults
 
DEFAULT_INDEX_ENGINE - Static variable in class org.elasticsearch.index.engine.IndexEngineModule.EngineSettings
 
DEFAULT_INDEX_NAME - Static variable in class org.elasticsearch.river.RiverIndexName.Conf
 
DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.search.SearchRequest
 
DEFAULT_INSTANCE - Static variable in class org.elasticsearch.common.inject.internal.SourceProvider
 
DEFAULT_LANG - Static variable in class org.elasticsearch.script.ScriptService
 
DEFAULT_MAPPING - Static variable in class org.elasticsearch.index.mapper.MapperService
 
DEFAULT_MASTER_NODE_TIMEOUT - Static variable in class org.elasticsearch.action.support.master.MasterNodeOperationRequest
 
DEFAULT_MAX_DOC_FREQ - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Ignore words which occur in more than this many docs.
DEFAULT_MAX_EDITS - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
The default maximum number of edits for fuzzy suggestions.
DEFAULT_MAX_INPUT_LENGTH - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Defaults
 
DEFAULT_MAX_LENGTH - Static variable in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Default maximum content size to process.
DEFAULT_MAX_MERGE_AT_ONCE - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
DEFAULT_MAX_MERGE_AT_ONCE - Static variable in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
Deprecated.
 
DEFAULT_MAX_MERGE_AT_ONCE_EXPLICIT - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
DEFAULT_MAX_MERGE_SIZE - Static variable in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
DEFAULT_MAX_MERGED_SEGMENT - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
DEFAULT_MAX_NUM_CELLS - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridParser
 
DEFAULT_MAX_NUM_TOKENS_PARSED - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Default maximum number of tokens to parse in each example doc field that is not stored with TermVector support.
DEFAULT_MAX_QUERY_TERMS - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Return a Query with no more than this many terms.
DEFAULT_MAX_TOKEN_COUNT - Static variable in class org.elasticsearch.index.analysis.LimitTokenCountFilterFactory
 
DEFAULT_MAX_WORD_LENGTH - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Ignore words greater than this length or if 0 then this has no effect.
DEFAULT_MIME_TYPES - Static variable in class org.elasticsearch.http.HttpServer
 
DEFAULT_MIN_DOC_FREQ - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Ignore words which do not occur in at least this many docs.
DEFAULT_MIN_FUZZY_LENGTH - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
The default minimum length of the key passed to XAnalyzingSuggester.lookup(java.lang.CharSequence, java.util.Set<org.apache.lucene.util.BytesRef>, boolean, int) before any edits are allowed.
DEFAULT_MIN_MERGE_SIZE - Static variable in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
DEFAULT_MIN_SCORE - Static variable in class org.elasticsearch.action.count.CountRequest
 
DEFAULT_MIN_SCORE - Static variable in class org.elasticsearch.action.exists.ExistsRequest
 
DEFAULT_MIN_TERM_FREQ - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Ignore terms with less than this frequency in the source doc.
DEFAULT_MIN_WORD_LENGTH - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Ignore words less than this length or if 0 then this has no effect.
DEFAULT_MINIMUM_SHOULD_MATCH - Static variable in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
DEFAULT_NO_MASTER_BLOCK - Static variable in class org.elasticsearch.discovery.DiscoverySettings
 
DEFAULT_NON_FUZZY_PREFIX - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
The default prefix length where edits are not allowed.
DEFAULT_NONEXISTENT_INDEX_RETRY_WAIT - Static variable in class org.elasticsearch.index.engine.ShadowEngine
 
DEFAULT_NULL_VALUE - Static variable in class org.elasticsearch.index.query.MissingFilterParser
 
DEFAULT_NUMBER_COEERCE_POLICY - Static variable in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
DEFAULT_PORT_RANGE - Static variable in class org.elasticsearch.transport.netty.NettyTransport
 
DEFAULT_POSITION_INCREMENTS - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Defaults
 
DEFAULT_PRECISION - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridParser
 
DEFAULT_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
DEFAULT_PRECISION_STEP - Static variable in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
DEFAULT_PRESERVE_SEPARATORS - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Defaults
 
DEFAULT_PROFILE - Static variable in class org.elasticsearch.transport.netty.NettyTransport
 
DEFAULT_PUBLISH_TIMEOUT - Static variable in class org.elasticsearch.discovery.DiscoverySettings
 
DEFAULT_RECLAIM_DELETES_WEIGHT - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
DEFAULT_RECOVER_AFTER_TIME_IF_EXPECTED_NODES_IS_SET - Static variable in class org.elasticsearch.gateway.GatewayService
 
DEFAULT_REFRESH_INTERVAL - Static variable in class org.elasticsearch.index.engine.EngineConfig
 
DEFAULT_REQUEST_BREAKER_LIMIT - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
DEFAULT_SCRIPTING_LANGUAGE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
 
DEFAULT_SEGMENTS_PER_TIER - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
DEFAULT_SETTING_PIPELINING - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
DEFAULT_SETTING_PIPELINING_MAX_EVENTS - Static variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
DEFAULT_SIMILARITY - Static variable in class org.elasticsearch.index.similarity.SimilarityLookupService
 
DEFAULT_STOP_WORDS - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Default set of stopwords.
DEFAULT_TERMINATE_AFTER - Static variable in class org.elasticsearch.search.internal.SearchContext
 
DEFAULT_TIMEOUT - Static variable in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
DEFAULT_TIMEOUT - Static variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
DEFAULT_TIMEOUT - Static variable in class org.elasticsearch.plugins.PluginManager
 
DEFAULT_TIMESTAMP - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
 
DEFAULT_TOKEN_LIMIT - Static variable in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
 
DEFAULT_TOTAL_CIRCUIT_BREAKER_LIMIT - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
DEFAULT_TRANSPOSITIONS - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
The default transposition value passed to LevenshteinAutomata
DEFAULT_UNICODE_AWARE - Static variable in class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
Measure maxEdits, minFuzzyLength, transpositions and nonFuzzyPrefix parameters in Unicode code points (actual letters) instead of bytes.
DEFAULT_VERSION_MAP_SIZE - Static variable in class org.elasticsearch.index.engine.EngineConfig
 
defaultAllowUnmappedFields() - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
defaultAnalyzer() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
defaultAnalyzer(Analyzer) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
defaultAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
defaultAnalyzer() - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
 
DefaultBigArraysModule - Class in org.elasticsearch.common.util
 
DefaultBigArraysModule(Settings) - Constructor for class org.elasticsearch.common.util.DefaultBigArraysModule
 
DefaultBindingScopingVisitor<V> - Class in org.elasticsearch.common.inject.spi
No-op visitor for subclassing.
DefaultBindingScopingVisitor() - Constructor for class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
 
DefaultBindingTargetVisitor<T,V> - Class in org.elasticsearch.common.inject.spi
No-op visitor for subclassing.
DefaultBindingTargetVisitor() - Constructor for class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
 
defaultClassConstructionWhitelist - Static variable in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
 
defaultCompressor() - Static method in class org.elasticsearch.common.compress.CompressorFactory
 
defaultConfig() - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
 
defaultConfig() - Method in class org.elasticsearch.search.suggest.context.ContextMapping
 
defaultConfig() - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
 
defaultDatePrinter - Static variable in class org.elasticsearch.common.xcontent.XContentBuilder
 
defaultDocValuesFormat() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
DefaultDocValuesFormatProvider - Class in org.elasticsearch.index.codec.docvaluesformat
The default doc values format.
DefaultDocValuesFormatProvider(String, Settings) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.DefaultDocValuesFormatProvider
 
DefaultElementVisitor<V> - Class in org.elasticsearch.common.inject.spi
No-op visitor for subclassing.
DefaultElementVisitor() - Constructor for class org.elasticsearch.common.inject.spi.DefaultElementVisitor
 
defaultField() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
defaultField(String) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
defaultField() - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
defaultField() - Method in class org.elasticsearch.index.query.QueryParseContext
 
defaultField(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
The default field to run against when no prefix field is specified.
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
defaultFieldDataType() - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
defaultFieldType() - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
defaultFormat() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
 
DefaultFsDirectoryService - Class in org.elasticsearch.index.store.fs
 
DefaultFsDirectoryService(ShardId, Settings, IndexStore) - Constructor for class org.elasticsearch.index.store.fs.DefaultFsDirectoryService
 
DefaultFsIndexStore - Class in org.elasticsearch.index.store.fs
 
DefaultFsIndexStore(Index, Settings, IndexService, IndicesStore, NodeEnvironment) - Constructor for class org.elasticsearch.index.store.fs.DefaultFsIndexStore
 
DefaultFsIndexStoreModule - Class in org.elasticsearch.index.store.fs
 
DefaultFsIndexStoreModule() - Constructor for class org.elasticsearch.index.store.fs.DefaultFsIndexStoreModule
 
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetParser
 
defaultGlobalMode() - Method in interface org.elasticsearch.search.facet.FacetParser
The default mode to use when executed as a "global" (all docs) facet.
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.filter.FilterFacetParser
 
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetParser
 
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetParser
 
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.query.QueryFacetParser
 
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.range.RangeFacetParser
 
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetParser
 
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.terms.TermsFacetParser
 
defaultGlobalMode() - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetParser
 
defaultIndexAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
defaultLocation(GeoPoint) - 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
defaultMainMode() - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetParser
 
defaultMainMode() - Method in interface org.elasticsearch.search.facet.FacetParser
The default mode to use when executed as a "main" (query level) facet.
defaultMainMode() - Method in class org.elasticsearch.search.facet.filter.FilterFacetParser
 
defaultMainMode() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetParser
 
defaultMainMode() - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetParser
 
defaultMainMode() - Method in class org.elasticsearch.search.facet.query.QueryFacetParser
 
defaultMainMode() - Method in class org.elasticsearch.search.facet.range.RangeFacetParser
 
defaultMainMode() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetParser
 
defaultMainMode() - Method in class org.elasticsearch.search.facet.terms.TermsFacetParser
 
defaultMainMode() - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetParser
 
defaultMethodBlacklist - Static variable in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
 
defaultOperator() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
defaultOperator(QueryParser.Operator) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
defaultOperator(QueryStringQueryBuilder.Operator) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Sets the boolean operator of the query parser used to parse the query string.
defaultOperator(SimpleQueryStringBuilder.Operator) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
Specify the default operator for the query.
defaultPackageWhitelist - Static variable in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
 
DefaultPageCacheRecyclerModule - Class in org.elasticsearch.cache.recycler
 
DefaultPageCacheRecyclerModule(Settings) - Constructor for class org.elasticsearch.cache.recycler.DefaultPageCacheRecyclerModule
 
defaultPostingFormat() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
defaultPostingFormat() - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
DefaultPostingsFormatProvider - Class in org.elasticsearch.index.codec.postingsformat
The default postingsformat, maps to Lucene41PostingsFormat.
DefaultPostingsFormatProvider(String, Settings) - Constructor for class org.elasticsearch.index.codec.postingsformat.DefaultPostingsFormatProvider
 
defaultQuoteAnalyzer() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
defaultQuoteAnalyzer(Analyzer) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
defaultReplicationType - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
defaultRescoreWindowSize(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Set the rescore window size for rescores that don't specify their window.
defaultReuseAddress() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
Defaults() - Constructor for class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.Murmur3FieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.core.TokenCountFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.AnalyzerMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.VersionFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.object.ObjectMapper.Defaults
 
Defaults() - Constructor for class org.elasticsearch.index.mapper.object.RootObjectMapper.Defaults
 
DEFAULTS() - Constructor for class org.elasticsearch.index.query.GeoShapeFilterParser.DEFAULTS
 
DEFAULTS() - Constructor for class org.elasticsearch.index.query.GeoShapeQueryParser.DEFAULTS
 
Defaults() - Constructor for class org.elasticsearch.index.query.IndexQueryParserService.Defaults
 
defaultSearchAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
DefaultSearchContext - Class in org.elasticsearch.search.internal
 
DefaultSearchContext(long, ShardSearchRequest, SearchShardTarget, Engine.Searcher, IndexService, IndexShard, ScriptService, CacheRecycler, PageCacheRecycler, BigArrays, Counter) - Constructor for class org.elasticsearch.search.internal.DefaultSearchContext
 
defaultSearchQuoteAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
DefaultShardOperationFailedException - Class in org.elasticsearch.action.support
 
DefaultShardOperationFailedException(IndexShardException) - Constructor for class org.elasticsearch.action.support.DefaultShardOperationFailedException
 
DefaultShardOperationFailedException(String, int, Throwable) - Constructor for class org.elasticsearch.action.support.DefaultShardOperationFailedException
 
DefaultSimilarityProvider - Class in org.elasticsearch.index.similarity
SimilarityProvider for DefaultSimilarity.
DefaultSimilarityProvider(String, Settings) - Constructor for class org.elasticsearch.index.similarity.DefaultSimilarityProvider
 
defaultStrategy() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
defaultTimestamp() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
defaultTimestamp(String) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
 
defaultTimestamp() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
defaultTTL(long) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Builder
 
defaultTTL() - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
defaultWriteConsistencyLevel - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
DEFAUTL_INDEX_BUFFER_SIZE - Static variable in class org.elasticsearch.index.engine.EngineConfig
 
DEFAUTL_KEEPALIVE_KEY - Static variable in class org.elasticsearch.search.SearchService
 
DeferringBucketCollector - Class in org.elasticsearch.search.aggregations.bucket
Buffers the matches in a collect stream and can replay a subset of the collected buckets to a deferred set of collectors.
DeferringBucketCollector(BucketCollector, AggregationContext) - Constructor for class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
 
delay(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequest
The delay for the restart to occur.
delay(String) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequest
The delay for the restart to occur.
delay() - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequest
 
delay(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
The delay for the shutdown to occur.
delay() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
 
delay(String) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
The delay for the shutdown to occur.
DelayRecoveryException - Exception in org.elasticsearch.indices.recovery
An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
DelayRecoveryException(String) - Constructor for exception org.elasticsearch.indices.recovery.DelayRecoveryException
 
DelayRecoveryException(String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.DelayRecoveryException
 
delDocCount - Variable in class org.elasticsearch.index.engine.Segment
 
delegate() - Method in class org.elasticsearch.common.collect.CopyOnWriteHashSet
 
delegate - Variable in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
delegate() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormatProvider
Deprecated.
 
delegate() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
delegate() - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
 
delegates - Variable in class org.elasticsearch.index.store.distributor.AbstractDistributor
 
DelegatingActionListener<Instigator extends ActionResponse,Delegated extends ActionResponse> - Class in org.elasticsearch.action.support
 
DelegatingActionListener(ActionListener<Delegated>) - Constructor for class org.elasticsearch.action.support.DelegatingActionListener
 
DelegatingMapParams(Map<String, String>, ToXContent.Params) - Constructor for class org.elasticsearch.common.xcontent.ToXContent.DelegatingMapParams
 
delete(DeleteRequest) - Method in interface org.elasticsearch.client.Client
Deletes a document from the index based on the index, type and id.
delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in interface org.elasticsearch.client.Client
Deletes a document from the index based on the index, type and id.
delete(DeleteIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes an index based on the index name.
delete(DeleteIndexRequest, ActionListener<DeleteIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes an index based on the index name.
delete(DeleteRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
delete(DeleteIndexRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
delete(DeleteIndexRequest, ActionListener<DeleteIndexResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
delete(DeleteRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
delete(BlobPath) - Method in interface org.elasticsearch.common.blobstore.BlobStore
 
delete(BlobPath) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
delete(BlobPath) - Method in class org.elasticsearch.common.blobstore.url.URLBlobStore
This operation is not supported by URL Blob Store
delete() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
delete(String, String) - Static method in class org.elasticsearch.common.Strings
Delete all occurrences of the given substring.
delete() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommit
Override the delete operation, and only actually delete it if it is not held by the SnapshotDeletionPolicy.
delete(Engine.Delete) - Method in class org.elasticsearch.index.engine.Engine
 
delete(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.engine.Engine
 
Delete(String, String, Term, long, VersionType, Engine.Operation.Origin, long, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.Delete
 
Delete(String, String, Term) - Constructor for class org.elasticsearch.index.engine.Engine.Delete
 
Delete(Engine.Delete, VersionType) - Constructor for class org.elasticsearch.index.engine.Engine.Delete
 
delete(Engine.Delete) - Method in class org.elasticsearch.index.engine.InternalEngine
 
delete(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.engine.InternalEngine
 
delete(Engine.Delete) - Method in class org.elasticsearch.index.engine.ShadowEngine
 
delete(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.engine.ShadowEngine
 
delete(Engine.Delete) - Method in class org.elasticsearch.index.shard.IndexShard
 
delete(SnapshotId, ShardId) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
Delete shard snapshot
Delete() - Constructor for class org.elasticsearch.index.translog.Translog.Delete
 
Delete(Engine.Delete) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
 
Delete(Term) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
 
Delete(Term, long, VersionType) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
 
DELETE_BY_QUERY_API - Static variable in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
DeleteAction - Class in org.elasticsearch.action.delete
 
deleteAny(String, String) - Static method in class org.elasticsearch.common.Strings
Delete any character in a given String.
deleteBlob(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
deleteBlob(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
deleteBlob(String) - Method in class org.elasticsearch.common.blobstore.url.URLBlobContainer
This operation is not supported by URLBlobContainer
deleteBlobsByFilter(BlobContainer.BlobNameFilter) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
deleteBlobsByFilter(BlobContainer.BlobNameFilter) - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
 
deleteBlobsByPrefix(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
deleteBlobsByPrefix(String) - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
 
deleteByQuery(DeleteByQueryRequest) - Method in interface org.elasticsearch.client.Client
Deletes all documents from one or more indices based on a query.
deleteByQuery(DeleteByQueryRequest, ActionListener<DeleteByQueryResponse>) - Method in interface org.elasticsearch.client.Client
Deletes all documents from one or more indices based on a query.
deleteByQuery(DeleteByQueryRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
deleteByQuery(DeleteByQueryRequest, ActionListener<DeleteByQueryResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
deleteByQuery(DeleteByQueryRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
deleteByQuery(DeleteByQueryRequest, ActionListener<DeleteByQueryResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
DeleteByQuery(Query, BytesReference, String[], Filter, FixedBitSetFilter, Engine.Operation.Origin, long, String...) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
deleteByQuery(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.shard.IndexShard
 
DeleteByQuery() - Constructor for class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
DeleteByQuery(Engine.DeleteByQuery) - Constructor for class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
DeleteByQuery(BytesReference, String[], String...) - Constructor for class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
DeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
 
DeleteByQueryFailedEngineException - Exception in org.elasticsearch.index.engine
 
DeleteByQueryFailedEngineException(ShardId, Engine.DeleteByQuery, Throwable) - Constructor for exception org.elasticsearch.index.engine.DeleteByQueryFailedEngineException
 
DeleteByQueryRequest - Class in org.elasticsearch.action.deletebyquery
A request to delete all documents that matching a specific query.
DeleteByQueryRequest(String...) - Constructor for class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
Constructs a new delete by query request to run against the provided indices.
DeleteByQueryRequest() - Constructor for class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
DeleteByQueryRequest(ActionRequest) - Constructor for class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
Copy constructor that creates a new delete by query request that is a copy of the one provided as an argument.
deleteByQueryRequest(String...) - Static method in class org.elasticsearch.client.Requests
Creates a delete by query request.
DeleteByQueryRequestBuilder - Class in org.elasticsearch.action.deletebyquery
 
DeleteByQueryRequestBuilder(Client) - Constructor for class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
 
DeleteByQueryResponse - Class in org.elasticsearch.action.deletebyquery
The response of delete by query action.
deleteByQueryShards(ClusterState, String, Set<String>) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
deleteByQueryShards(ClusterState, String, Set<String>) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
deleteClosedIndex(String, IndexMetaData, ClusterState) - Method in class org.elasticsearch.indices.IndicesService
 
DeleteFailedEngineException - Exception in org.elasticsearch.index.engine
 
DeleteFailedEngineException(ShardId, Engine.Delete, Throwable) - Constructor for exception org.elasticsearch.index.engine.DeleteFailedEngineException
 
deleteFile(String) - Method in class org.elasticsearch.index.store.DistributorDirectory
 
deleteFile(String) - Method in class org.elasticsearch.index.store.Store.StoreDirectory
 
deleteFilesIfExist(Path...) - Static method in class org.apache.lucene.util.XIOUtils
Deletes all given Paths, if they exist.
deleteFilesIfExist(Collection<? extends Path>) - Static method in class org.apache.lucene.util.XIOUtils
Deletes all given Paths, if they exist.
deleteFilesIgnoringExceptions(Directory, String...) - Static method in class org.apache.lucene.util.XIOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deleteFilesIgnoringExceptions(Path...) - Static method in class org.apache.lucene.util.XIOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deleteFilesIgnoringExceptions(Collection<? extends Path>) - Static method in class org.apache.lucene.util.XIOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deleteIndex(MetaDataDeleteIndexService.Request, MetaDataDeleteIndexService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService
 
deleteIndex(String, String) - Method in class org.elasticsearch.indices.IndicesService
Deletes the given index.
DeleteIndexAction - Class in org.elasticsearch.action.admin.indices.delete
 
deleteIndexDirectorySafe(Index, long, Settings) - Method in class org.elasticsearch.env.NodeEnvironment
Deletes an indexes data directory recursively iff all of the indexes shards locks were successfully acquired.
deleteIndexDirectoryUnderLock(Index, Settings) - Method in class org.elasticsearch.env.NodeEnvironment
Deletes an indexes data directory recursively.
deleteIndexedScript(DeleteIndexedScriptRequest, ActionListener<DeleteIndexedScriptResponse>) - Method in interface org.elasticsearch.client.Client
delete an indexed script
deleteIndexedScript(DeleteIndexedScriptRequest) - Method in interface org.elasticsearch.client.Client
Delete an indexed script
deleteIndexedScript(DeleteIndexedScriptRequest, ActionListener<DeleteIndexedScriptResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
delete an indexed script
deleteIndexedScript(DeleteIndexedScriptRequest) - Method in class org.elasticsearch.client.support.AbstractClient
Delete an indexed script
DeleteIndexedScriptAction - Class in org.elasticsearch.action.indexedscripts.delete
 
DeleteIndexedScriptRequest - Class in org.elasticsearch.action.indexedscripts.delete
A request to delete a script from the script index based on its scriptLang and id.
DeleteIndexedScriptRequest() - Constructor for class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
 
DeleteIndexedScriptRequest(String, String) - Constructor for class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
Constructs a new delete request against the specified index with the scriptLang and id.
DeleteIndexedScriptRequestBuilder - Class in org.elasticsearch.action.indexedscripts.delete
A delete document action request builder.
DeleteIndexedScriptRequestBuilder(Client) - Constructor for class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequestBuilder
 
DeleteIndexedScriptResponse - Class in org.elasticsearch.action.indexedscripts.delete
The response of the delete indexed script action.
DeleteIndexedScriptResponse() - Constructor for class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
 
DeleteIndexedScriptResponse(String, String, String, long, boolean) - Constructor for class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
 
DeleteIndexRequest - Class in org.elasticsearch.action.admin.indices.delete
A request to delete an index.
DeleteIndexRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
Constructs a new delete index request for the specified index.
DeleteIndexRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
Constructs a new delete index request for the specified indices.
deleteIndexRequest(String) - Static method in class org.elasticsearch.client.Requests
Creates a delete index request.
DeleteIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.delete
 
DeleteIndexRequestBuilder(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
 
DeleteIndexResponse - Class in org.elasticsearch.action.admin.indices.delete
A response for a delete index action.
deleteIndexStore(String, IndexMetaData, ClusterState) - Method in class org.elasticsearch.indices.IndicesService
Deletes the index store trying to acquire all shards locks for this index.
DeleteIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
 
DeleteIndexTemplateRequest - Class in org.elasticsearch.action.admin.indices.template.delete
A request to delete an index template.
DeleteIndexTemplateRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
Constructs a new delete index request for the specified name.
DeleteIndexTemplateRequestBuilder - Class in org.elasticsearch.action.admin.indices.template.delete
 
DeleteIndexTemplateRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
 
DeleteIndexTemplateRequestBuilder(IndicesAdminClient, String) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
 
DeleteIndexTemplateResponse - Class in org.elasticsearch.action.admin.indices.template.delete
A response for a delete index template.
deleteMapping(DeleteMappingRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes mapping (and all its data) from one or more indices.
deleteMapping(DeleteMappingRequest, ActionListener<DeleteMappingResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes mapping definition for a type into one or more indices.
deleteMapping(DeleteMappingRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
deleteMapping(DeleteMappingRequest, ActionListener<DeleteMappingResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
DeleteMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.delete
 
DeleteMappingClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.mapping.delete
Cluster state update request that allows to delete a mapping
DeleteMappingRequest - Class in org.elasticsearch.action.admin.indices.mapping.delete
Represents a request to delete a mapping
DeleteMappingRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
Constructs a new delete mapping request against one or more indices.
deleteMappingRequest(String...) - Static method in class org.elasticsearch.client.Requests
Deletes mapping (and all its data) from one or more indices.
DeleteMappingRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.delete
Builder for a delete mapping request
DeleteMappingRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequestBuilder
 
DeleteMappingResponse - Class in org.elasticsearch.action.admin.indices.mapping.delete
The response of remove mapping operation.
deleteMetaState(Path...) - Static method in class org.elasticsearch.gateway.local.state.meta.MetaDataStateFormat
Deletes all meta state directories recursively for the given data locations
deleteQuiet(String...) - Method in class org.elasticsearch.index.store.Store
 
deleteRecursively(File[], boolean) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Deletes the given files recursively.
deleteRecursively(File...) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Deletes the given files recursively including the given roots.
deleteRecursively(File, boolean) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Delete the supplied File - for directories, recursively delete any nested directories or files as well.
deleteRepository(DeleteRepositoryRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Unregisters a repository.
deleteRepository(DeleteRepositoryRequest, ActionListener<DeleteRepositoryResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Unregisters a repository.
deleteRepository(DeleteRepositoryRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
deleteRepository(DeleteRepositoryRequest, ActionListener<DeleteRepositoryResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
DeleteRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.delete
Unregister repository action
DeleteRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.delete
Unregister repository request.
DeleteRepositoryRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
Constructs a new unregister repository request with the provided name.
deleteRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
Deletes registration for snapshot repository
DeleteRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.delete
Builder for unregister repository request
DeleteRepositoryRequestBuilder(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequestBuilder
Constructs unregister repository request builder
DeleteRepositoryRequestBuilder(ClusterAdminClient, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequestBuilder
Constructs unregister repository request builder with specified repository name
DeleteRepositoryResponse - Class in org.elasticsearch.action.admin.cluster.repositories.delete
Unregister repository response
DeleteRequest - Class in org.elasticsearch.action.delete
A request to delete a document from an index based on its type and id.
DeleteRequest() - Constructor for class org.elasticsearch.action.delete.DeleteRequest
 
DeleteRequest(String) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
Constructs a new delete request against the specified index.
DeleteRequest(String, String, String) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
Constructs a new delete request against the specified index with the type and id.
DeleteRequest(DeleteRequest) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
Copy constructor that creates a new delete request that is a copy of the one provided as an argument.
DeleteRequest(DeleteRequest, ActionRequest) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
Copy constructor that creates a new delete request that is a copy of the one provided as an argument.
DeleteRequest(ActionRequest) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
Creates a delete 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
deleteRequest(String) - Static method in class org.elasticsearch.client.Requests
Creates a delete request against a specific index.
DeleteRequestBuilder - Class in org.elasticsearch.action.delete
A delete document action request builder.
DeleteRequestBuilder(Client) - Constructor for class org.elasticsearch.action.delete.DeleteRequestBuilder
 
DeleteRequestBuilder(Client, String) - Constructor for class org.elasticsearch.action.delete.DeleteRequestBuilder
 
DeleteResponse - Class in org.elasticsearch.action.delete
The response of the delete action.
DeleteResponse() - Constructor for class org.elasticsearch.action.delete.DeleteResponse
 
DeleteResponse(String, String, String, long, boolean) - Constructor for class org.elasticsearch.action.delete.DeleteResponse
 
deleteScriptFromIndex(DeleteIndexedScriptRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.script.ScriptService
 
deleteShardDirectorySafe(ShardId, Settings) - Method in class org.elasticsearch.env.NodeEnvironment
Deletes a shard data directory iff the shards locks were successfully acquired.
deleteShardDirectoryUnderLock(ShardLock, Settings) - Method in class org.elasticsearch.env.NodeEnvironment
Deletes a shard data directory.
deleteShards(ClusterState, String, String, String, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
deleteShards(ClusterState, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
deleteShardStore(String, ShardLock, Settings) - Method in class org.elasticsearch.indices.IndicesService
Deletes the shard with an already acquired shard lock.
deleteShardStore(String, ShardId, IndexMetaData) - Method in class org.elasticsearch.indices.IndicesService
This method deletes the shard contents on disk for the given shard ID.
deletesLogger - Variable in class org.elasticsearch.index.store.Store.StoreDirectory
 
deleteSnapshot(DeleteSnapshotRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Delete snapshot.
deleteSnapshot(DeleteSnapshotRequest, ActionListener<DeleteSnapshotResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Delete snapshot.
deleteSnapshot(DeleteSnapshotRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
deleteSnapshot(DeleteSnapshotRequest, ActionListener<DeleteSnapshotResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
deleteSnapshot(SnapshotId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
Deletes snapshot
deleteSnapshot(SnapshotId) - Method in interface org.elasticsearch.repositories.Repository
Deletes snapshot
deleteSnapshot(SnapshotId, SnapshotsService.DeleteSnapshotListener) - Method in class org.elasticsearch.snapshots.SnapshotsService
Deletes snapshot from repository.
DeleteSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
Delete snapshot action
DeleteSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
Delete snapshot request

Delete snapshot request removes the snapshot record from the repository and cleans up all files that are associated with this particular snapshot.

DeleteSnapshotRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
Constructs a new delete snapshots request
DeleteSnapshotRequest(String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
Constructs a new delete snapshots request with repository and snapshot name
DeleteSnapshotRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
Constructs a new delete snapshots request with repository name
deleteSnapshotRequest(String, String) - Static method in class org.elasticsearch.client.Requests
Deletes a snapshot
DeleteSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
Delete snapshot request builder
DeleteSnapshotRequestBuilder(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
Constructs delete snapshot request builder
DeleteSnapshotRequestBuilder(ClusterAdminClient, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
Constructs delete snapshot request builder with specified repository and snapshot names
DeleteSnapshotResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
Delete snapshot response
deleteSubDirectories(Path...) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Deletes all subdirectories in the given path recursively
deleteTemplate(DeleteIndexTemplateRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes index template.
deleteTemplate(DeleteIndexTemplateRequest, ActionListener<DeleteIndexTemplateResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes an index template.
deleteTemplate(DeleteIndexTemplateRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
deleteTemplate(DeleteIndexTemplateRequest, ActionListener<DeleteIndexTemplateResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
deleteWarmer(DeleteWarmerRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes an index warmer.
deleteWarmer(DeleteWarmerRequest, ActionListener<DeleteWarmerResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes an index warmer.
deleteWarmer(DeleteWarmerRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
deleteWarmer(DeleteWarmerRequest, ActionListener<DeleteWarmerResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
DeleteWarmerAction - Class in org.elasticsearch.action.admin.indices.warmer.delete
Action for the admin/warmers/delete API.
DeleteWarmerRequest - Class in org.elasticsearch.action.admin.indices.warmer.delete
A request that deletes a index warmer (name, SearchRequest) tuple from the clusters metadata.
DeleteWarmerRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequest
Constructs a new delete warmer request for the specified name.
DeleteWarmerRequestBuilder - Class in org.elasticsearch.action.admin.indices.warmer.delete
A builder for the DeleteWarmerRequest
DeleteWarmerRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequestBuilder
 
DeleteWarmerResponse - Class in org.elasticsearch.action.admin.indices.warmer.delete
An acknowledged response of delete warmer operation.
deletionPolicy - Variable in class org.elasticsearch.index.engine.Engine
 
DeletionPolicyModule - Class in org.elasticsearch.index.deletionpolicy
 
DeletionPolicyModule(Settings) - Constructor for class org.elasticsearch.index.deletionpolicy.DeletionPolicyModule
 
DeletionPolicyModule.DeletionPolicySettings - Class in org.elasticsearch.index.deletionpolicy
 
DeletionPolicySettings() - Constructor for class org.elasticsearch.index.deletionpolicy.DeletionPolicyModule.DeletionPolicySettings
 
delimitedListToStringArray(String, String) - Static method in class org.elasticsearch.common.Strings
Take a String which is a delimited list and convert it to a String array.
delimitedListToStringArray(String, String, String) - Static method in class org.elasticsearch.common.Strings
Take a String which is a delimited list and convert it to a String array.
DelimitedPayloadTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
DelimitedPayloadTokenFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.DelimitedPayloadTokenFilterFactory
 
DELIMITER - Static variable in class org.elasticsearch.index.mapper.Uid
 
DELIMITER_BYTE - Static variable in class org.elasticsearch.index.mapper.Uid
 
DELIMITER_BYTES - Static variable in class org.elasticsearch.index.mapper.Uid
 
delta(DiscoveryNodes) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Returns the changes comparing this nodes to the provided nodes.
Delta(String, ImmutableList<DiscoveryNode>, ImmutableList<DiscoveryNode>) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
Delta(DiscoveryNode, DiscoveryNode, String, ImmutableList<DiscoveryNode>, ImmutableList<DiscoveryNode>) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
Dependency<T> - Class in org.elasticsearch.common.inject.spi
A variable that can be resolved by an injector.
depth - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
depth() - Method in class org.elasticsearch.search.aggregations.Aggregator
Return the depth of this aggregator in the aggregation tree.
deque(Recycler.C<T>, int) - Static method in enum org.elasticsearch.common.recycler.Recyclers
Return a recycler based on a deque.
dequeFactory(Recycler.C<T>, int) - Static method in enum org.elasticsearch.common.recycler.Recyclers
Return a recycler based on a deque.
DequeRecycler<T> - Class in org.elasticsearch.common.recycler
A Recycler implementation based on a Deque.
DequeRecycler(Recycler.C<T>, Deque<T>, int) - Constructor for class org.elasticsearch.common.recycler.DequeRecycler
 
describeParams() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Describe the parameters that control how the "more like this" query is formed.
description() - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
description() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation.NodeExplanation
Get the explanation for the node
description() - Method in interface org.elasticsearch.plugins.Plugin
The description of the plugin.
description() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
 
description() - Method in enum org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.ComparatorType
 
description() - Method in enum org.elasticsearch.search.facet.histogram.HistogramFacet.ComparatorType
 
DESCRIPTION_NOT_AVAILABLE - Static variable in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
deserialize(DataInput) - Static method in class org.elasticsearch.common.util.BloomFilter
 
destroy() - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
destroy(T) - Method in class org.elasticsearch.common.recycler.AbstractRecyclerC
 
destroy(T) - Method in interface org.elasticsearch.common.recycler.Recycler.C
Destroy the data.
DestructiveOperations - Class in org.elasticsearch.action.support
Helper for dealing with destructive operations and wildcard usage.
DestructiveOperations(ESLogger, Settings, NodeSettingsService) - Constructor for class org.elasticsearch.action.support.DestructiveOperations
 
detailed() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
True if detailed flag is set, false otherwise.
detailed(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
Set value of the detailed flag.
detailed() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
 
detailed(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
 
detailedErrorsEnabled - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
detailedErrorsEnabled - Variable in class org.elasticsearch.rest.RestChannel
 
detailedErrorsEnabled() - Method in class org.elasticsearch.rest.RestChannel
 
detailedMessage(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
 
detailedMessage(Throwable, boolean, int) - Static method in class org.elasticsearch.ExceptionsHelper
 
detect() - Method in class org.elasticsearch.monitor.jvm.HotThreads
 
detectNoop(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
Should this update attempt to detect if it is a noop?
detectNoop() - Method in class org.elasticsearch.action.update.UpdateRequest
 
determineThreadName(String, String) - Method in class org.elasticsearch.common.netty.NettyUtils.EsThreadNameDeterminer
 
df() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
 
DFRSimilarityProvider - Class in org.elasticsearch.index.similarity
SimilarityProvider for DFRSimilarity.
DFRSimilarityProvider(String, Settings) - Constructor for class org.elasticsearch.index.similarity.DFRSimilarityProvider
 
dfs() - Method in class org.elasticsearch.search.query.QuerySearchRequest
 
DFS_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
 
dfSource(CachedDfSource) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
DfsPhase - Class in org.elasticsearch.search.dfs
 
DfsPhase() - Constructor for class org.elasticsearch.search.dfs.DfsPhase
 
DfsPhaseExecutionException - Exception in org.elasticsearch.search.dfs
 
DfsPhaseExecutionException(SearchContext, String, Throwable) - Constructor for exception org.elasticsearch.search.dfs.DfsPhaseExecutionException
 
dfsResult() - Method in class org.elasticsearch.percolator.PercolateContext
 
dfsResult() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
dfsResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
dfsResult() - Method in class org.elasticsearch.search.internal.SearchContext
 
DfsSearchResult - Class in org.elasticsearch.search.dfs
 
DfsSearchResult() - Constructor for class org.elasticsearch.search.dfs.DfsSearchResult
 
DfsSearchResult(long, SearchShardTarget) - Constructor for class org.elasticsearch.search.dfs.DfsSearchResult
 
DictionaryCompoundWordTokenFilterFactory - Class in org.elasticsearch.index.analysis.compound
Uses the DictionaryCompoundWordTokenFilter to decompound tokens using a dictionary.
DictionaryCompoundWordTokenFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.compound.DictionaryCompoundWordTokenFilterFactory
 
different - Variable in class org.elasticsearch.index.store.Store.RecoveryDiff
Files that exist in both snapshots but their they are not identical
digestToString(long) - Static method in class org.elasticsearch.index.store.Store
Produces a string representation of the given digest value.
DirectCandidateGenerator - Class in org.elasticsearch.search.suggest.phrase
 
DirectCandidateGenerator(DirectSpellChecker, String, SuggestMode, IndexReader, double, int) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
 
DirectCandidateGenerator(DirectSpellChecker, String, SuggestMode, IndexReader, double, int, Analyzer, Analyzer, Terms) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
 
DirectCandidateGenerator(String) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
Sets from what field to fetch the candidate suggestions from.
DirectCandidateGenerator.Candidate - Class in org.elasticsearch.search.suggest.phrase
 
DirectCandidateGenerator.CandidateSet - Class in org.elasticsearch.search.suggest.phrase
 
directMemoryMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
Directories - Class in org.elasticsearch.common.lucene
A set of utilities for Lucene Directory.
directory() - Method in class org.elasticsearch.index.store.Store
 
DirectoryService - Class in org.elasticsearch.index.store
 
DirectoryService(ShardId, Settings) - Constructor for class org.elasticsearch.index.store.DirectoryService
 
DirectoryUtils - Class in org.elasticsearch.index.store
Utils for working with Directory classes.
DirectSpellcheckerSettings - Class in org.elasticsearch.search.suggest
 
DirectSpellcheckerSettings() - Constructor for class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
DISABLE_DYNAMIC_SCRIPTING_DEFAULT - Static variable in class org.elasticsearch.script.ScriptService
 
DISABLE_DYNAMIC_SCRIPTING_SETTING - Static variable in class org.elasticsearch.script.ScriptService
 
DisableAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
Deprecated.
DisableAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
Deprecated.
 
disableConsoleLogging() - Static method in class org.elasticsearch.common.logging.Loggers
 
disableCoord(boolean) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Disables Similarity#coord(int,int) in scoring.
disableCoord(boolean) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
Disables Similarity#coord(int,int) in scoring.
DisabledIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
A field data implementation that forbids loading and will throw an ElasticsearchIllegalStateException if you try to load AtomicFieldData instances.
DisabledIndexFieldData(Index, Settings, FieldMapper.Names, FieldDataType, IndexFieldDataCache) - Constructor for class org.elasticsearch.index.fielddata.plain.DisabledIndexFieldData
 
DisabledIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
 
disableStatePersistence() - Method in class org.elasticsearch.cluster.block.ClusterBlock
Should global state persistence be disabled when this block is present.
disableStatePersistence() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
Returns true if one of the global blocks as its disable state persistence flag set.
disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.local.LocalTransport
 
disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.netty.NettyTransport
 
disconnectFromNode(DiscoveryNode, Channel, String) - Method in class org.elasticsearch.transport.netty.NettyTransport
Disconnects from a node, only if the relevant channel is found to be part of the node channels.
disconnectFromNode(DiscoveryNode) - Method in interface org.elasticsearch.transport.Transport
Disconnected from the given node, if not connected, will do nothing.
disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
 
disconnectFromNodeChannel(Channel, Throwable) - Method in class org.elasticsearch.transport.netty.NettyTransport
Disconnects from a node if a channel is found as part of that nodes channels.
Discovery - Interface in org.elasticsearch.discovery
A pluggable module allowing to implement discovery of other nodes, publishing of the cluster state to all nodes, electing a master of the cluster that raises cluster state change events.
Discovery.AckListener - Interface in org.elasticsearch.discovery
 
DISCOVERY_JOIN_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.membership.MembershipAction
 
DISCOVERY_JOIN_VALIDATE_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.membership.MembershipAction
 
DISCOVERY_LEAVE_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.membership.MembershipAction
 
DISCOVERY_REJOIN_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
 
DISCOVERY_TYPE_KEY - Static variable in class org.elasticsearch.discovery.DiscoveryModule
 
DISCOVERY_ZEN_MINIMUM_MASTER_NODES - Static variable in class org.elasticsearch.discovery.zen.elect.ElectMasterService
 
DiscoveryException - Exception in org.elasticsearch.discovery
 
DiscoveryException(String) - Constructor for exception org.elasticsearch.discovery.DiscoveryException
 
DiscoveryException(String, Throwable) - Constructor for exception org.elasticsearch.discovery.DiscoveryException
 
DiscoveryModule - Class in org.elasticsearch.discovery
 
DiscoveryModule(Settings) - Constructor for class org.elasticsearch.discovery.DiscoveryModule
 
DiscoveryNode - Class in org.elasticsearch.cluster.node
A discovery node represents a node that is part of the cluster.
DiscoveryNode(String, TransportAddress, Version) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
Creates a new DiscoveryNode
DiscoveryNode(String, String, TransportAddress, Map<String, String>, Version) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
Creates a new DiscoveryNode
DiscoveryNode(String, String, String, String, TransportAddress, Map<String, String>, Version) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
Creates a new DiscoveryNode
DiscoveryNodeFilters - Class in org.elasticsearch.cluster.node
 
DiscoveryNodeFilters.OpType - Enum in org.elasticsearch.cluster.node
 
DiscoveryNodes - Class in org.elasticsearch.cluster.node
This class holds all DiscoveryNode in the cluster and provides convenience methods to access, modify merge / diff discovery nodes.
DiscoveryNodes.Builder - Class in org.elasticsearch.cluster.node
 
DiscoveryNodes.Delta - Class in org.elasticsearch.cluster.node
 
DiscoveryNodeService - Class in org.elasticsearch.cluster.node
 
DiscoveryNodeService(Settings) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodeService
 
DiscoveryNodeService.CustomAttributesProvider - Interface in org.elasticsearch.cluster.node
 
DiscoveryNodesProvider - Interface in org.elasticsearch.discovery.zen
 
DiscoveryService - Class in org.elasticsearch.discovery
 
DiscoveryService(Settings, DiscoverySettings, Discovery) - Constructor for class org.elasticsearch.discovery.DiscoveryService
 
DiscoverySettings - Class in org.elasticsearch.discovery
Exposes common discovery settings that may be supported by all the different discovery implementations
DiscoverySettings(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.discovery.DiscoverySettings
 
DiskThresholdDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
The DiskThresholdDecider checks that the node a shard is potentially being allocated to has enough disk space.
DiskThresholdDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
 
DiskThresholdDecider(Settings, NodeSettingsService, ClusterInfoService, Client) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
 
DiskUsage - Class in org.elasticsearch.cluster
Encapsulation class used to represent the amount of disk used on a node.
DiskUsage(String, String, long, long) - Constructor for class org.elasticsearch.cluster.DiskUsage
Create a new DiskUsage, if totalBytes is 0, will always return 100.0% free
dismaxBlendedQuery(Term[], float) - Static method in class org.apache.lucene.queries.BlendedTermQuery
 
dismaxBlendedQuery(Term[], float[], float) - Static method in class org.apache.lucene.queries.BlendedTermQuery
 
disMaxQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that generates the union of documents produced by its sub-queries, and that scores each document with the maximum score for that document as produced by any sub-query, plus a tie breaking increment for any additional matching sub-queries.
DisMaxQueryBuilder - Class in org.elasticsearch.index.query
A query that generates the union of documents produced by its sub-queries, and that scores each document with the maximum score for that document as produced by any sub-query, plus a tie breaking increment for any additional matching sub-queries.
DisMaxQueryBuilder() - Constructor for class org.elasticsearch.index.query.DisMaxQueryBuilder
 
DisMaxQueryParser - Class in org.elasticsearch.index.query
 
DisMaxQueryParser() - Constructor for class org.elasticsearch.index.query.DisMaxQueryParser
 
dispatchRequest(HttpRequest, HttpChannel) - Method in interface org.elasticsearch.http.HttpServerAdapter
 
dispatchRequest(HttpRequest, HttpChannel) - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
dispatchRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.RestController
 
dist(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
 
Distance(double, DistanceUnit) - Constructor for class org.elasticsearch.common.unit.DistanceUnit.Distance
 
distance(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
 
distance(int) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionParser.AbstractDistanceScoreFunction
This function computes the distance from a defined origin.
distance(String) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
distance(double, DistanceUnit) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
distance() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
DISTANCE_ERROR_PCT - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
 
DISTANCE_ERROR_PCT - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
 
distanceBoundingCheck(double, double, double, DistanceUnit) - Static method in enum org.elasticsearch.common.geo.GeoDistance
 
distanceErrorPct(double) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
distanceInKm(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
 
distanceInKmWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
 
distanceInMiles(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
 
distanceInMilesWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
 
distanceType(GeoDistance) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
Set the distance type to use, defaults to GeoDistance#SLOPPY_ARC.
DistanceUnit - Enum in org.elasticsearch.common.unit
The DistanceUnit enumerates several units for measuring distances.
DistanceUnit.Distance - Class in org.elasticsearch.common.unit
This class implements a value+unit tuple.
distanceValues(MultiGeoPointValues, GeoDistance.FixedSourceDistance...) - Static method in enum org.elasticsearch.common.geo.GeoDistance
Return a SortedNumericDoubleValues instance that returns the distances to a list of geo-points for each document.
distanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
 
DISTIBUTOR_KEY - Static variable in class org.elasticsearch.index.store.StoreModule
 
Distributor - Interface in org.elasticsearch.index.store.distributor
Keeps track of available directories and selects a directory based on some distribution strategy
DistributorDirectory - Class in org.elasticsearch.index.store
A directory implementation that uses the Elasticsearch Distributor abstraction to distribute files across multiple data directories.
DistributorDirectory(Directory...) - Constructor for class org.elasticsearch.index.store.DistributorDirectory
Creates a new DistributorDirectory from multiple directories.
DistributorDirectory(Distributor) - Constructor for class org.elasticsearch.index.store.DistributorDirectory
Creates a new DistributorDirectory form the given Distributor.
DJB_HASH(String) - Static method in class org.elasticsearch.cluster.routing.operation.hash.djb.DjbHashFunction
 
DJB_HASH(byte[], int, int) - Static method in class org.elasticsearch.cluster.routing.operation.hash.djb.DjbHashFunction
 
DjbHashFunction - Class in org.elasticsearch.cluster.routing.operation.hash.djb
This class implements the efficient hash function developed by Daniel J.
DjbHashFunction() - Constructor for class org.elasticsearch.cluster.routing.operation.hash.djb.DjbHashFunction
 
DO_NOT_FETCH_SOURCE - Static variable in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
doAny() - Method in class org.elasticsearch.index.store.distributor.AbstractDistributor
 
doAny() - Method in class org.elasticsearch.index.store.distributor.LeastUsedDistributor
 
doAny() - Method in class org.elasticsearch.index.store.distributor.RandomWeightedDistributor
 
doBooleanValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doBooleanValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
doc() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Returns the artificial document from which term vectors are requested for.
doc(XContentBuilder) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Sets an artificial document from which term vectors are requested for.
doc(BytesReference, boolean) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Sets an artificial document from which term vectors are requested for.
doc(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified.
doc(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified.
doc(Map) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified.
doc(Map, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified.
doc(String) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified.
doc(byte[]) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified.
doc(byte[], int, int) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified.
doc(Object...) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified, the doc provided is a field and value pairs.
doc(String, Object) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc to use for updates when a script is not specified.
doc() - Method in class org.elasticsearch.action.update.UpdateRequest
 
doc(String, Settings, RootObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
doc() - Method in class org.elasticsearch.index.mapper.ParseContext
 
doc() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
doc() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
 
doc(XContentBuilder) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
 
doc() - Method in class org.elasticsearch.script.AbstractSearchScript
Returns the doc lookup allowing to access field data (cached) values as well as the current document score (where applicable).
doc(int) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
doc(int, StoredFieldVisitor) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
doc() - Method in class org.elasticsearch.search.lookup.SearchLookup
 
DOC_COUNT - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
 
DOC_COUNT_ERROR_UPPER_BOUND_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
DOC_FIELD_NAME - Static variable in class org.elasticsearch.search.sort.SortParseElement
 
DOC_VALUES - Static variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
DOC_VALUES - Static variable in class org.elasticsearch.index.mapper.core.TypeParsers
 
DOC_VALUES_FORMAT - Static variable in interface org.elasticsearch.index.mapper.FieldMapper
 
DOC_VALUES_FORMAT_SETTINGS_PREFIX - Static variable in interface org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatProvider
 
DOC_VALUES_FORMAT_VALUE - Static variable in class org.elasticsearch.index.fielddata.FieldDataType
 
docAsUpsert() - Method in class org.elasticsearch.action.update.UpdateRequest
 
docAsUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
 
docBoost() - Method in class org.elasticsearch.index.mapper.ParseContext
 
docBoost(float) - Method in class org.elasticsearch.index.mapper.ParseContext
 
docBoost() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
docBoost(float) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
docBuilder() - Static method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
 
DocBuilder() - Constructor for class org.elasticsearch.action.percolate.PercolateSourceBuilder.DocBuilder
 
docCount - Variable in class org.elasticsearch.index.engine.Segment
 
docCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
 
docCount() - Method in class org.elasticsearch.search.lookup.IndexField
 
docCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
 
docCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
docFieldDoubles(String) - Method in class org.elasticsearch.script.AbstractSearchScript
Returns field data double (floating point) access for the provided field.
docFieldLongs(String) - Method in class org.elasticsearch.script.AbstractSearchScript
Returns field data long (integers) access for the provided field.
docFieldStrings(String) - Method in class org.elasticsearch.script.AbstractSearchScript
Returns field data strings access for the provided field.
docFreq() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
doCheckAndNotify() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
Will be called periodically

Implementing watcher should check resource and notify all AbstractResourceWatcher.listeners().

doCheckAndNotify() - Method in class org.elasticsearch.watcher.FileWatcher
 
docID() - Method in class org.elasticsearch.common.lucene.docset.AllDocIdSet.Iterator
 
docID() - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSetIterator
 
docID() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.IteratorBasedIterator
 
docID() - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
docId - Variable in class org.elasticsearch.common.lucene.uid.Versions.DocIdAndVersion
 
docID() - Method in class org.elasticsearch.index.search.child.ConstantScorer
 
docId() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
docId() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
DocIdAndVersion(int, long, AtomicReaderContext) - Constructor for class org.elasticsearch.common.lucene.uid.Versions.DocIdAndVersion
 
docIdAndVersion() - Method in class org.elasticsearch.index.engine.Engine.GetResult
 
docIds() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
 
DocIdSetCollector - Class in org.elasticsearch.search.internal
 
DocIdSetCollector(DocSetCache, Collector) - Constructor for class org.elasticsearch.search.internal.DocIdSetCollector
 
DocIdSets - Class in org.elasticsearch.common.lucene.docset
 
DocIdSets() - Constructor for class org.elasticsearch.common.lucene.docset.DocIdSets
 
docIdsSize() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
 
docIdsToLoad() - Method in class org.elasticsearch.percolator.PercolateContext
 
docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.percolator.PercolateContext
 
docIdsToLoad() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
docIdsToLoad() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
docIdsToLoad() - Method in class org.elasticsearch.search.internal.SearchContext
 
docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.search.internal.SearchContext
 
docIdsToLoad() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
docIdsToLoadFrom() - Method in class org.elasticsearch.percolator.PercolateContext
 
docIdsToLoadFrom() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
docIdsToLoadFrom() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
docIdsToLoadFrom() - Method in class org.elasticsearch.search.internal.SearchContext
 
docIdsToLoadFrom() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
docIdsToLoadSize() - Method in class org.elasticsearch.percolator.PercolateContext
 
docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.SearchContext
 
docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
DocLookup - Class in org.elasticsearch.search.lookup
 
doClose() - Method in class org.elasticsearch.bulk.udp.BulkUdpService
 
doClose() - Method in class org.elasticsearch.cluster.routing.RoutingService
 
doClose() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
doClose() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
doClose() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
Deprecated.
 
doClose() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
 
doClose() - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
doClose() - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
Deprecated.
 
doClose() - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedStreamInput
 
doClose() - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedStreamOutput
 
doClose() - Method in class org.elasticsearch.discovery.DiscoveryService
 
doClose() - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
doClose() - Method in class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
doClose() - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
doClose() - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
 
doClose() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
doClose() - Method in class org.elasticsearch.gateway.GatewayService
 
doClose() - Method in class org.elasticsearch.gateway.local.LocalGateway
 
doClose() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
doClose() - Method in class org.elasticsearch.http.HttpServer
 
doClose() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doClose() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
 
doClose() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doClose() - Method in class org.elasticsearch.indices.IndicesService
 
doClose() - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
 
doClose() - Method in class org.elasticsearch.indices.ttl.IndicesTTLService
 
doClose() - Method in class org.elasticsearch.monitor.jvm.JvmMonitorService
 
doClose() - Method in class org.elasticsearch.monitor.MonitorService
 
doClose() - Method in class org.elasticsearch.percolator.PercolateContext
 
doClose() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
doClose() - Method in class org.elasticsearch.rest.RestController
 
doClose() - Method in class org.elasticsearch.river.cluster.RiverClusterService
 
doClose() - Method in class org.elasticsearch.river.RiversManager
 
doClose() - Method in class org.elasticsearch.river.RiversService
 
doClose() - Method in class org.elasticsearch.river.routing.RiversRouter
 
doClose() - Method in class org.elasticsearch.search.aggregations.Aggregator
Release instance-specific data.
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator.WithHash
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.LowCardinality
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.WithHash
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
 
doClose() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
 
doClose() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
doClose() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
doClose() - Method in class org.elasticsearch.search.internal.SearchContext
 
doClose() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
doClose() - Method in class org.elasticsearch.search.SearchService
 
doClose() - Method in class org.elasticsearch.snapshots.SnapshotsService
 
doClose() - Method in class org.elasticsearch.transport.local.LocalTransport
 
doClose() - Method in class org.elasticsearch.transport.netty.NettyTransport
 
doClose() - Method in class org.elasticsearch.transport.TransportService
 
doClose() - Method in class org.elasticsearch.tribe.TribeService
 
doClose() - Method in class org.elasticsearch.watcher.ResourceWatcherService
 
docMapper() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
docMapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
If the smart name was a typed field, with a type that we resolved, will return the document mapper for it.
docMapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameObjectMapper
 
docMapper() - Method in class org.elasticsearch.index.mapper.MergeContext
 
docMapper() - Method in class org.elasticsearch.index.mapper.ParseContext
 
docMapper() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
docMapperParser() - Method in class org.elasticsearch.index.mapper.ParseContext
 
docMapperParser() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
docMappers(boolean) - Method in class org.elasticsearch.index.mapper.MapperService
returns an immutable iterator over current document mappers.
docOrds(int) - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
Returns a shared LongsRef instance for the given doc ID holding all ordinals associated with it.
docs - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
docs(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
docs() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
docs(Bits, DocsEnum, int) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
docs() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
docs() - Method in class org.elasticsearch.index.mapper.ParseContext
 
docs() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
docs() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
docs(MoreLikeThisQueryBuilder.Item...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
 
docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
docSearcher() - Method in class org.elasticsearch.percolator.PercolateContext
 
docsEnumFlag - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
docSet - Variable in class org.elasticsearch.common.lucene.docset.ContextDocIdSet
 
docSet() - Method in class org.elasticsearch.index.cache.IndexCache
 
DocSetCache - Interface in org.elasticsearch.index.cache.docset
 
docSetCache() - Method in class org.elasticsearch.percolator.PercolateContext
 
docSetCache() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
docSetCache() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
docSetCache() - Method in class org.elasticsearch.search.internal.SearchContext
 
DocSetCacheModule - Class in org.elasticsearch.index.cache.docset
 
DocSetCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.docset.DocSetCacheModule
 
docSets() - Method in class org.elasticsearch.search.internal.DocIdSetCollector
 
docSource() - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
 
DocsStats - Class in org.elasticsearch.index.shard
 
DocsStats() - Constructor for class org.elasticsearch.index.shard.DocsStats
 
DocsStats(long, long) - Constructor for class org.elasticsearch.index.shard.DocsStats
 
DocsStatus - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
DocsStatus() - Constructor for class org.elasticsearch.action.admin.indices.status.DocsStatus
Deprecated.
 
docStats() - Method in class org.elasticsearch.index.shard.IndexShard
 
docsWithValue(SortedBinaryDocValues, int) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns a Bits representing all documents from dv that have a value.
docsWithValue(MultiGeoPointValues, int) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns a Bits representing all documents from dv that have a value.
docsWithValue(SortedNumericDoubleValues, int) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns a Bits representing all documents from dv that have a value.
docsWithValue(int) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes
 
docsWithValue(int) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
 
docsWithValue(int) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
 
docsWithValue(int) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
 
docsWithValue(int) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
 
Document() - Constructor for class org.elasticsearch.index.mapper.ParseContext.Document
 
DOCUMENT_IDS - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
DocumentAlreadyExistsException - Exception in org.elasticsearch.index.engine
 
DocumentAlreadyExistsException(ShardId, String, String) - Constructor for exception org.elasticsearch.index.engine.DocumentAlreadyExistsException
 
DocumentFieldMappers - Class in org.elasticsearch.index.mapper
 
DocumentFieldMappers(DocumentMapper) - Constructor for class org.elasticsearch.index.mapper.DocumentFieldMappers
 
DocumentMapper - Class in org.elasticsearch.index.mapper
 
DocumentMapper(String, Settings, DocumentMapperParser, RootObjectMapper, ImmutableMap<String, Object>, NamedAnalyzer, NamedAnalyzer, NamedAnalyzer, Map<Class<? extends RootMapper>, RootMapper>, List<DocumentMapper.SourceTransform>) - Constructor for class org.elasticsearch.index.mapper.DocumentMapper
 
documentMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
DocumentMapper.Builder - Class in org.elasticsearch.index.mapper
 
DocumentMapper.MergeFlags - Class in org.elasticsearch.index.mapper
 
DocumentMapper.MergeResult - Class in org.elasticsearch.index.mapper
A result of a merge.
DocumentMapper.ParseListener<ParseContext> - Interface in org.elasticsearch.index.mapper
A listener to be called during the parse process.
DocumentMapper.ParseListenerAdapter - Class in org.elasticsearch.index.mapper
 
DocumentMapperParser - Class in org.elasticsearch.index.mapper
 
DocumentMapperParser(Index, Settings, AnalysisService, PostingsFormatService, DocValuesFormatService, SimilarityLookupService, ScriptService) - Constructor for class org.elasticsearch.index.mapper.DocumentMapperParser
 
documentMapperParser() - Method in class org.elasticsearch.index.mapper.MapperService
 
documentMapperWithAutoCreate(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns the document mapper created, including if the document mapper ended up being actually created or not in the second tuple value.
DocumentMissingException - Exception in org.elasticsearch.index.engine
 
DocumentMissingException(ShardId, String, String) - Constructor for exception org.elasticsearch.index.engine.DocumentMissingException
 
DocumentRequest<T> - Interface in org.elasticsearch.action
Generic interface to group ActionRequest, which work on single document level Forces this class return index/type/id getters
DOCUMENTS - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
DocumentSourceMissingException - Exception in org.elasticsearch.index.engine
 
DocumentSourceMissingException(ShardId, String, String) - Constructor for exception org.elasticsearch.index.engine.DocumentSourceMissingException
 
documentType() - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
 
documentType(String) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
Sets the default document type for any percolate request that doesn't have a document type set.
documentType() - Method in class org.elasticsearch.action.percolate.PercolateRequest
documentType(String) - Method in class org.elasticsearch.action.percolate.PercolateRequest
Sets the type of the document to percolate.
documentType() - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
 
DocumentTypeListener - Interface in org.elasticsearch.index.mapper
 
docValues - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
docValues(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
docValues - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
docValuesFormat(DocValuesFormatProvider) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
docValuesFormat - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
docValuesFormat(DocValuesFormatProvider) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper.Builder
 
DocValuesFormatProvider - Interface in org.elasticsearch.index.codec.docvaluesformat
A DocValuesFormatProvider acts as a named container for specific DocValuesFormat implementations.
docValuesFormatProvider() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
docValuesFormatProvider() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
DocValuesFormatProvider.Factory - Interface in org.elasticsearch.index.codec.docvaluesformat
A simple factory used to create DocValuesFormatProvider.
DocValuesFormatProvider.Helper - Class in org.elasticsearch.index.codec.docvaluesformat
A helper class to lookup providers by their unique name
DocValuesFormats - Class in org.elasticsearch.index.codec.docvaluesformat
This class represents the set of Elasticsearch "built-in" doc values format factories
DocValuesFormats() - Constructor for class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormats
 
docValuesFormatService() - Method in class org.elasticsearch.index.codec.CodecService
 
DocValuesFormatService - Class in org.elasticsearch.index.codec.docvaluesformat
The DocValuesFormatService provides access to all configured DocValuesFormatProvider instances by name.
DocValuesFormatService(Index) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatService
 
DocValuesFormatService(Index, Settings) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatService
 
DocValuesFormatService(Index, Settings, Map<String, DocValuesFormatProvider.Factory>) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatService
 
docValuesFormatService() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
 
DocValuesIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
IndexFieldData impl based on Lucene's doc values.
DocValuesIndexFieldData(Index, FieldMapper.Names, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
 
DocValuesIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
 
docValuesProvider - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
doDoubleValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doDoubleValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
doExecute(ActionListener<Response>) - Method in class org.elasticsearch.action.ActionRequestBuilder
 
doExecute(ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
 
doExecute(ActionListener<NodesHotThreadsResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
 
doExecute(ActionListener<NodesInfoResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
 
doExecute(ActionListener<NodesRestartResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequestBuilder
 
doExecute(NodesRestartRequest, ActionListener<NodesRestartResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
doExecute(ActionListener<NodesShutdownResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequestBuilder
 
doExecute(ActionListener<NodesStatsResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
 
doExecute(ActionListener<DeleteRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequestBuilder
 
doExecute(ActionListener<GetRepositoriesResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
 
doExecute(ActionListener<PutRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
 
doExecute(ActionListener<VerifyRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequestBuilder
 
doExecute(ActionListener<ClusterRerouteResponse>) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
 
doExecute(ActionListener<ClusterUpdateSettingsResponse>) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
doExecute(ActionListener<ClusterSearchShardsResponse>) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
 
doExecute(ActionListener<CreateSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
 
doExecute(ActionListener<DeleteSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
 
doExecute(ActionListener<GetSnapshotsResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
 
doExecute(ActionListener<RestoreSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
 
doExecute(ActionListener<SnapshotsStatusResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
 
doExecute(ActionListener<ClusterStateResponse>) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
 
doExecute(ActionListener<ClusterStatsResponse>) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequestBuilder
 
doExecute(ActionListener<PendingClusterTasksResponse>) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequestBuilder
 
doExecute(ActionListener<AliasesExistResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistRequestBuilder
 
doExecute(ActionListener<GetAliasesResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequestBuilder
 
doExecute(ActionListener<IndicesAliasesResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
 
doExecute(ActionListener<AnalyzeResponse>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
 
doExecute(ActionListener<ClearIndicesCacheResponse>) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
doExecute(ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
 
doExecute(CloseIndexRequest, ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
 
doExecute(ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
 
doExecute(ActionListener<DeleteIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
 
doExecute(DeleteIndexRequest, ActionListener<DeleteIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
doExecute(ActionListener<IndicesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
 
doExecute(ActionListener<TypesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
 
doExecute(ActionListener<FlushResponse>) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
 
doExecute(ActionListener<GetIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
 
doExecute(ActionListener<DeleteMappingResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequestBuilder
 
doExecute(DeleteMappingRequest, ActionListener<DeleteMappingResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
doExecute(ActionListener<GetFieldMappingsResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
 
doExecute(ActionListener<GetMappingsResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequestBuilder
 
doExecute(GetFieldMappingsRequest, ActionListener<GetFieldMappingsResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsAction
 
doExecute(ActionListener<PutMappingResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
 
doExecute(ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
 
doExecute(OpenIndexRequest, ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
 
doExecute(ActionListener<OptimizeResponse>) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
 
doExecute(ActionListener<RecoveryResponse>) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequestBuilder
 
doExecute(ActionListener<RefreshResponse>) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
 
doExecute(ActionListener<IndicesSegmentResponse>) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
 
doExecute(ActionListener<GetSettingsResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
 
doExecute(ActionListener<UpdateSettingsResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
 
doExecute(ActionListener<IndicesStatsResponse>) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
doExecute(ActionListener<IndicesStatusResponse>) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
Deprecated.
 
doExecute(ActionListener<DeleteIndexTemplateResponse>) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
 
doExecute(ActionListener<GetIndexTemplatesResponse>) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequestBuilder
 
doExecute(ActionListener<PutIndexTemplateResponse>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
 
doExecute(ValidateQueryRequest, ActionListener<ValidateQueryResponse>) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
doExecute(ActionListener<ValidateQueryResponse>) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
 
doExecute(ActionListener<DeleteWarmerResponse>) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequestBuilder
 
doExecute(ActionListener<GetWarmersResponse>) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequestBuilder
 
doExecute(ActionListener<PutWarmerResponse>) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
 
doExecute(ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
 
doExecute(BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.TransportBulkAction
 
doExecute(ActionListener<CountResponse>) - Method in class org.elasticsearch.action.count.CountRequestBuilder
 
doExecute(CountRequest, ActionListener<CountResponse>) - Method in class org.elasticsearch.action.count.TransportCountAction
 
doExecute(ActionListener<DeleteResponse>) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
 
doExecute(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
doExecute(ActionListener<DeleteByQueryResponse>) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
 
doExecute(DeleteByQueryRequest, ActionListener<DeleteByQueryResponse>) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
doExecute(ActionListener<ExistsResponse>) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
 
doExecute(ExistsRequest, ActionListener<ExistsResponse>) - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
doExecute(ActionListener<ExplainResponse>) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
 
doExecute(ExplainRequest, ActionListener<ExplainResponse>) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
doExecute(ActionListener<GetResponse>) - Method in class org.elasticsearch.action.get.GetRequestBuilder
 
doExecute(ActionListener<MultiGetResponse>) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
 
doExecute(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in class org.elasticsearch.action.get.TransportMultiGetAction
 
doExecute(ActionListener<IndexResponse>) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
 
doExecute(IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
doExecute(ActionListener<DeleteIndexedScriptResponse>) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequestBuilder
 
doExecute(DeleteIndexedScriptRequest, ActionListener<DeleteIndexedScriptResponse>) - Method in class org.elasticsearch.action.indexedscripts.delete.TransportDeleteIndexedScriptAction
 
doExecute(ActionListener<GetIndexedScriptResponse>) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequestBuilder
 
doExecute(GetIndexedScriptRequest, ActionListener<GetIndexedScriptResponse>) - Method in class org.elasticsearch.action.indexedscripts.get.TransportGetIndexedScriptAction
 
doExecute(ActionListener<PutIndexedScriptResponse>) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
 
doExecute(PutIndexedScriptRequest, ActionListener<PutIndexedScriptResponse>) - Method in class org.elasticsearch.action.indexedscripts.put.TransportPutIndexedScriptAction
 
doExecute(ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
 
doExecute(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.mlt.TransportMoreLikeThisAction
 
doExecute(ActionListener<MultiPercolateResponse>) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequestBuilder
 
doExecute(ActionListener<PercolateResponse>) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
 
doExecute(MultiPercolateRequest, ActionListener<MultiPercolateResponse>) - Method in class org.elasticsearch.action.percolate.TransportMultiPercolateAction
 
doExecute(PercolateRequest, ActionListener<PercolateResponse>) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
doExecute(ActionListener<ClearScrollResponse>) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
 
doExecute(ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
 
doExecute(ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
 
doExecute(ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
 
doExecute(ClearScrollRequest, ActionListener<ClearScrollResponse>) - Method in class org.elasticsearch.action.search.TransportClearScrollAction
 
doExecute(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.action.search.TransportMultiSearchAction
 
doExecute(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.TransportSearchAction
 
doExecute(SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.TransportSearchScrollAction
 
doExecute(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchCountAction
 
doExecute(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchDfsQueryAndFetchAction
 
doExecute(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchDfsQueryThenFetchAction
 
doExecute(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchQueryAndFetchAction
 
doExecute(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchQueryThenFetchAction
 
doExecute(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchScanAction
 
doExecute(ActionListener<SuggestResponse>) - Method in class org.elasticsearch.action.suggest.SuggestRequestBuilder
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
doExecute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.TransportAction
 
doExecute(ActionListener<MultiTermVectorsResponse>) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequestBuilder
 
doExecute(ActionListener<TermVectorResponse>) - Method in class org.elasticsearch.action.termvector.TermVectorRequestBuilder
 
doExecute(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in class org.elasticsearch.action.termvector.TransportMultiTermVectorsAction
 
doExecute(TermVectorRequest, ActionListener<TermVectorResponse>) - Method in class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
doExecute(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
doExecute(ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
 
doExecute(Settings, Environment) - Method in class org.elasticsearch.common.cli.CheckFileCommand
abstract method, which should implement the same logic as CliTool.Command.execute(), but is wrapped
doFloatValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doFloatValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
doInit() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
Will be called once on initialization
doInit() - Method in class org.elasticsearch.watcher.FileWatcher
 
doInternalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
 
doInternalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramBuilder
 
doInternalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
 
doInternalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.date.DateRangeBuilder
 
doInternalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
 
doInternalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
 
doInternalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsBuilder
 
doInternalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
 
doIntValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doIntValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
doLongValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doLongValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
doMasterOperation(GetIndexRequest, String[], ClusterState, ActionListener<GetIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
 
doMasterOperation(GetMappingsRequest, String[], ClusterState, ActionListener<GetMappingsResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
 
doMasterOperation(GetWarmersRequest, String[], ClusterState, ActionListener<GetWarmersResponse>) - Method in class org.elasticsearch.action.admin.indices.warmer.get.TransportGetWarmersAction
 
doMasterOperation(Request, String[], ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
 
doMerge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
doMerge(ObjectMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
doMerge(ObjectMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
 
done() - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
 
done() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
 
doPostCollection() - Method in class org.elasticsearch.search.aggregations.Aggregator
Can be overriden by aggregator implementation to be called back when the collection phase ends.
doPostCollection() - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator
 
doPostCollection() - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.LowCardinality
 
doPostCollection() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
doPrint(String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestAllocationAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestCountAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestMasterAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestNodesAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestPluginsAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestRecoveryAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
 
doRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
 
doRun() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
This method has the same semantics as Runnable.run()
doSetDocument(int) - Method in class org.elasticsearch.index.fielddata.AbstractRandomAccessOrds
 
doSetDocument(int) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalMapping
 
doShortValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doShortValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
doSort - Variable in class org.elasticsearch.percolator.PercolateContext
 
doStart() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.AsyncShardOperationAction
Returns true if the action starting to be performed on the primary (or is done).
doStart() - Method in class org.elasticsearch.bulk.udp.BulkUdpService
 
doStart() - Method in class org.elasticsearch.cluster.routing.RoutingService
 
doStart() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
doStart() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
doStart() - Method in class org.elasticsearch.discovery.DiscoveryService
 
doStart() - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
doStart() - Method in class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
doStart() - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
doStart() - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
 
doStart() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
doStart() - Method in class org.elasticsearch.gateway.GatewayService
 
doStart() - Method in class org.elasticsearch.gateway.local.LocalGateway
 
doStart() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
doStart() - Method in class org.elasticsearch.http.HttpServer
 
doStart() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doStart() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
 
doStart() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doStart() - Method in class org.elasticsearch.indices.IndicesService
 
doStart() - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
 
doStart() - Method in class org.elasticsearch.indices.ttl.IndicesTTLService
 
doStart() - Method in class org.elasticsearch.monitor.jvm.JvmMonitorService
 
doStart() - Method in class org.elasticsearch.monitor.MonitorService
 
doStart() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
doStart() - Method in class org.elasticsearch.rest.RestController
 
doStart() - Method in class org.elasticsearch.river.cluster.RiverClusterService
 
doStart() - Method in class org.elasticsearch.river.RiversManager
 
doStart() - Method in class org.elasticsearch.river.RiversService
 
doStart() - Method in class org.elasticsearch.river.routing.RiversRouter
 
doStart() - Method in class org.elasticsearch.search.SearchService
 
doStart() - Method in class org.elasticsearch.snapshots.SnapshotsService
 
doStart() - Method in class org.elasticsearch.transport.local.LocalTransport
 
doStart() - Method in class org.elasticsearch.transport.netty.NettyTransport
 
doStart() - Method in class org.elasticsearch.transport.TransportService
 
doStart() - Method in class org.elasticsearch.tribe.TribeService
 
doStart() - Method in class org.elasticsearch.watcher.ResourceWatcherService
 
doStop() - Method in class org.elasticsearch.bulk.udp.BulkUdpService
 
doStop() - Method in class org.elasticsearch.cluster.routing.RoutingService
 
doStop() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
doStop() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
doStop() - Method in class org.elasticsearch.discovery.DiscoveryService
 
doStop() - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
doStop() - Method in class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
doStop() - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
doStop() - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
 
doStop() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
doStop() - Method in class org.elasticsearch.gateway.GatewayService
 
doStop() - Method in class org.elasticsearch.gateway.local.LocalGateway
 
doStop() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
doStop() - Method in class org.elasticsearch.http.HttpServer
 
doStop() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doStop() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
 
doStop() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doStop() - Method in class org.elasticsearch.indices.IndicesService
 
doStop() - Method in class org.elasticsearch.indices.memory.IndexingMemoryController
 
doStop() - Method in class org.elasticsearch.indices.ttl.IndicesTTLService
 
doStop() - Method in class org.elasticsearch.monitor.jvm.JvmMonitorService
 
doStop() - Method in class org.elasticsearch.monitor.MonitorService
 
doStop() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
doStop() - Method in class org.elasticsearch.rest.RestController
 
doStop() - Method in class org.elasticsearch.river.cluster.RiverClusterService
 
doStop() - Method in class org.elasticsearch.river.RiversManager
 
doStop() - Method in class org.elasticsearch.river.RiversService
 
doStop() - Method in class org.elasticsearch.river.routing.RiversRouter
 
doStop() - Method in class org.elasticsearch.search.SearchService
 
doStop() - Method in class org.elasticsearch.snapshots.SnapshotsService
 
doStop() - Method in class org.elasticsearch.transport.local.LocalTransport
 
doStop() - Method in class org.elasticsearch.transport.netty.NettyTransport
 
doStop() - Method in class org.elasticsearch.transport.TransportService
 
doStop() - Method in class org.elasticsearch.tribe.TribeService
 
doStop() - Method in class org.elasticsearch.watcher.ResourceWatcherService
 
DOUBLE - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
DOUBLE_GTE_2 - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
DoubleAdder - Class in jsr166e
One or more variables that together maintain an initially zero double sum.
DoubleAdder() - Constructor for class jsr166e.DoubleAdder
Creates a new adder with initial sum of zero.
DoubleArray - Interface in org.elasticsearch.common.util
Abstraction of an array of double values.
DoubleArrayIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
DoubleArrayIndexFieldData(Index, Settings, FieldMapper.Names, FieldDataType, IndexFieldDataCache, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.DoubleArrayIndexFieldData
 
DoubleArrayIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
 
DoubleEntry(double, int) - Constructor for class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
DoubleEntry(double, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
DoubleFacetAggregatorBase - Class in org.elasticsearch.search.facet
Simple Facet aggregator base class for DoubleValues
DoubleFacetAggregatorBase() - Constructor for class org.elasticsearch.search.facet.DoubleFacetAggregatorBase
 
doubleField(FieldInfo, double) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
doubleField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
DoubleFieldMapper - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper(FieldMapper.Names, int, float, FieldType, Boolean, Double, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
DoubleFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper.CustomDoubleNumericDocValuesField - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper.CustomDoubleNumericField - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
doubleIntMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
doubleIntMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
DoubleMaxUpdater - Class in jsr166e
One or more variables that together maintain a running double maximum with initial value Double.NEGATIVE_INFINITY.
DoubleMaxUpdater() - Constructor for class jsr166e.DoubleMaxUpdater
Creates a new instance with initial value of Double.NEGATIVE_INFINITY.
doubleObjectMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
doubleObjectMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
Doubles(SortedNumericDoubleValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
 
DoublesFieldDataFilter(IndexNumericFieldData, DoubleOpenHashSet) - Constructor for class org.elasticsearch.index.search.FieldDataTermsFilter.DoublesFieldDataFilter
 
DoubleTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
 
DoubleTerms(String, Terms.Order, ValueFormatter, int, int, long, List<InternalTerms.Bucket>, boolean, long, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
 
DoubleTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
 
DoubleTermsAggregator(String, AggregatorFactories, ValuesSource.Numeric, ValueFormat, long, Terms.Order, TermsAggregator.BucketCountThresholds, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, boolean, IncludeExclude.LongFilter) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.DoubleTermsAggregator
 
doubleToBytes(double) - Static method in class org.elasticsearch.common.Numbers
Converts a double to a byte array.
doubleValue() - Method in class jsr166e.DoubleAdder
Equivalent to sum().
doubleValue() - Method in class jsr166e.DoubleMaxUpdater
Equivalent to DoubleMaxUpdater.max().
doubleValue() - Method in class jsr166e.LongAdder
Returns the LongAdder.sum() as a double after a widening primitive conversion.
doubleValue() - Method in class jsr166e.LongMaxUpdater
Returns the LongMaxUpdater.max() as a double after a widening primitive conversion.
doubleValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
doubleValue(boolean) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
doubleValue(boolean) - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
doubleValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
doubleValue() - Method in class org.elasticsearch.script.ScoreAccessor
 
doubleValue() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
 
doubleValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
Get the current ValuesSource.Numeric.WithScript.DoubleValues.
doubleValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
 
doubleValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
 
doubleValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
 
DoubleValuesComparatorSource - Class in org.elasticsearch.index.fielddata.fieldcomparator
Comparator source for double values.
DoubleValuesComparatorSource(IndexNumericFieldData, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
 
doValidate() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
 
doValidate() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
 
doWithNode(DiscoveryNode, ActionListener<Response>) - Method in interface org.elasticsearch.client.transport.TransportClientNodesService.NodeListenerCallback
 
download(URL, File, HttpDownloadHelper.DownloadProgress, TimeValue) - Method in class org.elasticsearch.common.http.client.HttpDownloadHelper
 
downloadAndExtract(String) - Method in class org.elasticsearch.plugins.PluginManager
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.AndFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BaseFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BaseQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BytesFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.ExistsFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.FilteredQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.factor.FactorBuilder
Deprecated.
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.weight.WeightBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoPolygonFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoShapeFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.HasParentFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.HasParentQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IdsFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IndicesFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IndicesQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.LimitFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchAllFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MissingFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.NestedFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.NotFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.OrFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.PrefixFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.QueryFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.RegexpFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanTermQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TemplateQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermsFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TopChildrenQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TypeFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.WrapperFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
doXContentBody(XContentBuilder, boolean, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
 
doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
 
drain() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
 
drainTo(Collection<? super E>) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
 
drawCandidates(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
 
drawCandidates(DirectCandidateGenerator.CandidateSet) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
 
drawCandidates(DirectCandidateGenerator.CandidateSet) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
 
drawCandidates(DirectCandidateGenerator.CandidateSet) - Method in class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
 
dryRun(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
Sets a dry run flag (defaults to false) allowing to run the commands without actually applying them to the cluster state, and getting the resulting cluster state back.
dryRun() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
Returns the current dry run flag which allows to run the commands without actually applying them, just to get back the resulting cluster state back.
DummyRiver - Class in org.elasticsearch.river.dummy
 
DummyRiver(RiverName, RiverSettings) - Constructor for class org.elasticsearch.river.dummy.DummyRiver
 
DummyRiverModule - Class in org.elasticsearch.river.dummy
 
DummyRiverModule() - Constructor for class org.elasticsearch.river.dummy.DummyRiverModule
 
DummyTransportAddress - Class in org.elasticsearch.common.transport
 
duplicateBindingAnnotations(Member, Class<? extends Annotation>, Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
duplicateScopeAnnotations(Class<? extends Annotation>, Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
duplicateScopes(Scope, Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.common.inject.internal.Errors
 
duration() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
DutchAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
DutchAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.DutchAnalyzerProvider
 
DutchStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
DutchStemTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.DutchStemTokenFilterFactory
 
dynamic - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
dynamic(ObjectMapper.Dynamic) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
DYNAMIC - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Defaults
 
dynamic() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
DYNAMIC_DATE_TIME_FORMATTERS - Static variable in class org.elasticsearch.index.mapper.object.RootObjectMapper.Defaults
 
dynamicDateTimeFormatter(Iterable<FormatDateTimeFormatter>) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
 
dynamicDateTimeFormatters - Variable in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
 
dynamicDateTimeFormatters() - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
 
DynamicSettings - Class in org.elasticsearch.cluster.settings
 
DynamicSettings() - Constructor for class org.elasticsearch.cluster.settings.DynamicSettings
 
DynamicTemplate - Class in org.elasticsearch.index.mapper.object
 
DynamicTemplate(String, Map<String, Object>, String, String, String, String, String, DynamicTemplate.MatchType, Map<String, Object>) - Constructor for class org.elasticsearch.index.mapper.object.DynamicTemplate
 
DynamicTemplate.MatchType - Enum in org.elasticsearch.index.mapper.object
 
dynamicTemplates - Variable in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
 

E

EAGER_GLOBAL_ORDINALS_VALUE - Static variable in enum org.elasticsearch.index.mapper.FieldMapper.Loading
 
EAGER_SINGLETON - Static variable in class org.elasticsearch.common.inject.internal.Scoping
 
EAGER_VALUE - Static variable in enum org.elasticsearch.index.mapper.FieldMapper.Loading
 
EarlyTerminationException(String) - Constructor for exception org.elasticsearch.common.lucene.Lucene.EarlyTerminationException
 
EARTH_AXIS_RATIO - Static variable in class org.elasticsearch.common.geo.GeoUtils
Earth axis ratio defined by WGS 84 (0.996647189335)
EARTH_EQUATOR - Static variable in class org.elasticsearch.common.geo.GeoUtils
Earth ellipsoid equator length in meters
EARTH_MEAN_RADIUS - Static variable in class org.elasticsearch.common.geo.GeoUtils
Earth mean radius defined by WGS 84 in meters
EARTH_POLAR_DISTANCE - Static variable in class org.elasticsearch.common.geo.GeoUtils
Earth ellipsoid polar distance in meters
EARTH_SEMI_MAJOR_AXIS - Static variable in class org.elasticsearch.common.geo.GeoUtils
Earth ellipsoid major axis defined by WGS 84 in meters
EARTH_SEMI_MINOR_AXIS - Static variable in class org.elasticsearch.common.geo.GeoUtils
Earth ellipsoid minor axis defined by WGS 84 in meters
earthDiameter(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
Return an approximate value of the diameter of the earth (in meters) at the given latitude (in radians).
Edge(Coordinate, ShapeBuilder.Edge, Coordinate) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
 
Edge(Coordinate, ShapeBuilder.Edge) - Constructor for class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
 
EdgeNGramTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
EdgeNGramTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.EdgeNGramTokenFilterFactory
 
EdgeNGramTokenizerFactory - Class in org.elasticsearch.index.analysis
 
EdgeNGramTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.EdgeNGramTokenizerFactory
 
Elasticsearch - Class in org.elasticsearch.bootstrap
A wrapper around Bootstrap just so the process will look nicely on things like jps.
Elasticsearch() - Constructor for class org.elasticsearch.bootstrap.Elasticsearch
 
Elasticsearch090PostingsFormat - Class in org.elasticsearch.index.codec.postingsformat
Deprecated.
only for reading old segments
Elasticsearch090PostingsFormat() - Constructor for class org.elasticsearch.index.codec.postingsformat.Elasticsearch090PostingsFormat
Deprecated.
 
ElasticsearchClient<Client extends ElasticsearchClient> - Interface in org.elasticsearch.client
 
ElasticsearchCorruptionException - Exception in org.elasticsearch
This exception is thrown when Elasticsearch detects an inconsistency in one of it's persistent files.
ElasticsearchCorruptionException(String) - Constructor for exception org.elasticsearch.ElasticsearchCorruptionException
ElasticsearchCorruptionException(CorruptIndexException) - Constructor for exception org.elasticsearch.ElasticsearchCorruptionException
Creates a new ElasticsearchCorruptionException with the given exceptions stacktrace.
ElasticsearchException - Exception in org.elasticsearch
A base class for all elasticsearch exceptions.
ElasticsearchException(String) - Constructor for exception org.elasticsearch.ElasticsearchException
Construct a ElasticsearchException with the specified detail message.
ElasticsearchException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticsearchException
Construct a ElasticsearchException with the specified detail message and nested exception.
ElasticsearchException.WithRestHeaders - Exception in org.elasticsearch
A base class for exceptions that should carry rest headers
ElasticsearchF - Class in org.elasticsearch.bootstrap
Same as Elasticsearch just runs it in the foreground by default (does not close sout and serr).
ElasticsearchF() - Constructor for class org.elasticsearch.bootstrap.ElasticsearchF
 
ElasticsearchGenerationException - Exception in org.elasticsearch
A generic exception indicating failure to generate.
ElasticsearchGenerationException(String) - Constructor for exception org.elasticsearch.ElasticsearchGenerationException
 
ElasticsearchGenerationException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticsearchGenerationException
 
ElasticsearchIllegalArgumentException - Exception in org.elasticsearch
 
ElasticsearchIllegalArgumentException() - Constructor for exception org.elasticsearch.ElasticsearchIllegalArgumentException
 
ElasticsearchIllegalArgumentException(String) - Constructor for exception org.elasticsearch.ElasticsearchIllegalArgumentException
 
ElasticsearchIllegalArgumentException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticsearchIllegalArgumentException
 
ElasticsearchIllegalStateException - Exception in org.elasticsearch
 
ElasticsearchIllegalStateException() - Constructor for exception org.elasticsearch.ElasticsearchIllegalStateException
 
ElasticsearchIllegalStateException(String) - Constructor for exception org.elasticsearch.ElasticsearchIllegalStateException
 
ElasticsearchIllegalStateException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticsearchIllegalStateException
 
ElasticsearchMergePolicy - Class in org.elasticsearch.index.merge.policy
A MergePolicy that upgrades segments and can upgrade merges.
ElasticsearchMergePolicy(MergePolicy) - Constructor for class org.elasticsearch.index.merge.policy.ElasticsearchMergePolicy
 
ElasticsearchNullPointerException - Exception in org.elasticsearch
 
ElasticsearchNullPointerException() - Constructor for exception org.elasticsearch.ElasticsearchNullPointerException
 
ElasticsearchNullPointerException(String) - Constructor for exception org.elasticsearch.ElasticsearchNullPointerException
 
ElasticsearchNullPointerException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticsearchNullPointerException
 
ElasticsearchParseException - Exception in org.elasticsearch
 
ElasticsearchParseException(String) - Constructor for exception org.elasticsearch.ElasticsearchParseException
 
ElasticsearchParseException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticsearchParseException
 
ElasticsearchTimeoutException - Exception in org.elasticsearch
The same as TimeoutException simply a runtime one.
ElasticsearchTimeoutException(String) - Constructor for exception org.elasticsearch.ElasticsearchTimeoutException
 
ElasticsearchTimeoutException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticsearchTimeoutException
 
ElasticsearchWrapperException - Interface in org.elasticsearch
 
electMaster(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.elect.ElectMasterService
Elects a new master out of the possible nodes, returning it.
ElectMasterService - Class in org.elasticsearch.discovery.zen.elect
 
ElectMasterService(Settings) - Constructor for class org.elasticsearch.discovery.zen.elect.ElectMasterService
 
Element - Interface in org.elasticsearch.common.inject.spi
A core component of a module or injector.
elements - Variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
Elements - Class in org.elasticsearch.common.inject.spi
Exposes elements of a module so they can be inspected, validated or rewritten.
Elements() - Constructor for class org.elasticsearch.common.inject.spi.Elements
 
ElementVisitor<V> - Interface in org.elasticsearch.common.inject.spi
Visit elements.
ElisionTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
ElisionTokenFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ElisionTokenFilterFactory
 
EMPTY - Static variable in class org.elasticsearch.action.OriginalIndices
 
EMPTY - Static variable in class org.elasticsearch.action.percolate.PercolateResponse
 
EMPTY - Static variable in class org.elasticsearch.client.support.Headers
 
EMPTY - Static variable in interface org.elasticsearch.cluster.ClusterInfoService
 
EMPTY - Static variable in class org.elasticsearch.cluster.metadata.MappingMetaData.Id
 
EMPTY - Static variable in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
 
EMPTY - Static variable in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
EMPTY - Static variable in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
 
EMPTY - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
EMPTY - Static variable in class org.elasticsearch.common.bytes.BytesArray
 
EMPTY - Static variable in class org.elasticsearch.common.settings.ImmutableSettings
 
empty() - Static method in class org.elasticsearch.common.util.concurrent.AtomicArray
 
EMPTY - Static variable in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
empty() - Static method in class org.elasticsearch.index.fielddata.plain.AbstractAtomicOrdinalsFieldData
 
empty() - Static method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields
 
EMPTY - Static variable in interface org.elasticsearch.index.mapper.DocumentMapper.ParseListener
 
EMPTY - Static variable in class org.elasticsearch.index.store.Store.MetadataSnapshot
 
EMPTY - Static variable in interface org.elasticsearch.index.store.Store.OnClose
 
EMPTY - Static variable in class org.elasticsearch.river.routing.RiversRouting
 
EMPTY - Static variable in class org.elasticsearch.search.aggregations.AggregatorFactories
 
EMPTY - Static variable in class org.elasticsearch.search.aggregations.InternalAggregations
 
EMPTY - Static variable in class org.elasticsearch.search.internal.InternalSearchHits
 
empty() - Static method in class org.elasticsearch.search.internal.InternalSearchHits
 
empty() - Static method in class org.elasticsearch.search.internal.InternalSearchResponse
 
EMPTY - Static variable in class org.elasticsearch.search.suggest.phrase.Correction
 
EMPTY - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
 
EMPTY - Static variable in class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker.Result
 
Empty() - Constructor for class org.elasticsearch.transport.TransportRequest.Empty
 
Empty(TransportRequest) - Constructor for class org.elasticsearch.transport.TransportRequest.Empty
 
EMPTY - Static variable in class org.elasticsearch.transport.TransportRequestOptions
 
Empty() - Constructor for class org.elasticsearch.transport.TransportResponse.Empty
 
Empty(TransportResponse) - Constructor for class org.elasticsearch.transport.TransportResponse.Empty
 
EMPTY - Static variable in class org.elasticsearch.transport.TransportResponseOptions
 
EMPTY_ARRAY - Static variable in class org.elasticsearch.action.search.ShardSearchFailure
 
EMPTY_ARRAY - Static variable in class org.elasticsearch.common.Strings
 
EMPTY_ARRAY - Static variable in class org.elasticsearch.common.text.StringAndBytesText
 
EMPTY_ARRAY - Static variable in class org.elasticsearch.common.text.StringText
 
EMPTY_ARRAY - Static variable in interface org.elasticsearch.index.mapper.Mapper
 
EMPTY_CLUSTER_BLOCK - Static variable in class org.elasticsearch.cluster.block.ClusterBlocks
 
EMPTY_CONFIG - Static variable in class org.elasticsearch.search.suggest.context.ContextMapping
Dummy Context Config matching the Dummy Mapping by providing an empty context
EMPTY_CONTEXT - Static variable in class org.elasticsearch.search.suggest.context.ContextMapping
Dummy Context matching the Dummy Mapping by not wrapping a TokenStream
EMPTY_DOCS - Static variable in class org.elasticsearch.search.controller.SearchPhaseController
 
EMPTY_FIELDS - Static variable in class org.elasticsearch.search.highlight.vectorhighlight.SourceSimpleFragmentsBuilder
 
EMPTY_FLAGS - Static variable in class org.elasticsearch.common.ParseField
 
EMPTY_LIST - Static variable in class org.elasticsearch.cluster.node.DiscoveryNode
 
EMPTY_LOAD - Static variable in class org.elasticsearch.monitor.os.OsStats
 
EMPTY_MAPPING - Static variable in class org.elasticsearch.search.suggest.context.ContextMapping
Dummy Context Mapping that should be used if no context is used
EMPTY_META_DATA - Static variable in class org.elasticsearch.cluster.metadata.MetaData
 
EMPTY_MODULE - Static variable in class org.elasticsearch.common.inject.util.Modules
 
EMPTY_NODES - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodes
 
EMPTY_PARAMS - Static variable in interface org.elasticsearch.common.xcontent.ToXContent
 
EMPTY_ROUTING_TABLE - Static variable in class org.elasticsearch.cluster.routing.RoutingTable
 
EMPTY_SCORE_DOCS - Static variable in class org.elasticsearch.common.lucene.Lucene
 
EMPTY_SETTINGS - Static variable in class org.elasticsearch.common.settings.ImmutableSettings.Builder
 
EMPTY_TOP_DOCS - Static variable in class org.elasticsearch.common.lucene.Lucene
 
EMPTY_TYPE_ARRAY - Static variable in class org.elasticsearch.common.inject.internal.MoreTypes
 
EmptyClusterInfoService - Class in org.elasticsearch.cluster
ClusterInfoService that provides empty maps for disk usage and shard sizes
emptyDelta() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
emptyFieldNames() - Method in class org.elasticsearch.percolator.PercolateContext
 
emptyFieldNames() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
emptyFieldNames() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
emptyFieldNames() - Method in class org.elasticsearch.search.internal.SearchContext
 
emptyFieldNames() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
emptyGeoPoint() - Static method in enum org.elasticsearch.index.fielddata.FieldData
 
emptyMultiGeoPoints(int) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Return a SortedNumericDoubleValues that doesn't contain any value.
emptyNumericDouble() - Static method in enum org.elasticsearch.index.fielddata.FieldData
Return a NumericDoubleValues that doesn't contain any value.
EmptyScorer - Class in org.elasticsearch.common.lucene.search
 
EmptyScorer(Weight) - Constructor for class org.elasticsearch.common.lucene.search.EmptyScorer
 
emptySortedBinary(int) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Return a SortedBinaryDocValues that doesn't contain any value.
emptySortedNumericDoubles(int) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Return a SortedNumericDoubleValues that doesn't contain any value.
EmptyTransportResponseHandler - Class in org.elasticsearch.transport
 
EmptyTransportResponseHandler(String) - Constructor for class org.elasticsearch.transport.EmptyTransportResponseHandler
 
ENABLE_GEOHASH - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
ENABLE_GEOHASH_PREFIX - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
ENABLE_LATLON - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
EnableAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
This allocation decider allows shard allocations via the cluster wide settings EnableAllocationDecider.CLUSTER_ROUTING_ALLOCATION_ENABLE and the per index setting EnableAllocationDecider.INDEX_ROUTING_ALLOCATION_ENABLE.
EnableAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
 
EnableAllocationDecider.Allocation - Enum in org.elasticsearch.cluster.routing.allocation.decider
 
enableConsoleLogging() - Static method in class org.elasticsearch.common.logging.Loggers
 
enabled() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
enabled(Terminal.Verbosity) - Method in enum org.elasticsearch.common.cli.Terminal.Verbosity
 
enabled(EnabledAttributeMapper) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Defaults
 
enabled() - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
enabled - Variable in enum org.elasticsearch.index.mapper.internal.EnabledAttributeMapper
 
enabled(boolean) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Builder
 
enabled() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
enabled(EnabledAttributeMapper) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Builder
 
enabled() - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
enabled(EnabledAttributeMapper) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
enabled() - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
enabled(boolean) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
enabled() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
enabled(EnabledAttributeMapper) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
 
enabled() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
enabled(EnabledAttributeMapper) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Builder
 
enabled() - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
enabled - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
enabled(boolean) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Defaults
 
ENABLED_STATE - Static variable in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Defaults
 
ENABLED_STATE - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
ENABLED_STATE - Static variable in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Defaults
 
ENABLED_STATE - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
EnabledAttributeMapper - Enum in org.elasticsearch.index.mapper.internal
 
enabledState - Variable in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
enableGeoHash(boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
enableLatLon(boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
enableMainDocIdSetCollector() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
EnableMergeScheduler - Class in org.elasticsearch.index.merge
A wrapper of another MergeScheduler that allows to explicitly enable merge and disable on a thread local basis.
EnableMergeScheduler(MergeScheduler) - Constructor for class org.elasticsearch.index.merge.EnableMergeScheduler
 
enablePositionIncrements() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
enablePositionIncrements(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
enablePositionIncrements() - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
 
enablePositionIncrements(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Set to true to enable position increments in result query.
enablePositionIncrements - Variable in class org.elasticsearch.index.search.MatchQuery
 
encode(double, double) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
 
encode(double, double, int) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Encodes the given latitude and longitude into a geohash
encode(ChannelHandlerContext, Channel, Object) - Method in class org.elasticsearch.http.netty.ESHttpResponseEncoder
 
encode(double, double, byte[], int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
Encode a geo point into a byte-array, over GeoPointFieldMapper.Encoding.numBytes() bytes.
encode(String, Writer) - Method in class org.elasticsearch.script.mustache.JsonEscapingMustacheFactory
 
encodeAsLong(double, double, int) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Encodes latitude and longitude information into a single long with variable precision.
encodeCoordinate(double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
Return the bits that encode a latitude/longitude.
encoder(String) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
Set encoder for the highlighting are styled and default.
encoder() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
encodeWeight(long) - Static method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
weight -> cost
end() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder.InternalLineStringBuilder
 
end - Variable in class org.elasticsearch.common.io.stream.BytesStreamInput
 
end() - Method in class org.elasticsearch.index.analysis.NumericTokenizer
 
end() - Method in class org.elasticsearch.search.suggest.completion.CompletionTokenStream
 
end() - Method in class org.elasticsearch.search.suggest.SuggestUtils.TokenConsumer
 
END_BYTE - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
Marks end of the analyzed input and start of dedup byte.
endArray() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
endDownload() - Method in interface org.elasticsearch.common.http.client.HttpDownloadHelper.DownloadProgress
end a download
endDownload() - Method in class org.elasticsearch.common.http.client.HttpDownloadHelper.NullProgress
end a download
endDownload() - Method in class org.elasticsearch.common.http.client.HttpDownloadHelper.VerboseProgress
end a download
endHeaders() - Method in class org.elasticsearch.common.Table
 
endObject() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
endOffset - Variable in class org.elasticsearch.search.lookup.TermPosition
 
endRow(boolean) - Method in class org.elasticsearch.common.Table
 
endRow() - Method in class org.elasticsearch.common.Table
 
endTime(long) - Method in class org.elasticsearch.index.engine.Engine.Delete
 
endTime() - Method in class org.elasticsearch.index.engine.Engine.Delete
Returns operation end time in nanoseconds.
endTime(long) - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
endTime() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
Returns operation end time in nanoseconds.
endTime(long) - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
endTime() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
Returns operation end time in nanoseconds.
endTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
endTime(long) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets snapshot end time
endTime() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns time when snapshot ended

Can be 0L if snapshot is still running

endTime() - Method in interface org.elasticsearch.snapshots.Snapshot
Returns time when snapshot ended

Can be 0L if snapshot is still running

endTime() - Method in class org.elasticsearch.snapshots.SnapshotInfo
Returns time when snapshot ended

Can be 0L if snapshot is still running

endVerification(String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
 
endVerification(String) - Method in interface org.elasticsearch.repositories.Repository
Called at the end of repository verification process.
endVerification(String) - Method in class org.elasticsearch.repositories.uri.URLRepository
 
Engine - Class in org.elasticsearch.index.engine
 
Engine(EngineConfig) - Constructor for class org.elasticsearch.index.engine.Engine
 
engine() - Method in class org.elasticsearch.index.shard.IndexShard
 
Engine.Create - Class in org.elasticsearch.index.engine
 
Engine.Delete - Class in org.elasticsearch.index.engine
 
Engine.DeleteByQuery - Class in org.elasticsearch.index.engine
 
Engine.FailedEngineListener - Interface in org.elasticsearch.index.engine
 
Engine.Get - Class in org.elasticsearch.index.engine
 
Engine.GetResult - Class in org.elasticsearch.index.engine
 
Engine.Index - Class in org.elasticsearch.index.engine
 
Engine.IndexingOperation - Class in org.elasticsearch.index.engine
 
Engine.IndexThrottle - Class in org.elasticsearch.index.engine
A throttling class that can be activated, causing the acquireThrottle method to block on a lock when throttling is enabled
Engine.NoOpLock - Class in org.elasticsearch.index.engine
A Lock implementation that always allows the lock to be acquired
Engine.Operation - Interface in org.elasticsearch.index.engine
 
Engine.Operation.Origin - Enum in org.elasticsearch.index.engine
 
Engine.Operation.Type - Enum in org.elasticsearch.index.engine
 
Engine.RecoveryHandler - Interface in org.elasticsearch.index.engine
Recovery allow to start the recovery process.
Engine.Searcher - Class in org.elasticsearch.index.engine
 
ENGINE_FACTORY - Static variable in class org.elasticsearch.index.shard.IndexShardModule
 
EngineAlreadyStartedException - Exception in org.elasticsearch.index.engine
 
EngineAlreadyStartedException(ShardId) - Constructor for exception org.elasticsearch.index.engine.EngineAlreadyStartedException
 
EngineClosedException - Exception in org.elasticsearch.index.engine
An engine is already closed.
EngineClosedException(ShardId) - Constructor for exception org.elasticsearch.index.engine.EngineClosedException
 
EngineClosedException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.EngineClosedException
 
engineConfig - Variable in class org.elasticsearch.index.engine.Engine
 
EngineConfig - Class in org.elasticsearch.index.engine
 
EngineConfig(ShardId, boolean, ThreadPool, ShardIndexingService, IndexSettingsService, IndicesWarmer, Store, SnapshotDeletionPolicy, Translog, MergePolicyProvider, MergeSchedulerProvider, Analyzer, Similarity, CodecService, Engine.FailedEngineListener) - Constructor for class org.elasticsearch.index.engine.EngineConfig
Creates a new EngineConfig
EngineCreationFailureException - Exception in org.elasticsearch.index.engine
An exception indicating that an Engine creation failed.
EngineCreationFailureException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.EngineCreationFailureException
 
EngineException - Exception in org.elasticsearch.index.engine
 
EngineException(ShardId, String) - Constructor for exception org.elasticsearch.index.engine.EngineException
 
EngineException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.EngineException
 
EngineFactory - Interface in org.elasticsearch.index.engine
Simple Engine Factory
engineFactory - Variable in class org.elasticsearch.index.shard.IndexShard
 
EngineSearcher - Class in org.elasticsearch.index.engine
Searcher for an Engine
EngineSearcher(String, IndexSearcher, SearcherManager, Store, ESLogger) - Constructor for class org.elasticsearch.index.engine.EngineSearcher
 
EngineSearcherFactory - Class in org.elasticsearch.index.engine
Basic Searcher factory that allows returning an IndexSearcher given an IndexReader
EngineSearcherFactory(EngineConfig) - Constructor for class org.elasticsearch.index.engine.EngineSearcherFactory
 
EngineSettings() - Constructor for class org.elasticsearch.index.engine.IndexEngineModule.EngineSettings
 
engineUnsafe() - Method in class org.elasticsearch.index.shard.IndexShard
 
EnglishAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
EnglishAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.EnglishAnalyzerProvider
 
ENOMEM - Static variable in class org.elasticsearch.common.jna.CLibrary
 
ensureAtomicMoveSupported() - Method in class org.elasticsearch.env.NodeEnvironment
This method tries to write an empty file and moves it using an atomic move operation.
ensureNoNullKeys(int) - Static method in class org.elasticsearch.common.collect.HppcMaps
Wraps the given map and prevent adding of null keys.
ensureNoNullKeys(int, float) - Static method in class org.elasticsearch.common.collect.HppcMaps.Object.Integer
 
ensureNotDeleteByQuery(String, QueryParseContext) - Static method in class org.elasticsearch.index.query.QueryParserUtils
Ensures that the query parsing wasn't invoked via the delete by query api.
ensureOpen() - Method in class org.elasticsearch.action.bulk.BulkProcessor
 
ensureOpen() - Method in class org.elasticsearch.index.engine.Engine
 
ensureScoreDocsInOrder() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
ensureValidity() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
entries() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData
Returns list of currently running restore processes
entries() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData
 
entries() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
entries - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetExecutor.Aggregator
 
entries() - Method in class org.elasticsearch.search.facet.SearchContextFacets
 
entries - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
 
entries() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData
 
EntriesStats(long, long) - Constructor for class org.elasticsearch.index.cache.filter.FilterCache.EntriesStats
 
Entry(SnapshotId, RestoreMetaData.State, ImmutableList<String>, ImmutableMap<ShardId, RestoreMetaData.ShardRestoreStatus>) - Constructor for class org.elasticsearch.cluster.metadata.RestoreMetaData.Entry
Creates new restore metadata
Entry(SnapshotId, boolean, SnapshotMetaData.State, ImmutableList<String>, ImmutableMap<ShardId, SnapshotMetaData.ShardSnapshotStatus>) - Constructor for class org.elasticsearch.cluster.metadata.SnapshotMetaData.Entry
 
Entry(String, FastStringReader, int, float) - Constructor for class org.elasticsearch.common.lucene.all.AllEntries.Entry
 
Entry(int, E) - Constructor for class org.elasticsearch.common.util.concurrent.AtomicArray.Entry
 
Entry(double, double, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
Entry(String, FacetExecutor.Mode, FacetExecutor, boolean, Filter) - Constructor for class org.elasticsearch.search.facet.SearchContextFacets.Entry
 
Entry(Text, int, int) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry
 
Entry() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry
 
Entry(Text, int, int, double) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
 
Entry() - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
 
Entry(Text, int, int) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
Entry() - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
Entry(String, String[], Boolean, BytesReference) - Constructor for class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
 
EntryPriorityQueue - Class in org.elasticsearch.search.facet.terms.support
 
EntryPriorityQueue(int, Comparator<TermsFacet.Entry>) - Constructor for class org.elasticsearch.search.facet.terms.support.EntryPriorityQueue
 
entrySet() - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
 
entrySet() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
entrySet() - Method in class org.elasticsearch.common.util.MinimalMap
 
entrySet() - Method in class org.elasticsearch.search.lookup.DocLookup
 
entrySet() - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
entrySet() - Method in class org.elasticsearch.search.lookup.SourceLookup
 
env - Variable in class org.elasticsearch.common.cli.CliTool
 
envelope(EnvelopeBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
 
EnvelopeBuilder - Class in org.elasticsearch.common.geo.builders
 
EnvelopeBuilder() - Constructor for class org.elasticsearch.common.geo.builders.EnvelopeBuilder
 
EnvelopeBuilder(ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.EnvelopeBuilder
 
Environment - Class in org.elasticsearch.env
The environment of where things exists.
Environment() - Constructor for class org.elasticsearch.env.Environment
 
Environment(Settings) - Constructor for class org.elasticsearch.env.Environment
 
EnvironmentModule - Class in org.elasticsearch.env
 
EnvironmentModule(Environment) - Constructor for class org.elasticsearch.env.EnvironmentModule
 
equals(Object) - Method in class org.apache.lucene.queries.BlendedTermQuery
 
equals(Object) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
equals(Object) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmVersion
 
equals(Object) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
 
equals(Object) - Method in class org.elasticsearch.action.GenericAction
 
equals(Object) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
 
equals(Object) - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
equals(Object) - Method in class org.elasticsearch.cluster.ClusterName
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Id
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Entry
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.SnapshotId
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Entry
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData
 
equals(Object) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
equals(Object) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
equals(Object) - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
equals(Object) - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
 
equals(Object) - Method in class org.elasticsearch.cluster.routing.RestoreSource
 
equals(Object) - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
equals(Object) - Method in class org.elasticsearch.common.bytes.BytesArray
 
equals(Object) - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
 
equals(Object) - Method in class org.elasticsearch.common.bytes.HashedBytesArray
 
equals(Object) - Method in class org.elasticsearch.common.bytes.PagedBytesReference
 
equals(Object) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
 
equals(Object) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
equals(Object) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
 
equals(Object) - Method in class org.elasticsearch.common.collect.Tuple
 
equals(Object) - Method in class org.elasticsearch.common.compress.CompressedString
 
equals(Object) - Method in class org.elasticsearch.common.geo.GeoPoint
 
equals(Type, Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
Returns true if a and b are equal.
equals(Object) - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
 
equals(Object) - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
 
equals(Object) - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
 
equals(Object) - Method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
 
equals(Object) - Method in class org.elasticsearch.common.inject.Key
 
equals(Object) - Method in class org.elasticsearch.common.inject.spi.Dependency
 
equals(Object) - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
 
equals(Object) - Method in class org.elasticsearch.common.inject.spi.Message
 
equals(Object) - Method in class org.elasticsearch.common.inject.TypeLiteral
 
equals(Object) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
 
equals(Object) - Method in class org.elasticsearch.common.lucene.HashedBytesRef
 
equals(Object) - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.ApplyAcceptedDocsFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.MatchAllDocsFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsQuery
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
Returns true if o is equal to this.
equals(Object) - Method in class org.elasticsearch.common.lucene.search.NotFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.OrFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.RegexpFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.elasticsearch.common.network.MulticastChannel.Config
 
equals(Object) - Method in class org.elasticsearch.common.Priority
 
equals(Object) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
equals(Object) - Method in class org.elasticsearch.common.text.BytesText
 
equals(Object) - Method in class org.elasticsearch.common.text.StringAndBytesText
 
equals(Object) - Method in class org.elasticsearch.common.text.StringText
 
equals(Object) - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
equals(Object) - Method in class org.elasticsearch.common.transport.LocalTransportAddress
 
equals(Object) - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
equals(Object) - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
 
equals(Object) - Method in class org.elasticsearch.common.unit.SizeValue
 
equals(Object) - Method in class org.elasticsearch.common.unit.TimeValue
 
equals(ByteArray, ByteArray) - Method in class org.elasticsearch.common.util.BigArrays
 
equals(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
equals(Object) - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
equals(Object) - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
equals(Object) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
equals(Object) - Method in class org.elasticsearch.index.engine.Segment
 
equals(Object) - Method in class org.elasticsearch.index.fielddata.FieldDataType
 
equals(Object) - Method in class org.elasticsearch.index.Index
 
equals(Object) - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
 
equals(Object) - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
equals(Object) - Method in class org.elasticsearch.index.mapper.Uid
 
equals(Object) - Method in class org.elasticsearch.index.query.ScriptFilterParser.ScriptFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
 
equals(Object) - Method in class org.elasticsearch.index.search.child.ChildrenQuery
 
equals(Object) - Method in class org.elasticsearch.index.search.child.CustomQueryWrappingFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
 
equals(Object) - Method in class org.elasticsearch.index.search.child.ParentQuery
 
equals(Object) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
equals(Object) - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.BytesFieldDataFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.DoublesFieldDataFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.FieldDataTermsFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.LongsFieldDataFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
 
equals(Object) - Method in class org.elasticsearch.index.search.nested.NonNestedDocsFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
equals(Object) - Method in class org.elasticsearch.index.shard.ShardId
 
equals(Object) - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache.Key
 
equals(Object) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
 
equals(Object) - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
 
equals(Object) - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
equals(Object) - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
equals(Object) - Method in class org.elasticsearch.repositories.RepositoryName
 
equals(Object) - Method in class org.elasticsearch.river.RiverName
 
equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
 
equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
 
equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
 
equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
 
equals(Object) - Method in class org.elasticsearch.search.aggregations.support.OrderPath.Token
 
equals(Object) - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
equals(Object) - Method in class org.elasticsearch.search.SearchShardTarget
 
equals(Object) - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
 
equals(Object) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
 
equals(Object) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
 
equals(Object) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
equals(Object) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
 
equals(Object) - Method in class org.elasticsearch.Version
 
error() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response.Item
 
error(String, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
Logs an ERROR level message.
error(String, Throwable, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
Logs an ERROR level message.
error(String, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
 
error(String, Throwable, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
 
error(String) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
error(String, Throwable) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
ErrorHandler - Interface in org.elasticsearch.common.inject.internal
Handles errors in the Injector.
errorInjectingConstructor(Throwable) - Method in class org.elasticsearch.common.inject.internal.Errors
 
errorInjectingMethod(Throwable) - Method in class org.elasticsearch.common.inject.internal.Errors
 
errorInProvider(RuntimeException) - Method in class org.elasticsearch.common.inject.internal.Errors
 
errorInUserCode(Throwable, String, Object...) - Method in class org.elasticsearch.common.inject.internal.Errors
 
errorInUserInjector(MembersInjector<?>, TypeLiteral<?>, RuntimeException) - Method in class org.elasticsearch.common.inject.internal.Errors
 
errorMessage() - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse.Item
 
errorNotifyingInjectionListener(InjectionListener<?>, TypeLiteral<?>, RuntimeException) - Method in class org.elasticsearch.common.inject.internal.Errors
 
errorNotifyingTypeListener(TypeListenerBinding, TypeLiteral<?>, Throwable) - Method in class org.elasticsearch.common.inject.internal.Errors
 
Errors - Class in org.elasticsearch.common.inject.internal
A collection of error messages.
Errors() - Constructor for class org.elasticsearch.common.inject.internal.Errors
 
Errors(Object) - Constructor for class org.elasticsearch.common.inject.internal.Errors
 
ErrorsException - Exception in org.elasticsearch.common.inject.internal
Indicates that a result could not be returned while preparing or resolving a binding.
ErrorsException(Errors) - Constructor for exception org.elasticsearch.common.inject.internal.ErrorsException
 
ES_PLUGIN_PROPERTIES - Static variable in class org.elasticsearch.plugins.PluginsService
 
ES_PLUGIN_PROPERTIES_FILE_KEY - Static variable in class org.elasticsearch.plugins.PluginsService
 
EsAbortPolicy - Class in org.elasticsearch.common.util.concurrent
 
EsAbortPolicy() - Constructor for class org.elasticsearch.common.util.concurrent.EsAbortPolicy
 
escape() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
escape(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
escape(String, Writer) - Static method in class org.elasticsearch.script.mustache.JsonEscapingMustacheFactory
 
escapedTags() - Method in class org.elasticsearch.index.analysis.HtmlStripCharFilterFactory
 
EsExecutors - Class in org.elasticsearch.common.util.concurrent
 
ESHttpContentDecompressor - Class in org.elasticsearch.http.netty
 
ESHttpContentDecompressor(boolean) - Constructor for class org.elasticsearch.http.netty.ESHttpContentDecompressor
 
ESHttpResponseEncoder - Class in org.elasticsearch.http.netty
Wraps a netty HttpResponseEncoder and makes sure that if the resulting channel buffer is composite, it will use the correct gathering flag.
ESHttpResponseEncoder() - Constructor for class org.elasticsearch.http.netty.ESHttpResponseEncoder
 
ESLogger - Interface in org.elasticsearch.common.logging
Contract for all elasticsearch loggers.
ESLoggerFactory - Class in org.elasticsearch.common.logging
Factory to get ESLoggers
ESLoggerFactory() - Constructor for class org.elasticsearch.common.logging.ESLoggerFactory
 
ESLogRecord - Class in org.elasticsearch.common.logging.jdk
A LogRecord which is used in conjunction with JdkESLogger with the ability to provide the class name, method name and line number information of the code calling the logger
ESLogRecord(Level, String) - Constructor for class org.elasticsearch.common.logging.jdk.ESLogRecord
 
EsRejectedExecutionException - Exception in org.elasticsearch.common.util.concurrent
 
EsRejectedExecutionException(String) - Constructor for exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
 
EsRejectedExecutionException() - Constructor for exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
 
EsRejectedExecutionException(Throwable) - Constructor for exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
 
estabResets() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
EsThreadNameDeterminer() - Constructor for class org.elasticsearch.common.netty.NettyUtils.EsThreadNameDeterminer
 
EsThreadPoolExecutor - Class in org.elasticsearch.common.util.concurrent
An extension to thread pool executor, allowing (in the future) to add specific additional stats to it.
EsThreadPoolExecutor.ShutdownListener - Interface in org.elasticsearch.common.util.concurrent
 
estimatedBucketCount - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
estimatedBucketCount() - Method in class org.elasticsearch.search.aggregations.Aggregator
Return the estimated number of buckets.
estimatedBucketCount(ValuesSource, Aggregator) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
 
estimatedNumberOfOperations() - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
estimatedNumberOfOperations() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
estimatedNumberOfOperations() - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
estimatedNumberOfOperations() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
estimatedNumberOfOperations() - Method in interface org.elasticsearch.index.translog.Translog
Returns the number of operations in the transaction log.
estimatedNumberOfOperations() - Method in class org.elasticsearch.index.translog.TranslogStats
 
estimatedNumberType() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
estimatedNumberType() - Method in interface org.elasticsearch.common.xcontent.XContentParser
Is the number type estimated or not (i.e.
estimatedSizeInBytes() - Method in class org.elasticsearch.action.bulk.BulkRequest
The estimated size in bytes of the bulk request.
estimatedTimeInMillis() - Method in class org.elasticsearch.threadpool.ThreadPool
 
estimatedTimeInMillisCounter() - Method in class org.elasticsearch.threadpool.ThreadPool
 
estimatedTotalOperations() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
estimatedTotalOperations() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
The total number of operations in the translog.
estimateSize(Directory) - Static method in class org.elasticsearch.common.lucene.Directories
Returns the estimated size of a Directory.
estimateSize() - Method in class org.elasticsearch.index.translog.Translog.Create
 
estimateSize() - Method in class org.elasticsearch.index.translog.Translog.Delete
 
estimateSize() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
estimateSize() - Method in class org.elasticsearch.index.translog.Translog.Index
 
estimateSize() - Method in interface org.elasticsearch.index.translog.Translog.Operation
 
estimateStringFieldData() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
 
esVersion - Variable in class org.elasticsearch.index.analysis.EdgeNGramTokenizerFactory
 
evaluate(double, double) - Method in interface org.elasticsearch.index.query.functionscore.DecayFunction
 
EVEN_SHARD_COUNT_ALLOCATOR_KEY - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
EvenShardsCountAllocator - Class in org.elasticsearch.cluster.routing.allocation.allocator
A ShardsAllocator that tries to balance shards across nodes in the cluster such that each node holds approximatly the same number of shards.
EvenShardsCountAllocator(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
EventPredicate() - Constructor for class org.elasticsearch.cluster.ClusterStateObserver.EventPredicate
 
EWMA - Class in org.elasticsearch.common.metrics
An exponentially-weighted moving average.
EWMA(double, long, TimeUnit) - Constructor for class org.elasticsearch.common.metrics.EWMA
Create a new EWMA with a specific smoothing constant.
EXACT_FIRST - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
Include this flag in the options parameter to #XAnalyzingSuggester(Analyzer,Analyzer,int,int,int,boolean,FST,boolean,int,int,int,int,int) to always return the exact match first, regardless of score.
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.elasticsearch.http.netty.HttpRequestHandler
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.elasticsearch.transport.netty.MessageChannelHandler
 
ExceptionsHelper - Class in org.elasticsearch
 
ExceptionsHelper() - Constructor for class org.elasticsearch.ExceptionsHelper
 
EXCLUDE - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
exclude(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
 
exclude(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
Define a regular expression that will filter out terms that should be excluded from the aggregation.
exclude(String, int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
Define a regular expression that will filter out terms that should be excluded from the aggregation.
exclude(String[]) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
Define a set of terms that should not be aggregated.
exclude(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
Define a set of terms that should not be aggregated.
exclude(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
Define a regular expression that will filter out terms that should be excluded from the aggregation.
exclude(String, int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
Define a regular expression that will filter out terms that should be excluded from the aggregation.
exclude(String[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
Define a set of terms that should not be aggregated.
exclude(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
Define a set of terms that should not be aggregated.
exclude(double[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
Define a set of terms that should not be aggregated.
exclude(Object...) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
A set of terms that will be excluded.
excludeFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
excludes(String[]) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
 
excludes() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
excludes() - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsContext.PartialField
 
excludes() - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
excludes(String[]) - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
executable(Object, Map<String, Object>) - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
executable(Object, Map<String, Object>) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
executable(Object, Map<String, Object>) - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
 
executable(Object, Map<String, Object>) - Method in class org.elasticsearch.script.NativeScriptEngineService
 
executable(Object, Map<String, Object>) - Method in interface org.elasticsearch.script.ScriptEngineService
 
executable(String, String, ScriptService.ScriptType, Map<String, Object>) - Method in class org.elasticsearch.script.ScriptService
Compiles (or retrieves from cache) and executes the provided script
executable(CompiledScript, Map<String, Object>) - Method in class org.elasticsearch.script.ScriptService
Executes a previously compiled script provided as an argument
ExecutableScript - Interface in org.elasticsearch.script
An executable script, can't be used concurrently.
execute() - Method in class org.elasticsearch.action.ActionRequestBuilder
 
execute(ActionListener<Response>) - Method in class org.elasticsearch.action.ActionRequestBuilder
 
execute(SearchScrollRequest, ParsedScrollId, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchScrollQueryAndFetchAction
 
execute(SearchScrollRequest, ParsedScrollId, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchScrollQueryThenFetchAction
 
execute(SearchScrollRequest, ParsedScrollId, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.type.TransportSearchScrollScanAction
 
execute(Request) - Method in class org.elasticsearch.action.support.TransportAction
 
execute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.TransportAction
 
execute(DiscoveryNode, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.TransportActionNodeProxy
 
execute(Action<Request, Response, RequestBuilder, Client>, Request) - Method in interface org.elasticsearch.client.ElasticsearchClient
Executes a generic action, denoted by an Action.
execute(Action<Request, Response, RequestBuilder, Client>, Request, ActionListener<Response>) - Method in interface org.elasticsearch.client.ElasticsearchClient
Executes a generic action, denoted by an Action.
execute(Action<Request, Response, RequestBuilder, ClusterAdminClient>, Request) - Method in class org.elasticsearch.client.FilterClient.ClusterAdmin
 
execute(Action<Request, Response, RequestBuilder, ClusterAdminClient>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.FilterClient.ClusterAdmin
 
execute(Action<Request, Response, RequestBuilder, Client>, Request) - Method in class org.elasticsearch.client.FilterClient
 
execute(Action<Request, Response, RequestBuilder, Client>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.FilterClient
 
execute(Action<Request, Response, RequestBuilder, IndicesAdminClient>, Request) - Method in class org.elasticsearch.client.FilterClient.IndicesAdmin
 
execute(Action<Request, Response, RequestBuilder, IndicesAdminClient>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.FilterClient.IndicesAdmin
 
execute(Action<Request, Response, RequestBuilder, Client>, Request) - Method in class org.elasticsearch.client.node.NodeClient
 
execute(Action<Request, Response, RequestBuilder, Client>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeClient
 
execute(Action<Request, Response, RequestBuilder, ClusterAdminClient>, Request) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
execute(Action<Request, Response, RequestBuilder, ClusterAdminClient>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
execute(Action<Request, Response, RequestBuilder, IndicesAdminClient>, Request) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
execute(Action<Request, Response, RequestBuilder, IndicesAdminClient>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
execute(Action<Request, Response, RequestBuilder, Client>, Request) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
execute(Action<Request, Response, RequestBuilder, Client>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
execute(Action<Request, Response, RequestBuilder, ClusterAdminClient>, Request) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
execute(Action<Request, Response, RequestBuilder, ClusterAdminClient>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
execute(Action<Request, Response, RequestBuilder, IndicesAdminClient>, Request) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
execute(Action<Request, Response, RequestBuilder, IndicesAdminClient>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
execute(Action<Request, Response, RequestBuilder, Client>, Request) - Method in class org.elasticsearch.client.transport.TransportClient
 
execute(Action<Request, Response, RequestBuilder, Client>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.TransportClient
 
execute(TransportClientNodesService.NodeListenerCallback<Response>, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
execute(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
Update the cluster state based on the current state.
execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand
 
execute(RoutingAllocation, boolean) - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
Executes the command on a RoutingAllocation setup
execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
Executes all wrapped commands on a given RoutingAllocation
execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
 
execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
 
execute(Settings, Environment) - Method in class org.elasticsearch.common.cli.CheckFileCommand
 
execute(Settings, Environment) - Method in class org.elasticsearch.common.cli.CliTool.Command
 
execute(Settings, Environment) - Method in class org.elasticsearch.common.cli.CliTool.Command.Exit
 
execute(Settings, Environment) - Method in class org.elasticsearch.common.cli.CliTool.Command.Help
 
execute(String...) - Method in class org.elasticsearch.common.cli.CliTool
 
execute(CancellableThreads.Interruptable) - Method in class org.elasticsearch.common.util.CancellableThreads
run the Interruptable, capturing the executing thread.
execute(Runnable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
 
execute(Runnable, ScheduledExecutorService, TimeValue, Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
 
execute(Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
 
execute(RiverClusterState) - Method in interface org.elasticsearch.river.cluster.RiverClusterStateUpdateTask
 
execute(Object, Map<String, Object>) - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
execute(Object, Map<String, Object>) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
execute(Object, Map<String, Object>) - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
Execute a compiled template object (as retrieved from the compile method) and fill potential place holders with the variables given.
execute(Object, Map<String, Object>) - Method in class org.elasticsearch.script.NativeScriptEngineService
 
execute(Object, Map<String, Object>) - Method in interface org.elasticsearch.script.ScriptEngineService
 
execute(SearchContext) - Method in class org.elasticsearch.search.aggregations.AggregationPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.dfs.DfsPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.facet.FacetPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.fetch.FetchPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.query.QueryPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.rescore.RescorePhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.scan.ScanContext
 
execute(SearchContext) - Method in interface org.elasticsearch.search.SearchPhase
 
execute(String, T, IndexReader, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.Suggester
 
execute(SearchContext) - Method in class org.elasticsearch.search.suggest.SuggestPhase
 
execute(SuggestionSearchContext, IndexReader) - Method in class org.elasticsearch.search.suggest.SuggestPhase
 
executeBulk(BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.TransportBulkAction
This method executes the BulkRequest and calls the given listener once the request returns.
executeDfsPhase(ShardSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeFetchPhase(ShardSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeFetchPhase(QuerySearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeFetchPhase(InternalScrollSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeFetchPhase(ShardFetchRequest) - Method in class org.elasticsearch.search.SearchService
 
executePost(List<ContextDocIdSet>) - Method in class org.elasticsearch.search.facet.FacetExecutor.Post.Collector
 
executePost(List<ContextDocIdSet>) - Method in class org.elasticsearch.search.facet.FacetExecutor.Post
 
executePost(List<ContextDocIdSet>) - Method in class org.elasticsearch.search.facet.FacetExecutor.Post.Filtered
 
executePost(List<ContextDocIdSet>) - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Post
 
executeQueryPhase(ShardSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeQueryPhase(InternalScrollSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeQueryPhase(QuerySearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeScan(ShardSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeScan(InternalScrollSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executing - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
 
execution(String) - Method in class org.elasticsearch.index.query.TermsFilterBuilder
Sets the execution mode for the terms filter.
EXECUTION_HINT_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
 
EXECUTION_KEY - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
EXECUTION_VALUE_AND - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
EXECUTION_VALUE_AND_NOCACHE - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
EXECUTION_VALUE_BOOL - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
EXECUTION_VALUE_BOOL_NOCACHE - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
EXECUTION_VALUE_FIELDDATA - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
EXECUTION_VALUE_OR - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
EXECUTION_VALUE_OR_NOCACHE - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
EXECUTION_VALUE_PLAIN - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
ExecutionCancelledException(String) - Constructor for exception org.elasticsearch.common.util.CancellableThreads.ExecutionCancelledException
 
ExecutionCancelledException(String, Throwable) - Constructor for exception org.elasticsearch.common.util.CancellableThreads.ExecutionCancelledException
 
executionHint(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
Expert: give an execution hint to this aggregation.
executionHint(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
Expert: provide an execution hint to the aggregation.
executionHint(String) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
An execution hint to how the facet is computed.
executor() - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
 
executor() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
executor() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.warmer.get.TransportGetWarmersAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
 
executor() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
executor() - Method in class org.elasticsearch.action.count.TransportCountAction
 
executor() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
executor() - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
executor() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
executor() - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
executor() - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
executor() - Method in class org.elasticsearch.action.get.TransportGetAction
 
executor() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
executor() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
executor() - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
executor() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
 
executor() - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
 
executor() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
executor() - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
 
executor() - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
executor() - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
executor() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
executor() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
executor() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
executor() - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
executor() - Method in class org.elasticsearch.action.termvector.TransportSingleShardMultiTermsVectorAction
 
executor() - Method in class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
executor() - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
executor() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
executor() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
executor() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
executor() - Method in class org.elasticsearch.indices.IndicesWarmer.Listener
 
executor() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
executor(String) - Method in class org.elasticsearch.threadpool.ThreadPool
 
executor() - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
 
executor() - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
 
executor() - Method in class org.elasticsearch.transport.PlainTransportFuture
 
executor() - Method in interface org.elasticsearch.transport.TransportRequestHandler
 
executor() - Method in interface org.elasticsearch.transport.TransportResponseHandler
 
executorName() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
 
executorName() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
The name of the executor that the implementation of the callbacks of this lister should be executed on.
existence(boolean) - Method in class org.elasticsearch.index.query.MissingFilterBuilder
Should the missing filter include documents where the field doesn't exists in the docs.
existingFiles() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
 
existingParent(long) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
exists() - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
 
exists() - Method in class org.elasticsearch.action.exists.ExistsResponse
Whether the documents matching the query provided exists
exists(ExistsRequest) - Method in interface org.elasticsearch.client.Client
Checks existence of any documents matching a specific query.
exists(ExistsRequest, ActionListener<ExistsResponse>) - Method in interface org.elasticsearch.client.Client
Checks existence of any documents matching a specific query.
exists(IndicesExistsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices Exists.
exists(IndicesExistsRequest, ActionListener<IndicesExistsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
The status of one or more indices.
exists(ExistsRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
exists(ExistsRequest, ActionListener<ExistsResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
exists(IndicesExistsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
exists(IndicesExistsRequest, ActionListener<IndicesExistsResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
exists(File...) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Returns true if at least one of the files exists.
exists(Path...) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Returns true iff one of the files exists otherwise false
exists() - Method in class org.elasticsearch.common.lucene.Lucene.EarlyTerminatingCollector
 
exists(IndexSearcher, Query, Filter, Lucene.EarlyTerminatingCollector) - Static method in class org.elasticsearch.common.lucene.Lucene
Performs an exists (count > 0) query on the searcher for query with filter using the given collector The collector can be instantiated using Lucene.createExistsCollector()
exists(IndexSearcher, Query, Lucene.EarlyTerminatingCollector) - Static method in class org.elasticsearch.common.lucene.Lucene
Performs an exists (count > 0) query on the searcher for query using the given collector The collector can be instantiated using Lucene.createExistsCollector()
exists() - Method in class org.elasticsearch.index.engine.Engine.GetResult
 
ExistsAction - Class in org.elasticsearch.action.exists
 
ExistsFieldQueryExtension - Class in org.apache.lucene.queryparser.classic
 
ExistsFieldQueryExtension() - Constructor for class org.apache.lucene.queryparser.classic.ExistsFieldQueryExtension
 
existsFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter only documents where a field exists in them.
ExistsFilterBuilder - Class in org.elasticsearch.index.query
Constructs a filter that only match on documents that the field has a value in them.
ExistsFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.ExistsFilterBuilder
 
ExistsFilterParser - Class in org.elasticsearch.index.query
 
ExistsFilterParser() - Constructor for class org.elasticsearch.index.query.ExistsFilterParser
 
ExistsRequest - Class in org.elasticsearch.action.exists
 
ExistsRequest(String...) - Constructor for class org.elasticsearch.action.exists.ExistsRequest
Constructs a new exists request against the provided indices.
existsRequest(String...) - Static method in class org.elasticsearch.client.Requests
Creates a exists request which checks if any of the hits matched against a query exists.
ExistsRequestBuilder - Class in org.elasticsearch.action.exists
 
ExistsRequestBuilder(Client) - Constructor for class org.elasticsearch.action.exists.ExistsRequestBuilder
 
ExistsResponse - Class in org.elasticsearch.action.exists
 
exit(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
Should the JVM be exited as well or not.
exit() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
Should the JVM be exited as well or not.
exitCmd(CliTool.ExitStatus) - Static method in class org.elasticsearch.common.cli.CliTool
 
exitCmd(CliTool.ExitStatus, Terminal, String, Object...) - Static method in class org.elasticsearch.common.cli.CliTool
 
exp(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
exp(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
exp(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
exp(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
exp(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
expandAliasesWildcards() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
 
expandAliasesWildcards() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
 
expandAliasesWildcards() - Method in interface org.elasticsearch.action.AliasesRequest
Returns true if wildcards expressions among aliases should be resolved, false otherwise
expandWildcardsClosed() - Method in class org.elasticsearch.action.support.IndicesOptions
 
expandWildcardsOpen() - Method in class org.elasticsearch.action.support.IndicesOptions
 
expectedInsertions - Variable in class org.elasticsearch.common.util.BloomFilter.Factory.Entry
 
expectedNumberOfOperations() - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Translog
 
expectedNumberOfOperations(int) - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Translog
 
expectedSuccessfulOps - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
explain(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
Sets the explain flag, which will collect information about the reroute request without executing the actions.
explain() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
Returns the current explain flag
explain(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
Indicate if detailed information about query is requested
explain() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
Indicates if detailed information about query is requested
explain(ExplainRequest) - Method in interface org.elasticsearch.client.Client
Computes a score explanation for the specified request.
explain(ExplainRequest, ActionListener<ExplainResponse>) - Method in interface org.elasticsearch.client.Client
Computes a score explanation for the specified request.
explain(ExplainRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
explain(ExplainRequest, ActionListener<ExplainResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
explain(ExplainRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
explain(ExplainRequest, ActionListener<ExplainResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
explain(AtomicReaderContext, int) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight
 
explain(float, Explanation, Explanation, float) - Method in enum org.elasticsearch.common.lucene.search.function.CombineFunction
 
explain(AtomicReaderContext, int) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
explain() - Method in class org.elasticsearch.percolator.PercolateContext
 
explain(boolean) - Method in class org.elasticsearch.percolator.PercolateContext
 
explain(Explanation) - Method in interface org.elasticsearch.script.ExplainableSearchScript
Build the explanation of the current document being scored The script score needs the Explanation of the sub query score because it might use _score and want to explain how that was computed.
explain(Boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Should each SearchHit be returned with an explanation of the hit (ranking).
explain(Weight, int) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
explain(Query, int) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
explain() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
explain(boolean) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
explain() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
explain(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
explain() - Method in class org.elasticsearch.search.internal.SearchContext
 
explain(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
 
explain() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
explain(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
explain(int, SearchContext, RescoreSearchContext, Explanation) - Method in class org.elasticsearch.search.rescore.QueryRescorer
 
explain(int, SearchContext, RescoreSearchContext, Explanation) - Method in interface org.elasticsearch.search.rescore.Rescorer
Executes an Explanation phase on the rescorer.
ExplainableSearchScript - Interface in org.elasticsearch.script
To be implemented by SearchScript which can provided an Explanation of the score This is currently not used inside elasticsearch but it is used, see for example here: https://github.com/elasticsearch/elasticsearch/issues/8561
ExplainAction - Class in org.elasticsearch.action.explain
Entry point for the explain feature.
ExplainFetchSubPhase - Class in org.elasticsearch.search.fetch.explain
 
ExplainFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.explain.ExplainFetchSubPhase
 
explainFunction(String, double, double) - Method in interface org.elasticsearch.index.query.functionscore.DecayFunction
 
ExplainParseElement - Class in org.elasticsearch.search.fetch.explain
 
ExplainParseElement() - Constructor for class org.elasticsearch.search.fetch.explain.ExplainParseElement
 
ExplainRequest - Class in org.elasticsearch.action.explain
Explain request encapsulating the explain query and document identifier to get an explanation for.
ExplainRequest(String, String, String) - Constructor for class org.elasticsearch.action.explain.ExplainRequest
 
ExplainRequestBuilder - Class in org.elasticsearch.action.explain
A builder for ExplainRequest.
ExplainRequestBuilder(Client, String, String, String) - Constructor for class org.elasticsearch.action.explain.ExplainRequestBuilder
 
ExplainResponse - Class in org.elasticsearch.action.explain
Response containing the score explanation.
ExplainResponse(String, String, String, boolean) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
 
ExplainResponse(String, String, String, boolean, Explanation) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
 
ExplainResponse(String, String, String, boolean, Explanation, GetResult) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
 
explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
Deprecated.
 
explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
 
explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
 
explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
 
explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
 
explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
 
explainScore(int, Explanation) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionParser.AbstractDistanceScoreFunction
 
explainWeight() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
 
explanation() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
Get explanations of current routing
explanation() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
explanation(Explanation) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
explanation() - Method in interface org.elasticsearch.search.SearchHit
If enabled, the explanation of the search hit.
explanations() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
List of explanations involved by this AllocationExplanation
explanations() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
Get the explanation of this result
explanations() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
 
Explicit<T> - Class in org.elasticsearch.common
Holds a value that is either: a) set implicitly e.g.
Explicit(T, boolean) - Constructor for class org.elasticsearch.common.Explicit
Create a value with an indication if this was an explicit choice
explicit() - Method in class org.elasticsearch.common.Explicit
 
explicitTypeInName() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
Returns true if the type is explicitly specified in the name.
explicitTypeInNameWithDocMapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
 
expm1(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
exponentialDecayFunction(String, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
exponentialDecayFunction(String, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
ExponentialDecayFunctionBuilder - Class in org.elasticsearch.index.query.functionscore.exp
 
ExponentialDecayFunctionBuilder(String, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.exp.ExponentialDecayFunctionBuilder
 
ExponentialDecayFunctionParser - Class in org.elasticsearch.index.query.functionscore.exp
 
ExponentialDecayFunctionParser() - Constructor for class org.elasticsearch.index.query.functionscore.exp.ExponentialDecayFunctionParser
 
expose(Key<?>) - Method in interface org.elasticsearch.common.inject.PrivateBinder
Makes the binding for key available to the enclosing environment
expose(Class<?>) - Method in interface org.elasticsearch.common.inject.PrivateBinder
Makes a binding for type available to the enclosing environment.
expose(TypeLiteral<?>) - Method in interface org.elasticsearch.common.inject.PrivateBinder
Makes a binding for type available to the enclosing environment.
expose(Key<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
Makes the binding for key available to other modules and the injector.
expose(Class<?>) - Method in class org.elasticsearch.common.inject.PrivateModule
Makes a binding for type available to other modules and the injector.
expose(TypeLiteral<?>) - Method in class org.elasticsearch.common.inject.PrivateModule
Makes a binding for type available to other modules and the injector.
Exposed - Annotation Type in org.elasticsearch.common.inject
Acccompanies a @Provides method annotation in a private module to indicate that the provided binding is exposed.
ExposedBinding<T> - Interface in org.elasticsearch.common.inject.spi
A binding to a key exposed from an enclosed private environment.
ExposedBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
 
ExposedBindingImpl(Injector, Object, Key<T>, InternalFactory<T>, PrivateElements) - Constructor for class org.elasticsearch.common.inject.internal.ExposedBindingImpl
 
ExposedBindingImpl(Object, Key<T>, Scoping, PrivateElements) - Constructor for class org.elasticsearch.common.inject.internal.ExposedBindingImpl
 
exposedButNotBound(Key<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
ExposureBuilder<T> - Class in org.elasticsearch.common.inject.internal
For private binder's expose() method.
ExposureBuilder(Binder, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.ExposureBuilder
 
ExpressionScriptCompilationException - Exception in org.elasticsearch.script.expression
Exception representing a compilation error in an expression.
ExpressionScriptCompilationException(String, ParseException) - Constructor for exception org.elasticsearch.script.expression.ExpressionScriptCompilationException
 
ExpressionScriptCompilationException(String) - Constructor for exception org.elasticsearch.script.expression.ExpressionScriptCompilationException
 
ExpressionScriptEngineService - Class in org.elasticsearch.script.expression
Provides the infrastructure for Lucene expressions as a scripting language for Elasticsearch.
ExpressionScriptEngineService(Settings) - Constructor for class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
ExpressionScriptExecutionException - Exception in org.elasticsearch.script.expression
Exception used to wrap exceptions occuring while running expressions.
ExpressionScriptExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.script.expression.ExpressionScriptExecutionException
 
ExpressionScriptExecutionException(String) - Constructor for exception org.elasticsearch.script.expression.ExpressionScriptExecutionException
 
extendedBounds(Long, Long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Set extended bounds for the histogram.
extendedBounds(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Set extended bounds for the histogram.
extendedBounds(DateTime, DateTime) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Set extended bounds for the histogram.
ExtendedBounds - Class in org.elasticsearch.search.aggregations.bucket.histogram
 
extendedBounds(Long, Long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramBuilder
Set extended bounds for the histogram.
ExtendedCommonTermsQuery - Class in org.apache.lucene.queries
Extended version of CommonTermsQuery that allows to pass in a minimumNumberShouldMatch specification that uses the actual num of high frequent terms to calculate the minimum matching terms.
ExtendedCommonTermsQuery(BooleanClause.Occur, BooleanClause.Occur, float, boolean, FieldMapper<?>) - Constructor for class org.apache.lucene.queries.ExtendedCommonTermsQuery
 
ExtendedMemoryIndex - Class in org.apache.lucene.index.memory
This class overwrites MemoryIndex to make the reuse constructor visible.
ExtendedMemoryIndex(boolean, long) - Constructor for class org.apache.lucene.index.memory.ExtendedMemoryIndex
 
extendedStats(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new ExtendedStats aggregation with the given name.
ExtendedStats - Interface in org.elasticsearch.search.aggregations.metrics.stats.extended
Statistics over a set of values (either aggregated over field data or scripts)
ExtendedStats.Bounds - Enum in org.elasticsearch.search.aggregations.metrics.stats.extended
 
ExtendedStatsAggregator - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
 
ExtendedStatsAggregator(String, long, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator, double) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
ExtendedStatsAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
 
ExtendedStatsBuilder - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
Builder for the ExtendedStats aggregation.
ExtendedStatsBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsBuilder
Sole constructor.
ExtendedStatsParser - Class in org.elasticsearch.search.aggregations.metrics.stats.extended
 
ExtendedStatsParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsParser
 
EXTENSION - Static variable in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat
 
extensions() - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
extensions() - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
extensions() - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
 
extensions() - Method in class org.elasticsearch.script.NativeScriptEngineService
 
extensions() - Method in interface org.elasticsearch.script.ScriptEngineService
 
externalValue() - Method in class org.elasticsearch.index.mapper.ParseContext
 
externalValueSet() - Method in class org.elasticsearch.index.mapper.ParseContext
 
extra - Variable in class org.elasticsearch.index.analysis.NumericTokenizer
 
extractGetResult(UpdateRequest, String, long, Map<String, Object>, XContentType, BytesReference) - Method in class org.elasticsearch.action.update.UpdateHelper
Extracts the fields from the updated document to be returned in a update response
extractRawValues(String, Map<String, Object>) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
Extracts raw values (string, int, and so on) based on the path provided returning all of them as a single list.
extractRawValues(String) - Method in class org.elasticsearch.search.lookup.SourceLookup
Returns the values associated with the path.
extractShardId(AtomicReader) - Static method in class org.elasticsearch.index.shard.ShardUtils
Tries to extract the shard id from a reader if possible, when its not possible, will return null.
extractShardId(IndexReader) - Static method in class org.elasticsearch.index.shard.ShardUtils
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.queries.BlendedTermQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.index.search.child.ChildrenQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.index.search.child.ParentQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
 
extractTerms(SearchContext, RescoreSearchContext, Set<Term>) - Method in class org.elasticsearch.search.rescore.QueryRescorer
 
extractTerms(SearchContext, RescoreSearchContext, Set<Term>) - Method in interface org.elasticsearch.search.rescore.Rescorer
Extracts all terms needed to exectue this Rescorer.
extractValue(String, Map<String, Object>) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
extractValue(String) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
extraSource(SearchSourceBuilder) - Method in class org.elasticsearch.action.search.SearchRequest
Allows to provide additional source that will be used as well.
extraSource(Map) - Method in class org.elasticsearch.action.search.SearchRequest
 
extraSource(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequest
 
extraSource(String) - Method in class org.elasticsearch.action.search.SearchRequest
Allows to provide additional source that will use used as well.
extraSource(byte[]) - Method in class org.elasticsearch.action.search.SearchRequest
Allows to provide additional source that will be used as well.
extraSource(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequest
Allows to provide additional source that will be used as well.
extraSource(byte[], int, int, boolean) - Method in class org.elasticsearch.action.search.SearchRequest
Allows to provide additional source that will be used as well.
extraSource(BytesReference, boolean) - Method in class org.elasticsearch.action.search.SearchRequest
Allows to provide additional source that will be used as well.
extraSource() - Method in class org.elasticsearch.action.search.SearchRequest
Additional search source to execute.
extraSource() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
 
extraSource() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
 
extraSource() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 

F

facet(FacetBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Add a facet to perform as part of the search.
Facet - Interface in org.elasticsearch.search.facet
A search facet.
facet(Class<T>, String) - Method in interface org.elasticsearch.search.facet.Facets
Returns the facet by name already casted to the specified type.
facet(String) - Method in interface org.elasticsearch.search.facet.Facets
A facet of the specified name.
facet(Class<T>, String) - Method in class org.elasticsearch.search.facet.InternalFacets
Returns the facet by name already casted to the specified type.
facet(String) - Method in class org.elasticsearch.search.facet.InternalFacets
A facet of the specified name.
FacetBinaryParseElement - Class in org.elasticsearch.search.facet
 
FacetBinaryParseElement(FacetParsers) - Constructor for class org.elasticsearch.search.facet.FacetBinaryParseElement
 
FacetBuilder - Class in org.elasticsearch.search.facet
 
FacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.FacetBuilder
 
FacetBuilder.Mode - Enum in org.elasticsearch.search.facet
 
FacetBuilders - Class in org.elasticsearch.search.facet
Deprecated.
Facets are deprecated and will be removed in a future release. Please use aggregations instead.
FacetBuilders() - Constructor for class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
FacetExecutor - Class in org.elasticsearch.search.facet
A facet processor ends up actually executing the relevant facet for a specific search request.
FacetExecutor() - Constructor for class org.elasticsearch.search.facet.FacetExecutor
 
FacetExecutor.Collector - Class in org.elasticsearch.search.facet
Simple extension to XCollector that implements methods that are typically not needed when doing collector based faceting.
FacetExecutor.Mode - Enum in org.elasticsearch.search.facet
The mode of the execution.
FacetExecutor.Post - Class in org.elasticsearch.search.facet
A post class extends this class to implement post hits processing.
FacetExecutor.Post.Collector - Class in org.elasticsearch.search.facet
FacetExecutor.Post.Filtered - Class in org.elasticsearch.search.facet
A filtered post execution.
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
An additional filter used to further filter down the set of documents the facet will run on.
facetFilter - Variable in class org.elasticsearch.search.facet.FacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.FacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.filter.FilterFacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
An additional filter used to further filter down the set of documents the facet will run on.
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.query.QueryFacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
An additional filter used to further filter down the set of documents the facet will run on.
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
An additional facet filter that will further filter the documents the facet will be executed on.
FacetModule - Class in org.elasticsearch.search.facet
 
FacetModule() - Constructor for class org.elasticsearch.search.facet.FacetModule
 
FacetParseElement - Class in org.elasticsearch.search.facet
facets : { facet1: { query : { ...
FacetParseElement(FacetParsers) - Constructor for class org.elasticsearch.search.facet.FacetParseElement
 
FacetParser - Interface in org.elasticsearch.search.facet
A facet parser parses the relevant matching "type" of facet into a FacetExecutor.
FacetParsers - Class in org.elasticsearch.search.facet
 
FacetParsers(Set<FacetParser>) - Constructor for class org.elasticsearch.search.facet.FacetParsers
 
FacetPhase - Class in org.elasticsearch.search.facet
 
FacetPhase(FacetParseElement, FacetBinaryParseElement) - Constructor for class org.elasticsearch.search.facet.FacetPhase
 
FacetPhaseExecutionException - Exception in org.elasticsearch.search.facet
 
FacetPhaseExecutionException(String, String) - Constructor for exception org.elasticsearch.search.facet.FacetPhaseExecutionException
 
FacetPhaseExecutionException(String, String, Throwable) - Constructor for exception org.elasticsearch.search.facet.FacetPhaseExecutionException
 
facets() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
 
facets() - Method in class org.elasticsearch.percolator.PercolateContext
 
facets(SearchContextFacets) - Method in class org.elasticsearch.percolator.PercolateContext
 
facets(byte[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Sets a raw (xcontent / json) facets.
facets(byte[], int, int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Sets a raw (xcontent / json) facets.
facets(BytesReference) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Sets a raw (xcontent / json) facets.
facets(XContentBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Sets a raw (xcontent / json) facets.
facets(Map) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Sets a raw (xcontent / json) facets.
Facets - Interface in org.elasticsearch.search.facet
Facets of search action.
facets() - Method in interface org.elasticsearch.search.facet.Facets
The list of Facets.
facets() - Method in class org.elasticsearch.search.facet.InternalFacet.ReduceContext
 
facets() - Method in class org.elasticsearch.search.facet.InternalFacets
The list of Facets.
facets() - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetExecutor.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetExecutor.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
facets(SearchContextFacets) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
facets() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
facets(SearchContextFacets) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
facets() - Method in class org.elasticsearch.search.internal.InternalSearchResponse
 
facets() - Method in class org.elasticsearch.search.internal.SearchContext
 
facets(SearchContextFacets) - Method in class org.elasticsearch.search.internal.SearchContext
 
facets() - Method in class org.elasticsearch.search.query.QuerySearchResult
 
facets(InternalFacets) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
facetsAsMap() - Method in interface org.elasticsearch.search.facet.Facets
Returns the Facets keyed by facet name.
facetsAsMap() - Method in class org.elasticsearch.search.facet.InternalFacets
Returns the Facets keyed by map.
factor(float) - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
factor(float) - Method in class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionBuilder
 
factor(int) - Method in class org.elasticsearch.index.query.TopChildrenQueryBuilder
Controls the multiplication factor of the initial hits required from the child query over the main query request.
factor(float) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Set a factor to apply to values of the field, typically used if times are stored in seconds instead of milliseconds.
factor(float) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Sets the factor that will be used to multiply the value with before and divided by after the rounding of the results.
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
 
factorFunction(float) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
Deprecated.
factories - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
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.metadata.MetaData.Custom.Factory
 
FACTORY - Static variable in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
 
Factory() - Constructor for class org.elasticsearch.cluster.metadata.RepositoriesMetaData.Factory
 
FACTORY - Static variable in class org.elasticsearch.cluster.metadata.RestoreMetaData
 
Factory() - Constructor for class org.elasticsearch.cluster.metadata.RestoreMetaData.Factory
 
FACTORY - Static variable in class org.elasticsearch.cluster.metadata.SnapshotMetaData
 
Factory() - Constructor for class org.elasticsearch.cluster.metadata.SnapshotMetaData.Factory
 
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(DocValuesFormat) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider.Factory
 
Factory(String, DocValuesFormat) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider.Factory
 
Factory(PostingsFormat) - Constructor for class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider.Factory
 
Factory(String, PostingsFormat) - Constructor for class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider.Factory
 
Factory(String, Similarity) - Constructor for class org.elasticsearch.index.similarity.PreBuiltSimilarityProvider.Factory
 
Factory(String, ValuesSourceConfig<ValuesSource.Bytes.ParentChild>, String, Filter, Filter) - Constructor for class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator.Factory
 
Factory(String, Filter) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator.Factory
 
Factory(String, List<FiltersAggregator.KeyedFilter>, boolean) - 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(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 - Static variable in class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
 
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(String, ValuesSourceConfig<ValuesSource.Numeric>, InternalRange.Factory, List<RangeAggregator.Range>, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.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.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[], double, boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregator.Factory
 
Factory(String, ValuesSourceConfig<ValuesSource.Numeric>, double[], double, boolean) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregator.Factory
 
Factory(String, String, ScriptService.ScriptType, String, ScriptService.ScriptType, String, ScriptService.ScriptType, String, ScriptService.ScriptType, String, Map<String, Object>, 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.StatsAggegator.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 - Static variable in class org.elasticsearch.search.suggest.phrase.LaplaceScorer
 
FACTORY - Static variable in class org.elasticsearch.search.suggest.phrase.StupidBackoffScorer
 
FACTORY - Static variable in class org.elasticsearch.search.warmer.IndexWarmersMetaData
 
Factory() - Constructor for class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
FactoryProvider<F> - Class in org.elasticsearch.common.inject.assistedinject
Provides a factory that combines the caller's arguments with injector-supplied values to construct objects.
fail(RecoveryFailedException, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
fail the recovery and call listener
FAIL_ON_UNSUPPORTED_FIELD - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
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.metadata.SnapshotMetaData.State
 
failed(Throwable) - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
failed(String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Marks snapshot as failed and saves failure reason
failed() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
 
FailedCommunicationException - Exception in org.elasticsearch.transport
 
FailedCommunicationException(String) - Constructor for exception org.elasticsearch.transport.FailedCommunicationException
 
FailedCommunicationException(String, Throwable) - Constructor for exception org.elasticsearch.transport.FailedCommunicationException
 
failedDelete(Engine.Delete) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
failedEngine - Variable in class org.elasticsearch.index.engine.Engine
 
failedEngineListener - Variable in class org.elasticsearch.index.engine.Engine
 
failedIndex(Engine.Index) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
failedMerge(MergePolicy.MergeException) - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
FailedNodeException - Exception in org.elasticsearch.action
 
FailedNodeException(String, String, Throwable) - Constructor for exception org.elasticsearch.action.FailedNodeException
 
FailedRerouteAllocation - Class in org.elasticsearch.cluster.routing.allocation
This RoutingAllocation keeps a shard which routing allocation has faild
FailedRerouteAllocation(AllocationDeciders, RoutingNodes, DiscoveryNodes, List<ShardRouting>, ClusterInfo) - Constructor for class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation
 
failedShards() - Method in class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation
 
failedShards() - Method in class org.elasticsearch.snapshots.RestoreInfo
Number of failed shards
failedShards() - Method in class org.elasticsearch.snapshots.SnapshotInfo
Number of failed shards
FailedToResolveConfigException - Exception in org.elasticsearch.env
 
FailedToResolveConfigException(String) - Constructor for exception org.elasticsearch.env.FailedToResolveConfigException
 
FailedToResolveConfigException(String, Throwable) - Constructor for exception org.elasticsearch.env.FailedToResolveConfigException
 
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.FuzzyLikeThisFieldQueryBuilder
Whether to fail or return no result when this query is run against a field which is not supported such as binary/numeric fields.
failOnUnsupportedField(boolean) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
Whether to fail or return no result when this query is run against a field which is not supported such as binary/numeric fields.
failOnUnsupportedField(boolean) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Whether to fail or return no result when this query is run against a field which is not supported such as binary/numeric fields.
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
 
Failure(String, String, String, Throwable) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.Failure
 
Failure(String, String, String, String, RestStatus) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.Failure
 
Failure(String, String, String, String) - Constructor for class org.elasticsearch.action.get.MultiGetResponse.Failure
 
Failure(String, String, String, String) - Constructor for class org.elasticsearch.action.termvector.MultiTermVectorsResponse.Failure
 
failure(String) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
Sets the reason for the failure if the snapshot is in the IndexShardSnapshotStatus.Stage.FAILURE state
failure() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
Returns the reason for the failure if the snapshot is in the IndexShardSnapshotStatus.Stage.FAILURE state
failureDescription() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
 
failures() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
 
failures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
failures() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState
 
failures() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards
 
failures() - Method in exception org.elasticsearch.index.mapper.MergeMappingException
 
failures() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
 
failures(int, ImmutableList<SnapshotShardFailure>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets the total number of shards and the list of individual shard failures
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

(shay.banon )

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
A base class for MasterFaultDetection & NodesFaultDetection, making sure both use the same setting.
FaultDetection(Settings, ThreadPool, TransportService, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.fd.FaultDetection
 
features(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
 
features(String[]) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
Deprecated.
features() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
Deprecated.
featuresAsEnums() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
 
fetch(MultiTermVectorsRequest) - Method in class org.elasticsearch.index.search.morelikethis.MoreLikeThisFetchService
 
fetch(String, String, String, 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_SOURCE - Static variable in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
FetchPhase - Class in org.elasticsearch.search.fetch
 
FetchPhase(HighlightPhase, ScriptFieldsFetchSubPhase, PartialFieldsFetchSubPhase, MatchedQueriesFetchSubPhase, ExplainFetchSubPhase, VersionFetchSubPhase, FetchSourceSubPhase, FieldDataFieldsFetchSubPhase, InnerHitsFetchSubPhase) - Constructor for class org.elasticsearch.search.fetch.FetchPhase
 
FetchPhaseExecutionException - Exception in org.elasticsearch.search.fetch
 
FetchPhaseExecutionException(SearchContext, String) - Constructor for exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
 
FetchPhaseExecutionException(SearchContext, String, Throwable) - Constructor for exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
 
fetchResult() - Method in class org.elasticsearch.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.HitContext - Class in org.elasticsearch.search.fetch
 
field(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
 
field() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
 
field() - Method in class org.elasticsearch.common.lucene.search.RegexpFilter
 
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, BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
Writes the binary content of the given BytesReference Use XContentParser.binaryValue() to read the value back
field(XContentBuilderString, BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
Writes the binary content of the given BytesReference Use XContentParser.binaryValue() to read the value back
field(XContentBuilderString, BytesRef) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
Deprecated.
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, 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(String) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper.Builder
 
FIELD - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
field(String) - Method in class org.elasticsearch.index.query.GeohashCellFilter.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(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.facet.datehistogram.DateHistogramFacetBuilder
The field name to perform the histogram facet.
field(String) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The geo point field that will be used to extract the document location(s).
field(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
The field name to perform the histogram facet.
field(String) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
The field name to perform the range facet.
field(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetBuilder
 
field(String) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
The field the terms will be collected from.
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.AbstractFieldMapper.Defaults
 
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.NumberFieldMapper.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.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.BoostFieldMapper.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
 
FieldBased(ESLogger, IndexService, FieldMapper.Names, FieldDataType, CacheBuilder, IndicesFieldDataCacheListener) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
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<?>, FieldMapper) - 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 - 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<?>, ValuesSource.MetaData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
 
FieldData(IndexOrdinalsFieldData, ValuesSource.MetaData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
FieldData(IndexNumericFieldData, ValuesSource.MetaData) - 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_CACHE_VALUE_RESIDENT - Static variable in class org.elasticsearch.index.fielddata.IndexFieldDataService
 
FIELDDATA_CACHE_VALUE_SOFT - 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
 
fieldDataFields() - Method in class org.elasticsearch.percolator.PercolateContext
 
fieldDataFields() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
fieldDataFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
fieldDataFields() - Method in class org.elasticsearch.search.internal.SearchContext
 
fieldDataFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
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
 
fieldDataSettings - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
fieldDataSettings(Settings) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
fieldDataSettings(Settings) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
fieldDataSettings - Variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.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, ObjectLongOpenHashMap<String>) - Constructor for class org.elasticsearch.index.fielddata.FieldDataStats
 
fieldDataStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
 
fieldDataTermsFilter(List, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
A terms filter based on the field data cache
fieldDataTermsFilter(List, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
A terms filter based on the field data cache for numeric fields.
fieldDataTermsFilter(List, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
FieldDataTermsFilter - Class in org.elasticsearch.index.search
Similar to a TermsFilter but pulls terms from the fielddata.
FieldDataTermsFilter(IndexFieldData) - Constructor for class org.elasticsearch.index.search.FieldDataTermsFilter
 
FieldDataTermsFilter.BytesFieldDataFilter - Class in org.elasticsearch.index.search
Filters on non-numeric fields.
FieldDataTermsFilter.DoublesFieldDataFilter - Class in org.elasticsearch.index.search
Filters on floating point numeric fields.
FieldDataTermsFilter.LongsFieldDataFilter - Class in org.elasticsearch.index.search
Filters on non-floating point numeric fields.
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 - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fieldDataType() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
FieldDataWeigher() - Constructor for class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.FieldDataWeigher
 
FieldLookup - Class in org.elasticsearch.search.lookup
 
FieldMapper<T> - Interface in org.elasticsearch.index.mapper
 
fieldMapper(FieldMapper<?>) - Method in class org.elasticsearch.index.mapper.FieldMapperListener.Aggregator
 
fieldMapper(FieldMapper<?>) - Method in class org.elasticsearch.index.mapper.FieldMapperListener
 
fieldMapper(String) - Method in class org.elasticsearch.index.query.QueryParseContext
 
FieldMapper.Loading - Enum in org.elasticsearch.index.mapper
 
FieldMapper.Names - Class in org.elasticsearch.index.mapper
 
FieldMapperListener - Class in org.elasticsearch.index.mapper
 
FieldMapperListener() - Constructor for class org.elasticsearch.index.mapper.FieldMapperListener
 
FieldMapperListener.Aggregator - Class in org.elasticsearch.index.mapper
 
fieldMappers(List<FieldMapper<?>>) - Method in class org.elasticsearch.index.mapper.FieldMapperListener
 
FieldMappers - Class in org.elasticsearch.index.mapper
A holder for several FieldMapper.
FieldMappers() - Constructor for class org.elasticsearch.index.mapper.FieldMappers
 
FieldMappers(FieldMapper) - Constructor for class org.elasticsearch.index.mapper.FieldMappers
 
fieldMappers() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
All the field mappers for the smart name field.
FieldMappersLookup - Class in org.elasticsearch.index.mapper
A class that holds a map of field mappers from name, index name, and full name.
FieldMappersLookup() - Constructor for class org.elasticsearch.index.mapper.FieldMappersLookup
Create a new empty instance.
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.GeoDistanceFilter
 
fieldName() - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
fieldName() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
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(Analyzer) - Constructor for class org.elasticsearch.index.analysis.FieldNameAnalyzer
 
FieldNameAnalyzer(Map<String, Analyzer>, Analyzer) - Constructor for class org.elasticsearch.index.analysis.FieldNameAnalyzer
 
fieldNames - Variable in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
 
fieldNames() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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(Settings) - Constructor for class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
FieldNamesFieldMapper(String, String, float, FieldType, PostingsFormatProvider, DocValuesFormatProvider, EnabledAttributeMapper, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
FieldNamesFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
FieldNamesFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
FieldNamesFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
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(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() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The fields of the document to use in order to find documents "like" this one.
fields(String...) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The fields of the document to use in order to find documents "like" this one.
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() - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryParser.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(String...) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetBuilder
The fields the terms will be collected from.
fields(String...) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
The fields the terms will be collected from.
fields() - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsContext
 
fields() - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsContext
 
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.SearchLookup
 
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
 
fieldSearchAnalyzer(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
fieldSearchQuoteAnalyzer(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
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.termvector.TermVectorRequest
 
fieldStatistics(boolean) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Return the field statistics for each term in the shard or skip.
fieldStatistics() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
 
fieldStatistics(ObjectObjectOpenHashMap<String, CollectionStatistics>) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
fieldStatistics() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
FieldsTermsStringFacetExecutor - Class in org.elasticsearch.search.facet.terms.strings
 
FieldsTermsStringFacetExecutor(FieldMapper[], int, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<BytesRef>, Pattern, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetExecutor
 
fieldsValues - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
FieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
 
FieldsVisitor() - Constructor for class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
fieldType - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
fieldType - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fieldType() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fieldType() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
 
fieldType() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
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, 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() - Method in class org.elasticsearch.index.translog.fs.RafReference
 
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.index.store.DistributorDirectory
 
fileExists(String) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
FileInfo(String, String, long, String) - Constructor for class org.elasticsearch.index.gateway.CommitPoint.FileInfo
 
FileInfo(String, StoreFileMetaData, ByteSizeValue) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
Constructs a new instance of file info
fileLength(String) - Method in class org.elasticsearch.index.store.DistributorDirectory
 
filePath() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
files(Path) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Returns an array of all files in the given directory.
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.gateway.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
 
FileSystemUtils - Class in org.elasticsearch.common.io
 
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(File) - 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() - Method in class org.elasticsearch.search.suggest.completion.CompletionTokenStream.ByteTermAttributeImpl
 
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.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(FilterBuilder) - 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(FilterBuilder) - 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(FilterBuilder) - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
filter(CompressedString) - 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() - Method in class org.elasticsearch.common.lucene.search.ApplyAcceptedDocsFilter
 
filter - Variable in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
 
filter() - Method in class org.elasticsearch.common.lucene.search.NotFilter
 
filter(ImmutableSettings.Builder) - Method in interface org.elasticsearch.common.settings.SettingsFilter.Filter
 
filter(Map<String, Object>, String[], String[]) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
filter() - Method in class org.elasticsearch.index.aliases.IndexAlias
 
filter() - Method in class org.elasticsearch.index.cache.IndexCache
 
filter(Terms, AtomicReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
 
filter() - Method in class org.elasticsearch.index.query.ParsedFilter
 
filter() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
FILTER - Static variable in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction.Fields
 
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(FilterBuilder) - 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, FilterBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregationBuilder
Add a new filter with the given key.
filter(FilterBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregationBuilder
Add a new filter with no key.
filter(FilterBuilder) - Method in class org.elasticsearch.search.facet.filter.FilterFacetBuilder
 
filter(String[], String[]) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
FILTER_CACHE_TYPE - Static variable in class org.elasticsearch.index.cache.filter.FilterCacheModule.FilterCacheSettings
 
FILTER_KEYS - Static variable in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction.Fields
 
FILTER_PREFIX - Static variable in class org.elasticsearch.index.query.IndexQueryParserService.Defaults
 
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, Filter) - 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, Filter, AggregatorFactories, AggregationContext, Aggregator) - 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
 
FilterBuilder - Interface in org.elasticsearch.index.query
 
FilterBuilders - Class in org.elasticsearch.index.query
A static factory for simple "import static" usage.
filterCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
filterCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
filterCache - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
filterCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
filterCache() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
FilterCache - Interface in org.elasticsearch.index.cache.filter
 
filterCache() - Method in class org.elasticsearch.index.shard.IndexShard
 
filterCache() - Method in class org.elasticsearch.percolator.PercolateContext
 
filterCache() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
filterCache() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
filterCache() - Method in class org.elasticsearch.search.internal.SearchContext
 
FilterCache.EntriesStats - Class in org.elasticsearch.index.cache.filter
 
FilterCacheKey(Object, Object) - Constructor for class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
FilterCacheModule - Class in org.elasticsearch.index.cache.filter
 
FilterCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.filter.FilterCacheModule
 
FilterCacheModule.FilterCacheSettings - Class in org.elasticsearch.index.cache.filter
 
FilterCacheSettings() - Constructor for class org.elasticsearch.index.cache.filter.FilterCacheModule.FilterCacheSettings
 
FilterCacheStats - Class in org.elasticsearch.index.cache.filter
 
FilterCacheStats() - Constructor for class org.elasticsearch.index.cache.filter.FilterCacheStats
 
FilterCacheStats(long, long) - Constructor for class org.elasticsearch.index.cache.filter.FilterCacheStats
 
filterCacheStats() - Method in class org.elasticsearch.index.shard.IndexShard
 
FilterCacheValue<T> - Class in org.elasticsearch.index.cache.filter.support
 
FilterCacheValue(T) - Constructor for class org.elasticsearch.index.cache.filter.support.FilterCacheValue
 
FilterCacheValueWeigher(int) - Constructor for class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheValueWeigher
 
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
FilterClient.ClusterAdmin - Class in org.elasticsearch.client
A ClusterAdminClient that contains another ClusterAdminClient which it uses as its basic source, possibly transforming the requests / responses along the way or providing additional functionality.
FilterClient.IndicesAdmin - Class in org.elasticsearch.client
A IndicesAdminClient that contains another IndicesAdminClient which it uses as its basic source, possibly transforming the requests / responses along the way or providing additional functionality.
filtered(QueryBuilder, FilterBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
Use filteredQuery instead (rename) Will be removed in elasticsearch 2.0.0
Filtered(FacetExecutor.Post, Filter) - Constructor for class org.elasticsearch.search.facet.FacetExecutor.Post.Filtered
 
FilteredCollector - Class in org.elasticsearch.common.lucene.search
 
FilteredCollector(Collector, Filter) - 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, FilterBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that applies a filter to the results of another query.
FilteredQueryBuilder - Class in org.elasticsearch.index.query
A query that applies a filter to the results of another query.
FilteredQueryBuilder(QueryBuilder, FilterBuilder) - Constructor for class org.elasticsearch.index.query.FilteredQueryBuilder
A query that applies a filter to the results of another query.
FilteredQueryParser - Class in org.elasticsearch.index.query
 
FilteredQueryParser() - Constructor for class org.elasticsearch.index.query.FilteredQueryParser
 
filteredScorer(AtomicReaderContext, Weight, DocIdSet) - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery.CustomRandomAccessFilterStrategy
 
FilteredSearchContext - Class in org.elasticsearch.search.internal
 
FilteredSearchContext(SearchContext) - Constructor for class org.elasticsearch.search.internal.FilteredSearchContext
 
filterFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
filterFacet(String, FilterBuilder) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
FilterFacet - Interface in org.elasticsearch.search.facet.filter
A query facets returns the count (number of hits) for a facet based on a query.
FilterFacetBuilder - Class in org.elasticsearch.search.facet.filter
 
FilterFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.filter.FilterFacetBuilder
 
FilterFacetExecutor - Class in org.elasticsearch.search.facet.filter
 
FilterFacetExecutor(Filter) - Constructor for class org.elasticsearch.search.facet.filter.FilterFacetExecutor
 
FilterFacetParser - Class in org.elasticsearch.search.facet.filter
 
FilterFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.filter.FilterFacetParser
 
filterFound - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
filterFound() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
FilterFunction(Filter, 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(IndexOutput) - Constructor for class org.elasticsearch.common.lucene.store.FilterIndexOutput
 
filterIndices(ImmutableList<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.deletebyquery.ShardDeleteByQueryRequest
 
filteringAliases(String, String...) - Method in class org.elasticsearch.cluster.metadata.MetaData
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
 
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
 
FilteringBucketCollector - Class in org.elasticsearch.search.aggregations
Filters a collection stream of docIds and related buckets using a sorted list of valid bucket ordinals.
FilteringBucketCollector(long[], BucketCollector, BigArrays) - Constructor for class org.elasticsearch.search.aggregations.FilteringBucketCollector
 
filteringRequired() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
filterKey() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
filterKeys(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
filterKeys() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
filterName(String) - Method in class org.elasticsearch.index.query.AndFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.ExistsFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.GeoPolygonFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.GeoShapeFilterBuilder
Sets the name of the filter
filterName(String) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.HasParentFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.IdsFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.IndicesFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.MissingFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.NestedFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.NotFilterBuilder
 
filterName(String) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.OrFilterBuilder
 
filterName(String) - Method in class org.elasticsearch.index.query.PrefixFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.QueryFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.RegexpFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.TermFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.TermsFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterName(String) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
Sets the filter name for the filter that can be used when searching for matched_filters per hit.
filterNodeIds(DiscoveryNodes, String[]) - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
FilterParser - Interface in org.elasticsearch.index.query
 
filterParser(String) - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
FilterParser - Class in org.elasticsearch.search.aggregations.bucket.filter
 
FilterParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterParser
 
FilterParserFactory - Interface in org.elasticsearch.index.query
 
filterParsers() - Method in class org.elasticsearch.indices.query.IndicesQueriesRegistry
 
filters() - Method in class org.elasticsearch.action.support.ActionFilters
Returns the action filters that have been injected
filters() - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
filters() - Method in class org.elasticsearch.common.lucene.search.OrFilter
 
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)
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, List<FiltersAggregator.KeyedFilter>, boolean, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator
 
FiltersAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.filters
 
filterSettings(Settings) - 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
 
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.
finalizeSnapshot(SnapshotId, String, int, ImmutableList<SnapshotShardFailure>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
Finalizes snapshotting process

This method is called on master after all shards are snapshotted.

finalizeSnapshot(SnapshotId, String, int, ImmutableList<SnapshotShardFailure>) - Method in interface org.elasticsearch.repositories.Repository
Finalizes snapshotting process

This method is called on master after all shards are snapshotted.

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
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 or for all indices iff the given index is null on the current node.
findAllShardIds() - Method in class org.elasticsearch.env.NodeEnvironment
Tries to find all allocated shards for all indices iff 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.merge.policy.ElasticsearchMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, IndexWriter) - Method in class org.elasticsearch.index.merge.policy.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.merge.policy.ElasticsearchMergePolicy
 
findNameFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoint
 
findNameFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoints
 
findNameFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
Returns true if this snapshot contains a file with a given name
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.gateway.CommitPoint
 
findNameTranslogFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoint
 
findNestedObjectMapper(int, FixedBitSetFilterCache, AtomicReaderContext) - Method in class org.elasticsearch.index.mapper.DocumentMapper
Returns the best nested ObjectMapper instances that is in the scope of the specified nested docId.
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.gateway.CommitPoint
 
findPhysicalIndexFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoints
 
findPhysicalIndexFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
 
findPhysicalIndexFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
Finds reference to a snapshotted file by its original name
findRecoveryByShard(IndexShard) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
Try to find an ongoing recovery for a given shard.
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.
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.TransportBroadcastOperationAction.AsyncBroadcastAction
 
finishStage(ContextIndexSearcher.Stage) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
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, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.FinnishAnalyzerProvider
 
firstPhaseName() - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
firstResults - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
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
 
FixedBitSetFilter - Class in org.elasticsearch.index.cache.fixedbitset
A filter that always returns a FixedBitSet.
FixedBitSetFilter() - Constructor for class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilter
 
fixedBitSetFilter(Filter) - Method in class org.elasticsearch.index.query.QueryParseContext
 
FixedBitSetFilterCache - Class in org.elasticsearch.index.cache.fixedbitset
This is a cache for FixedBitSet based filters and is unbounded by size or time.
FixedBitSetFilterCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
fixedBitSetFilterCache() - Method in class org.elasticsearch.index.cache.IndexCache
Return the FixedBitSetFilterCache for this index.
fixedBitSetFilterCache() - Method in class org.elasticsearch.index.IndexService
 
fixedBitSetFilterCache() - Method in class org.elasticsearch.percolator.PercolateContext
 
fixedBitSetFilterCache() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
fixedBitSetFilterCache() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
fixedBitSetFilterCache() - Method in class org.elasticsearch.search.internal.SearchContext
 
FixedBitSetFilterCache.Value - Class in org.elasticsearch.index.cache.fixedbitset
 
FixedBitSetFilterCacheModule - Class in org.elasticsearch.index.cache.fixedbitset
 
FixedBitSetFilterCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCacheModule
 
fixedSourceDistance(double, double, DistanceUnit) - Method in enum org.elasticsearch.common.geo.GeoDistance
 
fixedSourceDistance - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetExecutor.Aggregator
 
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 to pass to IndexField#get(String, flags) if you require positions in the returned IndexFieldTerm.
FLAG_FREQUENCIES - Static variable in class org.elasticsearch.search.lookup.IndexLookup
Flag to pass to IndexField#get(String, flags) if you require frequencies in the returned IndexFieldTerm.
FLAG_OFFSETS - Static variable in class org.elasticsearch.search.lookup.IndexLookup
Flag to pass to IndexField#get(String, flags) if you require offsets in the returned IndexFieldTerm.
FLAG_PAYLOADS - Static variable in class org.elasticsearch.search.lookup.IndexLookup
Flag to pass to IndexField#get(String, flags) if you require payloads in the returned IndexFieldTerm.
FLAG_POSITIONS - Static variable in class org.elasticsearch.search.lookup.IndexLookup
Flag to pass to IndexField#get(String, flags) if you require positions in the returned IndexFieldTerm.
flags() - Method in class org.elasticsearch.common.lucene.search.RegexpFilter
 
flags(RegexpFlag...) - Method in class org.elasticsearch.index.query.RegexpFilterBuilder
Sets the regexp flags (see RegexpFlag).
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
 
FLAT_SETTINGS_KEY - Static variable in class org.elasticsearch.common.settings.ImmutableSettings
 
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, FieldMapper.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(FieldMapper.Names, int, float, FieldType, Boolean, Float, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.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
 
floatIntMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
floatIntMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
floatToBytes(float) - Static method in class org.elasticsearch.common.Numbers
Converts a float to a byte array.
floatValue() - Method in class jsr166e.DoubleAdder
Returns the sum() as a float after a narrowing primitive conversion.
floatValue() - Method in class jsr166e.DoubleMaxUpdater
Returns the DoubleMaxUpdater.max() as a float after a narrowing primitive conversion.
floatValue() - Method in class jsr166e.LongAdder
Returns the LongAdder.sum() as a float after a widening primitive conversion.
floatValue() - Method in class jsr166e.LongMaxUpdater
Returns the LongMaxUpdater.max() as a float after a widening primitive conversion.
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.optimize.OptimizeRequest.Defaults
 
flush() - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should flush be performed after the optimization.
flush(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should flush be performed after the optimization.
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(FlushRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
flush(FlushRequest, ActionListener<FlushResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
flush() - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
flush() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Flush the stream.
flush() - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
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.NoopStreamOutput
 
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.lucene.store.FilterIndexOutput
Deprecated.
flush() - Method in class org.elasticsearch.common.lucene.store.OutputStreamIndexOutput
 
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 - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
FlushAction - Class in org.elasticsearch.action.admin.indices.flush
 
flushAndClose() - Method in class org.elasticsearch.index.engine.Engine
Flush the engine (committing segments to disk and truncating the translog) and close it.
FlushFailedEngineException - Exception in org.elasticsearch.index.engine
 
FlushFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.FlushFailedEngineException
 
FlushFailedEngineException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.FlushFailedEngineException
 
FlushingRecoveryCounter - Class in org.elasticsearch.index.engine
A special RecoveryCounter that flushes the engine when all recoveries have completed
FlushNotAllowedEngineException - Exception in org.elasticsearch.index.engine
 
FlushNotAllowedEngineException(ShardId, String) - 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(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(IndicesAdminClient) - 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
 
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() - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Deprecated.
force(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
force() - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
Deprecated.
force(boolean) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
Deprecated.
unnecessary flag since 1.5.0
FORCE_ASYNC_MERGE - Static variable in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
FORCE_LOCAL_SETTING - Static variable in class org.elasticsearch.action.support.master.TransportMasterNodeReadOperationAction
 
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.
forceAnalyzeQueryString() - Method in class org.elasticsearch.index.search.MatchQuery
 
forceAnalyzeQueryString() - Method in class org.elasticsearch.index.search.MultiMatchQuery.CrossFieldsQueryBuilder
 
forceAnalyzeQueryString() - Method in class org.elasticsearch.index.search.MultiMatchQuery
 
forceAnalyzeQueryString() - Method in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
 
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(boolean) - Method in class org.elasticsearch.index.engine.Engine
Optimizes to 1 segment
forceMerge(boolean, int, boolean, boolean) - Method in class org.elasticsearch.index.engine.Engine
Triggers a forced merge on this engine
forceMerge(boolean, int, boolean, boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
 
forceMerge(boolean, int, boolean, boolean) - Method in class org.elasticsearch.index.engine.ShadowEngine
 
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
 
forceThreadedListener() - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
forceThreadedListener() - Method in class org.elasticsearch.action.support.TransportAction
 
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.ImmutableOpenLongMap.Builder
 
forEach(T) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
 
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(double) - Static method in class org.elasticsearch.common.unit.Percent
 
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.local.state.meta.MetaDataStateFormat
Returns the XContentType used to serialize xcontent on write.
FORMAT - Static variable in class org.elasticsearch.gateway.local.state.shards.LocalGatewayShardsState
 
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.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) - 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.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
The
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
 
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.merge.policy.AbstractMergePolicyProvider
 
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 - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
 
formatter - Variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
formatter - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
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.
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).
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
 
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(long, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.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
The "fquery" filter is the same as the QueryFilterParser except that it allows also to associate a name with the query filter.
FQueryFilterParser() - Constructor for class org.elasticsearch.index.query.FQueryFilterParser
 
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() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
free() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
 
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.
freePercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
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(long) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.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, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.FrenchAnalyzerProvider
 
FrenchStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
FrenchStemTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.FrenchStemTokenFilterFactory
 
freq() - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
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, Filter, 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.GeoDistanceRangeFilterBuilder
 
from(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
from(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
from(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
from(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
from(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
from(Object) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
from(int) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
from(long) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
from(float) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
from(double) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
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.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, ClusterName) - Static 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.
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.support.replication.ReplicationType
Constructs the operation type from its internal representation.
fromId(byte) - Static method in enum org.elasticsearch.action.ThreadingModel
 
fromId(byte) - Static method in enum org.elasticsearch.action.WriteConsistencyLevel
 
fromId(int) - Static method in enum org.elasticsearch.cluster.block.ClusterBlockLevel
 
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.facet.datehistogram.DateHistogramFacet.ComparatorType
 
fromId(byte) - Static method in enum org.elasticsearch.search.facet.histogram.HistogramFacet.ComparatorType
 
fromId(byte) - Static method in enum org.elasticsearch.search.facet.terms.TermsFacet.ComparatorType
 
fromId(byte) - Static method in enum org.elasticsearch.search.facet.termsstats.TermsStatsFacet.ComparatorType
 
fromId(byte) - Static method in enum org.elasticsearch.search.suggest.Suggest.Suggestion.Sort
 
fromId(int) - Static method in class org.elasticsearch.Version
 
fromMap(Map<String, Object>) - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom.Factory
 
fromMap(Map<String, Object>) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
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
 
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) - Static method in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction
 
fromRestContentType(String) - Static method in enum org.elasticsearch.common.xcontent.XContentType
 
fromSimilarity(float) - Static method in class org.elasticsearch.common.unit.Fuzziness
Creates a Fuzziness instance from a similarity.
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) - Static method in enum org.elasticsearch.action.search.SearchType
The a string representation search type to execute, defaults to SearchType.DEFAULT.
fromString(String) - Static method in enum org.elasticsearch.action.support.replication.ReplicationType
Parse the replication type from string.
fromString(String) - Static method in enum org.elasticsearch.action.WriteConsistencyLevel
 
fromString(String) - Static method in enum org.elasticsearch.cluster.metadata.IndexMetaData.State
 
fromString(String) - Static method in enum org.elasticsearch.common.geo.GeoDistance
Get a GeoDistance according to a given name.
fromString(String) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
Convert a String to a 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.fs.FsTranslogFile.Type
 
fromString(String) - Static method in enum org.elasticsearch.index.VersionType
 
fromString(String, VersionType) - Static method in enum org.elasticsearch.index.VersionType
 
fromString(String) - Static method in enum org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregatorFactory.ExecutionMode
 
fromString(String) - Static method in enum org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
 
fromString(String) - Static method in enum org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.ComparatorType
 
fromString(String) - Static method in enum org.elasticsearch.search.facet.histogram.HistogramFacet.ComparatorType
 
fromString(String) - Static method in enum org.elasticsearch.search.facet.terms.TermsFacet.ComparatorType
 
fromString(String) - Static method in enum org.elasticsearch.search.facet.termsstats.TermsStatsFacet.ComparatorType
 
fromString(String) - Static method in enum org.elasticsearch.search.MultiValueMode
A case insensitive version of MultiValueMode.valueOf(String)
fromString(String) - Static method in enum org.elasticsearch.transport.TransportRequestOptions.Type
 
fromString(String) - Static method in class org.elasticsearch.Version
Returns the version given its string representation, current version if the argument is null or empty
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.cluster.health.ClusterHealthStatus
 
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
Generate snapshot state from code
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus.Stage
Deprecated.
 
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus.Stage
Deprecated.
 
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus.Stage
Deprecated.
 
fromValue(byte) - Static method in enum org.elasticsearch.cluster.metadata.AliasAction.Type
 
fromValue(byte) - Static method in enum org.elasticsearch.cluster.metadata.RestoreMetaData.State
Returns state corresponding to state code
fromValue(byte) - Static method in enum org.elasticsearch.cluster.metadata.SnapshotMetaData.State
 
fromValue(byte) - Static method in enum org.elasticsearch.cluster.routing.ShardRoutingState
 
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.Factory
 
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 class org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
fromXContent(XContentParser) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData.Factory
fromXContent(XContentParser) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Factory
fromXContent(XContentParser) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Factory
 
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
Reads an AllocationCommand of type T from a XContentParser
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) - Method in class org.elasticsearch.gateway.local.state.meta.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.gateway.CommitPoints
 
fromXContent(XContentParser) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
Parses JSON that represents file info
fromXContent(XContentParser) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
Parses shard snapshot metadata
fromXContent(XContentParser) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Parses the snapshot
fromXContent(XContentParser) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
fromXContent(XContentParser) - Static method in class org.elasticsearch.snapshots.SnapshotShardFailure
Deserializes snapshot failure information from JSON
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, File) - Constructor for class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
FsBlobStore - Class in org.elasticsearch.common.blobstore.fs
 
FsBlobStore(Settings, File) - Constructor for class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
FsChannelSnapshot - Class in org.elasticsearch.index.translog.fs
 
FsChannelSnapshot(long, RafReference, long, int) - Constructor for class org.elasticsearch.index.translog.fs.FsChannelSnapshot
Create a snapshot of translog file channel.
FsDirectoryService - Class in org.elasticsearch.index.store.fs
 
FsDirectoryService(ShardId, Settings, IndexStore) - Constructor for class org.elasticsearch.index.store.fs.FsDirectoryService
 
FsIndexStore - Class in org.elasticsearch.index.store.fs
 
FsIndexStore(Index, Settings, IndexService, IndicesStore, NodeEnvironment) - Constructor for class org.elasticsearch.index.store.fs.FsIndexStore
 
FsProbe - Interface in org.elasticsearch.monitor.fs
 
FsRepository - Class in org.elasticsearch.repositories.fs
Shared file system implementation of the BlobStoreRepository

Shared file system repository supports the following settings locationPath to the root of repository.

FsRepository(RepositoryName, RepositorySettings, IndexShardRepository) - Constructor for class org.elasticsearch.repositories.fs.FsRepository
Constructs new shared file system repository
FsRepositoryModule - Class in org.elasticsearch.repositories.fs
File system repository module
FsRepositoryModule() - Constructor for class org.elasticsearch.repositories.fs.FsRepositoryModule
 
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
 
FsStats - Class in org.elasticsearch.monitor.fs
 
FsStats(long, FsStats.Info[]) - Constructor for class org.elasticsearch.monitor.fs.FsStats
 
FsStats.Info - Class in org.elasticsearch.monitor.fs
 
fsStore() - Method in enum org.elasticsearch.index.store.IndexStoreModule.Type
Returns true iff this store type is a filesystem based store.
FSTBytesAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
 
FSTBytesAtomicFieldData(FST<Long>, Ordinals) - Constructor for class org.elasticsearch.index.fielddata.plain.FSTBytesAtomicFieldData
 
FSTBytesIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
FSTBytesIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
 
FsTranslog - Class in org.elasticsearch.index.translog.fs
 
FsTranslog(ShardId, Settings, IndexSettingsService, BigArrays, IndexStore) - Constructor for class org.elasticsearch.index.translog.fs.FsTranslog
 
FsTranslog(ShardId, Settings, File) - Constructor for class org.elasticsearch.index.translog.fs.FsTranslog
 
FsTranslogFile - Interface in org.elasticsearch.index.translog.fs
 
FsTranslogFile.Type - Enum in org.elasticsearch.index.translog.fs
 
fsync(Path, boolean) - Static method in class org.apache.lucene.util.XIOUtils
Ensure that any writes to the given file is written to the storage device that contains it.
FullEntry(long, long, double, double, long, double) - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
FullEntry(long, long, double, double, long, double) - Constructor for class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet.FullEntry
 
FullHistogramFacetExecutor - Class in org.elasticsearch.search.facet.histogram
A histogram facet collector that uses the same field as the key as well as the value.
FullHistogramFacetExecutor(IndexNumericFieldData, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.FullHistogramFacetExecutor
 
FullHistogramFacetExecutor.HistogramProc - Class in org.elasticsearch.search.facet.histogram
 
fullName() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
 
fullName(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
fullName() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The full name, including dot path.
fullName(String) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
Returns the field mappers based on the mapper full name.
fullName(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns the FieldMappers of all the FieldMappers that are registered under the give fullName across all the different DocumentMapper types.
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
 
FunctionScoreModule - Class in org.elasticsearch.index.query.functionscore
 
FunctionScoreModule() - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreModule
 
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.
functionScoreQuery(FilterBuilder, ScoreFunctionBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that allows to define a custom scoring function.
functionScoreQuery(FilterBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that allows to define a custom scoring function.
functionScoreQuery(QueryBuilder, FilterBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that allows to define a custom scoring function.
functionScoreQuery(QueryBuilder, FilterBuilder, 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(FilterBuilder) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
Creates a function_score query that executes on documents that match query a query.
FunctionScoreQueryBuilder(QueryBuilder, FilterBuilder) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
Creates a function_score query that executes on documents that match query and filter.
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.FuzzyLikeThisFieldQueryBuilder
 
fuzziness(Fuzziness) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
 
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
fuzzyLikeThisFieldQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
A fuzzy like this query that finds documents that are "like" the provided FuzzyLikeThisFieldQueryBuilder.likeText(String).
FuzzyLikeThisFieldQueryBuilder - Class in org.elasticsearch.index.query
 
FuzzyLikeThisFieldQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
A fuzzy more like this query on the provided field.
FuzzyLikeThisFieldQueryParser - Class in org.elasticsearch.index.query
{ fuzzy_like_this_field : { field1 : { maxNumTerms : 12, boost : 1.1, likeText : "..." } }
FuzzyLikeThisFieldQueryParser() - Constructor for class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryParser
 
fuzzyLikeThisQuery(String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
A fuzzy like this query that finds documents that are "like" the provided FuzzyLikeThisQueryBuilder.likeText(String) which is checked against the fields the query is constructed with.
fuzzyLikeThisQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
A fuzzy like this query that finds documents that are "like" the provided FuzzyLikeThisQueryBuilder.likeText(String) which is checked against the "_all" field.
FuzzyLikeThisQueryBuilder - Class in org.elasticsearch.index.query
 
FuzzyLikeThisQueryBuilder() - Constructor for class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
Constructs a new fuzzy like this query which uses the "_all" field.
FuzzyLikeThisQueryBuilder(String...) - Constructor for class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
Sets the field names that will be used when generating the 'Fuzzy Like This' query.
FuzzyLikeThisQueryParser - Class in org.elasticsearch.index.query
{ fuzzy_like_this : { maxNumTerms : 12, boost : 1.1, fields : ["field1", "field2"] likeText : "..." } }
FuzzyLikeThisQueryParser() - Constructor for class org.elasticsearch.index.query.FuzzyLikeThisQueryParser
 
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
 
fuzzyMinSim() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
fuzzyMinSim(float) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
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(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
fuzzyQuery(String, Fuzziness, int, int, boolean) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
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 term 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
 

G

GalicianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
GalicianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GalicianAnalyzerProvider
 
Gateway - Interface in org.elasticsearch.gateway
 
gateway() - Method in class org.elasticsearch.index.IndexService
 
Gateway.GatewayStateRecoveredListener - Interface in org.elasticsearch.gateway
 
GatewayAllocator - Interface in org.elasticsearch.cluster.routing.allocation.allocator
The gateway allocator allows for a pluggable control of the gateway to allocate unassigned shards.
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
 
GatewayModule - Class in org.elasticsearch.gateway
 
GatewayModule(Settings) - Constructor for class org.elasticsearch.gateway.GatewayModule
 
GatewayRecoveryStatus - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
GatewayRecoveryStatus(GatewayRecoveryStatus.Stage, long, long, long, long, long, long) - Constructor for class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
GatewayRecoveryStatus.Stage - Enum in org.elasticsearch.action.admin.indices.status
Deprecated.
 
GatewayService - Class in org.elasticsearch.gateway
 
GatewayService(Settings, Gateway, AllocationService, ClusterService, DiscoveryService, ThreadPool) - Constructor for class org.elasticsearch.gateway.GatewayService
 
GatewaySnapshotStatus - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
GatewaySnapshotStatus(GatewaySnapshotStatus.Stage, long, long, long, int) - Constructor for class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
Deprecated.
 
GatewaySnapshotStatus.Stage - Enum in org.elasticsearch.action.admin.indices.status
Deprecated.
 
gatherAnalysis(BucketCollector.BucketAnalysisCollector, long) - Method in class org.elasticsearch.search.aggregations.Aggregator
 
gatherAnalysis(BucketCollector.BucketAnalysisCollector, long) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
 
gatherAnalysis(BucketCollector.BucketAnalysisCollector, long) - Method in class org.elasticsearch.search.aggregations.BucketCollector
Called post-collection to gather the results from surviving buckets.
gatherAnalysis(BucketCollector.BucketAnalysisCollector, long) - Method in class org.elasticsearch.search.aggregations.FilteringBucketCollector
 
gatherAnalysis(BucketCollector.BucketAnalysisCollector, long) - Method in class org.elasticsearch.search.aggregations.RecordingBucketCollector
 
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
 
gc() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
GcNames - Class in org.elasticsearch.monitor.jvm
 
GcNames() - Constructor for class org.elasticsearch.monitor.jvm.GcNames
 
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 TokenStreams generated with analyzer provide with character terms.
generateUuidIfNeeded() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
generator - Variable in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
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.GeoPointFieldMapper.Defaults
 
GeoBoundingBoxDocSet(int, Bits, MultiGeoPointValues, GeoPoint, GeoPoint) - Constructor for class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.GeoBoundingBoxDocSet
 
geoBoundingBoxFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter based on a bounding box defined by top left and bottom right locations / points
GeoBoundingBoxFilterBuilder - Class in org.elasticsearch.index.query
 
GeoBoundingBoxFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
GeoBoundingBoxFilterParser - Class in org.elasticsearch.index.query
 
GeoBoundingBoxFilterParser() - Constructor for class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
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, long, AggregationContext, Aggregator, ValuesSource.GeoPoint, boolean) - 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
Builder for the GeoBounds aggregation.
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
 
geoDisjointFilter(String, ShapeBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter indexed shapes that are not intersection with the query shape
geoDisjointFilter(String, String, String) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
GeoDistance - Enum in org.elasticsearch.common.geo
Geo distance calculation.
geoDistance(GeoDistance) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
geoDistance(GeoDistance) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
geoDistance() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
geoDistance() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
geoDistance(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new GeoDistance aggregation with the given name.
GeoDistance - Interface in org.elasticsearch.search.aggregations.bucket.range.geodistance
An aggregation that computes ranges of geo distances.
geoDistance(GeoDistance) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The geo distance type used to compute the distance.
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.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.range.geodistance
A range bucket.
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
Basic implementation of GeoDistance.FixedSourceDistance.
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
Builder for the GeoDistance aggregation.
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.
GeoDistanceDocSet(int, Bits, MultiGeoPointValues, GeoDistance.FixedSourceDistance, GeoDistance.DistanceBoundingCheck, double) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceFilter.GeoDistanceDocSet
 
geoDistanceFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
GeoDistanceFacet - Interface in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacet.Entry - Class in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacetBuilder - Class in org.elasticsearch.search.facet.geodistance
A geo distance builder allowing to create a facet of distances from a specific location including the number of hits within each distance range, and aggregated data (like totals of either the distance or cusotm value fields).
GeoDistanceFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
Constructs a new geo distance with the provided facet name.
GeoDistanceFacetExecutor - Class in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacetExecutor(IndexGeoPointFieldData, double, double, DistanceUnit, GeoDistance, GeoDistanceFacet.Entry[], SearchContext) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetExecutor
 
GeoDistanceFacetExecutor.Aggregator - Class in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacetParser - Class in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetParser
 
geoDistanceFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter based on a specific distance from a specific geo location / point.
GeoDistanceFilter - Class in org.elasticsearch.index.search.geo
 
GeoDistanceFilter(double, double, double, GeoDistance, IndexGeoPointFieldData, GeoPointFieldMapper, String) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
GeoDistanceFilter.GeoDistanceDocSet - Class in org.elasticsearch.index.search.geo
 
GeoDistanceFilterBuilder - Class in org.elasticsearch.index.query
 
GeoDistanceFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
GeoDistanceFilterParser - Class in org.elasticsearch.index.query
{ "name.lat" : 1.1, "name.lon" : 1.2, }
GeoDistanceFilterParser() - Constructor for class org.elasticsearch.index.query.GeoDistanceFilterParser
 
GeoDistanceParser - Class in org.elasticsearch.search.aggregations.bucket.range.geodistance
 
GeoDistanceParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceParser
 
GeoDistanceRangeDocSet(int, Bits, MultiGeoPointValues, GeoDistance.FixedSourceDistance, GeoDistance.DistanceBoundingCheck, double, double) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter.GeoDistanceRangeDocSet
 
geoDistanceRangeFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter based on a specific range from a specific geo location / point.
GeoDistanceRangeFilter - Class in org.elasticsearch.index.search.geo
 
GeoDistanceRangeFilter(GeoPoint, Double, Double, boolean, boolean, GeoDistance, GeoPointFieldMapper, IndexGeoPointFieldData, String) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
GeoDistanceRangeFilter.GeoDistanceRangeDocSet - Class in org.elasticsearch.index.search.geo
 
GeoDistanceRangeFilterBuilder - Class in org.elasticsearch.index.query
 
GeoDistanceRangeFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
GeoDistanceRangeFilterParser - Class in org.elasticsearch.index.query
{ "name.lat" : 1.1, "name.lon" : 1.2, }
GeoDistanceRangeFilterParser() - Constructor for class org.elasticsearch.index.query.GeoDistanceRangeFilterParser
 
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.GeoPointFieldMapper.Names
 
geohash(String) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
geohash(String) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
geohash(String) - Method in class org.elasticsearch.index.query.GeohashCellFilter.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(String) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The geohash of the geo point to create the range distance facets from.
GEOHASH_LEVELS - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
 
GEOHASH_SUFFIX - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
geoHashCellFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter based on a bounding box defined by geohash.
geoHashCellFilter(String, String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter based on a bounding box defined by geohash.
geoHashCellFilter(String, GeoPoint) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter based on a bounding box defined by geohash.
geoHashCellFilter(String, String, boolean) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter based on a bounding box defined by geohash.
GeohashCellFilter - Class in org.elasticsearch.index.query
A geohash cell filter that filters GeoPoints by their geohashes.
GeohashCellFilter() - Constructor for class org.elasticsearch.index.query.GeohashCellFilter
 
GeohashCellFilter.Builder - Class in org.elasticsearch.index.query
Builder for a geohashfilter.
GeohashCellFilter.Parser - Class in org.elasticsearch.index.query
 
geoHashCellHeight(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
Calculate the height (in meters) of geohash cells at a specific level
geoHashCellSize(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
Calculate the size (in meters) of geohash cells at a specific level
geoHashCellWidth(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
Calculate the width (in meters) of geohash cells at a specific level
geohashDistance(String) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
 
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.
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, ValuesSource.Numeric, int, int, AggregationContext, Aggregator) - 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.
geoHashPrecision(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
geohashPrefix(boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
geoHashStringMapper() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
GeoHashUtils - Class in org.elasticsearch.common.geo
Utilities for encoding and decoding geohashes.
geoIntersectionFilter(String, ShapeBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter indexed shapes intersecting with shapes
geoIntersectionFilter(String, String, String) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
GeolocationContextMapping - Class in org.elasticsearch.search.suggest.context
The GeolocationContextMapping allows to take GeoInfomation into account during building suggestions.
GeolocationContextMapping(String, int[], boolean, Collection<String>, String) - Constructor for class org.elasticsearch.search.suggest.context.GeolocationContextMapping
Create a new GeolocationContextMapping with a given precision
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(IndexGeoPointFieldData, ValuesSource.MetaData) - 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
 
GeoPointBinaryDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
GeoPointBinaryDVIndexFieldData(Index, FieldMapper.Names, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointBinaryDVIndexFieldData
 
GeoPointBinaryDVIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
 
GeoPointCompressedAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
Field data atomic impl for geo points with lossy compression.
GeoPointCompressedAtomicFieldData() - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointCompressedAtomicFieldData
 
GeoPointCompressedAtomicFieldData.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.
GeoPointCompressedIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
GeoPointCompressedIndexFieldData(Index, Settings, FieldMapper.Names, FieldDataType, IndexFieldDataCache, DistanceUnit.Distance, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointCompressedIndexFieldData
 
GeoPointCompressedIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
 
GeoPointDoubleArrayAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
 
GeoPointDoubleArrayAtomicFieldData() - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayAtomicFieldData
 
GeoPointDoubleArrayAtomicFieldData.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.
GeoPointDoubleArrayIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
GeoPointDoubleArrayIndexFieldData(Index, Settings, FieldMapper.Names, FieldDataType, IndexFieldDataCache, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayIndexFieldData
 
GeoPointDoubleArrayIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
 
geoPointField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
GeoPointFieldMapper - Class in org.elasticsearch.index.mapper.geo
Parsing: We handle:

- "field" : "geo_hash" - "field" : "lat,lon" - "field" : { "lat" : 1.1, "lon" : 2.1 }

GeoPointFieldMapper(FieldMapper.Names, FieldType, Boolean, NamedAnalyzer, NamedAnalyzer, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, Settings, Settings, ContentPath.Type, boolean, boolean, boolean, Integer, int, DoubleFieldMapper, DoubleFieldMapper, StringFieldMapper, boolean, boolean, boolean, boolean, AbstractFieldMapper.MultiFields) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
GeoPointFieldMapper.Builder - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.CustomGeoPointDocValuesField - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.Encoding - Class in org.elasticsearch.index.mapper.geo
A byte-aligned fixed-length encoding for latitudes and longitudes.
GeoPointFieldMapper.Names - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.TypeParser - 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() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
 
GeoPolygonDocIdSet(int, Bits, MultiGeoPointValues, GeoPoint[]) - Constructor for class org.elasticsearch.index.search.geo.GeoPolygonFilter.GeoPolygonDocIdSet
 
geoPolygonFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter based on a polygon defined by a set of locations / points.
GeoPolygonFilter - Class in org.elasticsearch.index.search.geo
 
GeoPolygonFilter(IndexGeoPointFieldData, GeoPoint...) - Constructor for class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
GeoPolygonFilter.GeoPolygonDocIdSet - Class in org.elasticsearch.index.search.geo
 
GeoPolygonFilterBuilder - Class in org.elasticsearch.index.query
 
GeoPolygonFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoPolygonFilterBuilder
 
GeoPolygonFilterParser - Class in org.elasticsearch.index.query
{ "pin.location" : { "points" : [ { "lat" : 12, "lon" : 40}, {} ] } }
GeoPolygonFilterParser() - Constructor for class org.elasticsearch.index.query.GeoPolygonFilterParser
 
geoShapeField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
GeoShapeFieldMapper - Class in org.elasticsearch.index.mapper.geo
FieldMapper for indexing Shapes.
GeoShapeFieldMapper(FieldMapper.Names, SpatialPrefixTree, String, double, ShapeBuilder.Orientation, FieldType, PostingsFormatProvider, DocValuesFormatProvider, AbstractFieldMapper.MultiFields, AbstractFieldMapper.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.Names - Class in org.elasticsearch.index.mapper.geo
 
GeoShapeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.geo
 
geoShapeFilter(String, ShapeBuilder, ShapeRelation) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter based on the relationship of a shape and indexed shapes
geoShapeFilter(String, String, String, ShapeRelation) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
GeoShapeFilterBuilder - Class in org.elasticsearch.index.query
FilterBuilder that builds a GeoShape Filter
GeoShapeFilterBuilder(String, ShapeBuilder) - Constructor for class org.elasticsearch.index.query.GeoShapeFilterBuilder
Creates a new GeoShapeFilterBuilder whose Filter will be against the given field name using the given Shape
GeoShapeFilterBuilder(String, ShapeBuilder, ShapeRelation) - Constructor for class org.elasticsearch.index.query.GeoShapeFilterBuilder
Creates a new GeoShapeFilterBuilder whose Filter will be against the given field name using the given Shape
GeoShapeFilterBuilder(String, String, String, ShapeRelation) - Constructor for class org.elasticsearch.index.query.GeoShapeFilterBuilder
Creates a new GeoShapeFilterBuilder whose Filter will be against the given field name and will use the Shape found with the given ID in the given type
GeoShapeFilterParser - Class in org.elasticsearch.index.query
FilterParser for filtering Documents based on Shapes.
GeoShapeFilterParser() - Constructor for class org.elasticsearch.index.query.GeoShapeFilterParser
 
GeoShapeFilterParser.DEFAULTS - Class in org.elasticsearch.index.query
 
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, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
 
GeoShapeQueryBuilder - Class in org.elasticsearch.index.query
QueryBuilder that builds a GeoShape Query
GeoShapeQueryBuilder(String, ShapeBuilder) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
Creates a new GeoShapeQueryBuilder whose Query will be against the given field name using the given Shape
GeoShapeQueryBuilder(String, String, String) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
Creates a new GeoShapeQueryBuilder whose Query will be against the given field name and will use the Shape found with the given ID in the given type
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
 
geoWithinFilter(String, ShapeBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter indexed shapes that are contained by a shape
geoWithinFilter(String, String, String) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
GermanAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
GermanAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GermanAnalyzerProvider
 
GermanNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
Factory for GermanNormalizationFilter
GermanNormalizationFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GermanNormalizationFilterFactory
 
GermanStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
GermanStemTokenFilterFactory(Index, Settings, 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(GetRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
get(GetRequest, ActionListener<GetResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
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.HashedBytesArray
 
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(long) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
get(long) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
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(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 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(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(int) - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSet
 
get(int) - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.NotBits
 
get(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Returns a setting value based on the setting key.
get(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
get(String[]) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
get(String, String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
get(String[], String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
get(String) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value associated with the setting key.
get(String[]) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value associated with the first setting key.
get(String, String) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value associated with the setting key.
get(String[], String) - Method in interface 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 <e; index <e; 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 <e; index <e; 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.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(QueryParserSettings) - Method in class org.elasticsearch.index.cache.query.parser.none.NoneQueryParserCache
 
get(QueryParserSettings) - Method in interface org.elasticsearch.index.cache.query.parser.QueryParserCache
 
get(QueryParserSettings) - Method in class org.elasticsearch.index.cache.query.parser.resident.ResidentQueryParserCache
 
get() - Method in class org.elasticsearch.index.codec.docvaluesformat.DefaultDocValuesFormatProvider
 
get() - Method in interface org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatProvider
Returns this providers DocValuesFormat instance.
get(String) - Method in class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatService
 
get() - Method in class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider.Factory
 
get() - Method in class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider
 
get() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormatProvider
Deprecated.
 
get() - Method in class org.elasticsearch.index.codec.postingsformat.DefaultPostingsFormatProvider
 
get() - Method in interface org.elasticsearch.index.codec.postingsformat.PostingsFormatProvider
Returns this providers PostingsFormat instance.
get(String) - Method in class org.elasticsearch.index.codec.postingsformat.PostingsFormatService
 
get() - Method in class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider.Factory
 
get() - Method in class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider
 
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 the GeoPoint associated with docID.
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
Returns GetResult based on the specified Engine.GetResult argument.
get(String) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
 
get(Index, String) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionParserMapper
 
get() - Method in class org.elasticsearch.index.settings.IndexSettingsProvider
 
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.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.highlight.Highlighters
 
get(Object) - Method in class org.elasticsearch.search.lookup.DocLookup
 
get(Object) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
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.IndexLookup
 
get(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
get() - Method in class org.elasticsearch.search.suggest.completion.CompletionPostingsFormatProvider
 
get(String) - Method in class org.elasticsearch.search.suggest.Suggesters
 
GET - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
GetAction - Class in org.elasticsearch.action.get
 
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
getActiveOpens() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getActivePrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
getActivePrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
getActiveShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
getActiveShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
getActiveShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
getActiveShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Returns a ImmutableList of active shards
getActualFree() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
getActualTypeArguments() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
 
getActualUsed() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
getAddress() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The address that the node can be communicated with.
getAddress() - Method in class org.elasticsearch.http.HttpInfo
 
getAddress() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
getAddress() - Method in class org.elasticsearch.transport.TransportInfo
 
getAfterUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
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
 
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(GetAliasesRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getAliases(GetAliasesRequest, ActionListener<GetAliasesResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
getAliases() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
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(IndicesAdminClient, 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
 
getAllAvailableAddresses() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
getAllAvailableInterfaces() - Static method in class org.elasticsearch.common.network.NetworkUtils
Returns all the available interfaces, including first level sub interfaces.
getAllEntries() - Method in class org.elasticsearch.common.lucene.all.AllField
Returns the AllEntries containing the original text fields for the document.
getAllNamesIncludedDeprecated() - Method in class org.elasticsearch.common.ParseField
 
getAllStats() - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
 
getAllValidationFailures() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
All the validation failures, including index level validation failures.
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(FieldMapper, MapperService.SmartNameFieldMappers) - 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
 
getArgs(ShapeBuilder, ShapeRelation) - Static method in class org.elasticsearch.index.query.GeoShapeQueryParser
 
getAsArray(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsArray(String, String[]) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsArray(String, String[], Boolean) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsArray(String, String[], Boolean) - Method in interface org.elasticsearch.common.settings.Settings
The values associated with a setting prefix as an array.
getAsArray(String, String[]) - Method in interface org.elasticsearch.common.settings.Settings
The values associated with a setting prefix as an array.
getAsArray(String) - Method in interface 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.ImmutableSettings
 
getAsBoolean(String[], Boolean) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsBoolean(String, Boolean) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as boolean) associated with the setting key.
getAsBoolean(String[], Boolean) - Method in interface 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.ImmutableSettings
 
getAsBytesSize(String[], ByteSizeValue) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsBytesSize(String, ByteSizeValue) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as size) associated with the setting key.
getAsBytesSize(String[], ByteSizeValue) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as size) associated with the setting key.
getAsClass(String, Class<? extends T>) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsClass(String, Class<? extends T>, String, String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsClass(String, Class<? extends T>) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as a class) associated with the setting key.
getAsClass(String, Class<? extends T>, String, String) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as a class) associated with the setting key.
getAsDouble(String, Double) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsDouble(String[], Double) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsDouble(String, Double) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as double) associated with the setting key.
getAsDouble(String[], Double) - Method in interface 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.
getAsFactory(String) - Static method in class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormats
 
getAsFactory(String) - Static method in class org.elasticsearch.index.codec.postingsformat.PostingFormats
 
getAsFloat(String, Float) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsFloat(String[], Float) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsFloat(String, Float) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as float) associated with the setting key.
getAsFloat(String[], Float) - Method in interface 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.ImmutableSettings
 
getAsInt(String[], Integer) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsInt(String, Integer) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as int) associated with the setting key.
getAsInt(String[], Integer) - Method in interface 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.ImmutableSettings
 
getAsLong(String[], Long) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsLong(String, Long) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as long) associated with the setting key.
getAsLong(String[], Long) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as long) associated with the setting key.
getAsMap() - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsMap() - Method in interface 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
Returns the Aggregations keyed by aggregation name.
getAsMap() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
Returns the Aggregations keyed by map.
getAsMemory(String, String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsMemory(String[], String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsMemory(String, String) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as size) associated with the setting key.
getAsMemory(String[], String) - Method in interface 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
 
getAsProvider(String) - Static method in class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormats
 
getAsProvider(String) - Static method in class org.elasticsearch.index.codec.postingsformat.PostingFormats
 
getAsRatio(String, String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsRatio(String[], String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsRatio(String, String) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as a RatioValue) associated with the setting key.
getAsRatio(String[], String) - Method in interface 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.ImmutableSettings
 
getAsSettings(String) - Method in interface 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 ImmutableList of assigned shards
getAsSize(String, SizeValue) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsSize(String[], SizeValue) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsSize(String, SizeValue) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as size) associated with the setting key.
getAsSize(String[], SizeValue) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as size) associated with the setting key.
getAsStructuredMap() - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsStructuredMap() - Method in interface org.elasticsearch.common.settings.Settings
The settings as a structured Map.
getAsTime(String, TimeValue) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsTime(String[], TimeValue) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsTime(String, TimeValue) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as time) associated with the setting key.
getAsTime(String[], TimeValue) - Method in interface 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.ImmutableSettings
 
getAsVersion(String, Version) - Method in interface 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.status.IndexShardStatus
Deprecated.
 
getAt(int) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
Deprecated.
 
getAt(int) - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
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
 
getAttemptFails() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getAttributes() - Method in class org.elasticsearch.action.search.type.ParsedScrollId
 
getAttributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The node attributes.
getAvailable() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
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
 
getBeforeUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
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
 
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
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.
 
getBoost() - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
 
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(CircuitBreaker.Name) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
 
getBreaker(CircuitBreaker.Name) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
getBreaker(CircuitBreaker.Name) - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
 
getBreakIterator(String) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
getBreakIterator(String) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Returns the BreakIterator to use for dividing text into passages.
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 interface org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGrid
 
getBucketByKey(Number) - Method in interface org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGrid
 
getBucketByKey(GeoPoint) - Method in interface org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGrid
 
getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
 
getBucketByKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
 
getBucketByKey(GeoPoint) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
 
getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram
 
getBucketByKey(Number) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram
 
getBucketByKey(DateTime) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram
 
getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
Returns a bucket by the key associated with it.
getBucketByKey(Number) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
Returns a bucket by the key associated with it.
getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
 
getBucketByKey(DateTime) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
 
getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
 
getBucketByKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
 
getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation
The bucket that is associated with the given key.
getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.range.date.DateRange
 
getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistance
 
getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
 
getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4Range
 
getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range
 
getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
 
getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms
 
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.DateHistogram
 
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 interface org.elasticsearch.search.aggregations.bucket.range.date.DateRange
 
getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistance
 
getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
 
getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.range.ipv4.IPv4Range
 
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.
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
Get back fields that have been previously added with ParseContext.Document.addWithKey(Object, IndexableField).
getByMemoryPoolName(String, String) - Static method in class org.elasticsearch.monitor.jvm.GcNames
Resolves the GC type by its memory pool name (MemoryPoolMXBean.getName().
getByPrefix(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getByPrefix(String) - Method in interface 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.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
 
getCacheSize() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getCallbacks() - Method in class org.elasticsearch.common.jna.Kernel32Library
 
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
 
getChannel(String, boolean, MulticastChannel.Config, MulticastChannel.Listener) - Static method in class org.elasticsearch.common.network.MulticastChannel
Builds a channel based on the provided config, allowing to control if sharing a channel that uses the same config is allowed or not.
getChannel() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
getChannel() - Method in class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
 
getChannelEvent() - Method in class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
 
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.
getChronology() - Method in class org.joda.time.base.BaseDateTime
Gets the chronology of the datetime.
getClassLoader() - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getClassLoader() - Method in interface org.elasticsearch.common.settings.Settings
The class loader associated with this settings, or Classes.getDefaultClassLoader() if not set.
getClassLoaderIfSet() - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getClassLoaderIfSet() - Method in interface org.elasticsearch.common.settings.Settings
The class loader associated with this settings, but only if explicitly set, otherwise null.
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.shutdown.NodesShutdownResponse
 
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.NodesOperationResponse
 
getClusterName() - Method in class org.elasticsearch.cluster.ClusterState
 
getClusterNameAsString() - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
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
 
getComparator() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
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(String, BytesRef) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
getCompletionField(ContextMapping.Context, String, BytesRef) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
getComponentSettings(Class) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getComponentSettings(String, Class) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getComponentSettings(Class) - Method in interface org.elasticsearch.common.settings.Settings
Component settings for a specific component.
getComponentSettings(String, Class) - Method in interface org.elasticsearch.common.settings.Settings
Component settings for a specific component.
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
 
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.
getContentLength(String, int) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
getContentLength(String, int) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
 
getContext() - Method in class org.elasticsearch.action.search.type.ParsedScrollId
 
getContext() - Method in class org.elasticsearch.common.ContextHolder
 
getContextMapping() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
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
 
getCoresPerSocket() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getCorrections(TokenStream, CandidateGenerator, float, int, IndexReader, WordScorer, BytesRef, 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
 
getCorsSettingRegex(Settings) - Static method in class org.elasticsearch.rest.support.RestUtils
Determine if CORS setting is a regex
getCount() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
 
getCount() - Method in class org.elasticsearch.action.count.CountResponse
The count of documents matching the query provided.
getCount() - Method in class org.elasticsearch.action.percolate.PercolateResponse
 
getCount() - Method in class org.elasticsearch.common.io.stream.NoopStreamOutput
Retrieve the number of bytes that have been written
getCount() - Method in class org.elasticsearch.index.engine.SegmentsStats
The the segments count.
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
 
getCount() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The number of hits that fall within that key "range" or "interval".
getCount() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
getCount() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
getCount() - Method in interface org.elasticsearch.search.facet.filter.FilterFacet
The count of the facet.
getCount() - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
The count of the facet.
getCount() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
getCount() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The number of hits that fall within that key "range" or "interval".
getCount() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet.CountEntry
 
getCount() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet.FullEntry
 
getCount() - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
getCount() - Method in interface org.elasticsearch.search.facet.query.QueryFacet
The count of the facet.
getCount() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getCount() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getCount() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The number of values counted.
getCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.TermEntry
 
getCount() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet.Entry
 
getCount() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
getCount() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
getCount() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
getCount() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
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.os.OsInfo
 
getCpu() - Method in class org.elasticsearch.monitor.os.OsStats
 
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.
getCpus() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
 
getCreationDate() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
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
 
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
 
getCurrentVersion() - Method in exception org.elasticsearch.index.engine.VersionConflictEngineException
 
getCurrEstab() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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
 
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
 
getDate() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
 
getDateTimeFormatterParser(FormatDateTimeFormatter, DateTimeZone) - Static method in class org.elasticsearch.common.joda.DateMathParser
Get a DateTimeFormatter parser applying timezone if any.
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
 
getDecodingReader(InputStream, Charset) - Static method in class org.apache.lucene.util.XIOUtils
Wrapping the given InputStream in a reader using a CharsetDecoder.
getDecodingReader(Class<?>, String, Charset) - Static method in class org.apache.lucene.util.XIOUtils
Opens a Reader for the given resource using a CharsetDecoder.
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
 
getDefaultClassLoader() - Static method in class org.elasticsearch.common.Classes
Return the default ClassLoader to use: typically the thread context ClassLoader, if available; the ClassLoader that loaded the ClassUtils class will be used as fallback.
getDefaultScoreCombiner() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
 
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.
 
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.action.admin.indices.status.DocsStatus
Deprecated.
The number of deleted docs in the index.
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
Returns a SnapshotDeletionPolicy used in the engines IndexWriter.
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 interface org.elasticsearch.common.inject.spi.ConvertedConstantBinding
Returns a singleton set containing only the converted key.
getDependencies() - Method in interface org.elasticsearch.common.inject.spi.HasDependencies
Returns the known dependencies for this type.
getDependencies() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
Returns the dependencies for this injection point.
getDependency() - Method in class org.elasticsearch.common.inject.internal.InternalContext
 
getDescription() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
getDetailedMessage() - Method in exception org.elasticsearch.ElasticsearchException
Return the detail message, including the message from the nested exception if there is one.
getDev() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
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
 
getDirectSpellChecker(DirectSpellcheckerSettings) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
 
getDiskQueue() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getDiskReads() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getDiskReadSizeInBytes() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getDiskReadSizeSize() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getDiskServiceTime() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getDiskWrites() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getDiskWriteSizeInBytes() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getDiskWriteSizeSize() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getDistancePerDegree() - Method in enum org.elasticsearch.common.unit.DistanceUnit
Measures a longitude in this unit
getDistanceString(int) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionParser.AbstractDistanceScoreFunction
 
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.IndexLookup
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.ApplyAcceptedDocsFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.LimitFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.MatchAllDocsFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.NotFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.OrFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.RegexpFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.ResolvableFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
Returns the a DocIdSetIterator representing the Boolean composition of the filters that have been added.
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.query.ScriptFilterParser.ScriptFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.child.CustomQueryWrappingFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.BytesFieldDataFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.DoublesFieldDataFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.LongsFieldDataFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.nested.NonNestedDocsFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.elasticsearch.search.scan.ScanContext.ScanFilter
 
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.action.admin.indices.status.IndexShardStatus
Deprecated.
 
getDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
 
getDocs() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
Docs level information for the shard index, null if not applicable.
getDocs() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
getDocValuesFormatForField(String) - Method in class org.elasticsearch.index.codec.PerFieldMappingPostingFormatCodec
 
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.
getDuration() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
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
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
 
getEmptyHighlight(String, BreakIterator, int) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Called to summarize a document when no hits were found.
getEndOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
getEndTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
getEntries() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet
An ordered list of histogram facet entries.
getEntries() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
getEntries() - Method in interface org.elasticsearch.search.facet.geodistance.GeoDistanceFacet
An ordered list of geo distance facet entries.
getEntries() - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
getEntries() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet
An ordered list of histogram facet entries.
getEntries() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
getEntries() - Method in interface org.elasticsearch.search.facet.range.RangeFacet
An ordered list of range facet entries.
getEntries() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
getEntries() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet
The terms and counts.
getEntries() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
getEntries() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet
The terms and counts.
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
 
getEstabResets() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getEstimated() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
 
getEvictions() - Method in class org.elasticsearch.index.cache.filter.FilterCacheStats
 
getEvictions() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
 
getEvictions() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
 
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
 
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
 
getExpectedNumberOfOperations() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
Deprecated.
 
getExpectedRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
getExpectedRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
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.
getFacetExecutor() - Method in class org.elasticsearch.search.facet.SearchContextFacets.Entry
 
getFacetName() - Method in class org.elasticsearch.search.facet.SearchContextFacets.Entry
 
getFacets() - Method in class org.elasticsearch.action.percolate.PercolateResponse
 
getFacets() - Method in class org.elasticsearch.action.search.SearchResponse
The search facets.
getFacets() - Method in interface org.elasticsearch.search.facet.Facets
Returns the Facets keyed by facet name.
getFacets() - Method in class org.elasticsearch.search.facet.InternalFacets
Returns the Facets keyed by map.
getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
 
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
 
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.delete.IndexDeleteResponse
The failed number of shards the delete by query was executed on.
getFailedShards() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
The failed number of shards the delete by query was executed on.
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.BroadcastOperationResponse
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.termvector.MultiTermVectorsItemResponse
The failure if relevant.
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.deletebyquery.IndexDeleteByQueryResponse
 
getFetchCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
getFetchCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
getFetchTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
getFetchTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
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.index.search.NumericRangeFieldDataFilter
 
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
 
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
getFieldMappings(GetFieldMappingsRequest, ActionListener<GetFieldMappingsResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getFieldMappings(GetFieldMappingsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
GetFieldMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
 
GetFieldMappingsRequest - Class in org.elasticsearch.action.admin.indices.mapping.get
Request the mappings of specific fields
GetFieldMappingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
 
GetFieldMappingsRequest(GetFieldMappingsRequest) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
 
GetFieldMappingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.get
A helper class to build GetFieldMappingsRequest objects
GetFieldMappingsRequestBuilder(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
 
GetFieldMappingsResponse - Class in org.elasticsearch.action.admin.indices.mapping.get
Response object for GetFieldMappingsRequest API
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
Name of the field used by this 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
 
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.get.GetResponse
 
getFields() - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
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
 
getFieldType(Field) - Method in class org.elasticsearch.common.inject.TypeLiteral
Returns the resolved generic type of field.
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.FilterIndexOutput
 
getFiles() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommit
 
getFilter() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
getFilter() - Method in class org.elasticsearch.common.lucene.search.XConstantScoreQuery
 
getFilter() - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
Returns this FilteredQuery's filter
getFilter() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredTerms
Deprecated.
 
getFilter() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsParametersParser
 
getFilter() - Method in class org.elasticsearch.search.facet.SearchContextFacets.Entry
 
getFilterCache() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
 
getFilterCache() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getFilterCache() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
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
getFirstAddress(NetworkInterface, NetworkUtils.StackType) - Static method in class org.elasticsearch.common.network.NetworkUtils
Returns the first address with the proper ipVersion on the given interface on the current host.
getFirstErrorFailure(CreationException) - Static method in class org.elasticsearch.common.inject.Injectors
 
getFirstNonLoopbackAddress(NetworkUtils.StackType) - Static method in class org.elasticsearch.common.network.NetworkUtils
Returns the first non-loopback address on any interface on the current host.
getFirstNonLoopbackAddress(NetworkInterface, NetworkUtils.StackType) - Static method in class org.elasticsearch.common.network.NetworkUtils
Returns the first non-loopback address on the given interface on the current host.
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.
getFixedBitSetFilter(Filter) - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
getFixedBitSetMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
 
getFixedBitSetMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
Estimation of how much the cached fixed bit sets are taking.
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.termvector.TermVectorRequest
 
getFlush() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getFlush() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
getFlushStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Deprecated.
 
getFlushStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
 
getFlushStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
 
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(FieldMapper<?>) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
 
getForField(FieldMapper<?>) - 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(String) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Returns the PassageFormatter to use for formatting passages into highlighted snippets.
getFragments() - Method in class org.elasticsearch.search.highlight.HighlightField
The highlighted fragments.
getFree() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
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
 
getFreq() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
 
getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
 
getFrom() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
 
getFrom() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
getFrom() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getFromAsDate() - Method in interface org.elasticsearch.search.aggregations.bucket.range.date.DateRange.Bucket
 
getFromAsDate() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.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
 
getFromAsString() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getFromContext(Object) - Method in class org.elasticsearch.common.ContextHolder
 
getFromContext(Object, V) - Method in class org.elasticsearch.common.ContextHolder
 
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
 
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.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
 
getGatewayRecoveryStatus() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
Gateway recovery status (null if not applicable).
getGatewaySnapshotStatus() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
The current on going snapshot to the gateway or the last one if none is on going.
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.Segment
 
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.GeoPointCompressedAtomicFieldData.Single
 
getGeoPointValues() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayAtomicFieldData.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.ImmutableSettings
 
getGroups(String, boolean) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getGroups(String) - Method in interface org.elasticsearch.common.settings.Settings
Returns group settings for the given setting prefix.
getGroups(String, boolean) - Method in interface org.elasticsearch.common.settings.Settings
Returns group settings for the given setting prefix.
getGroupStats() - Method in class org.elasticsearch.index.search.stats.SearchStats
 
getHandler(String) - Method in class org.elasticsearch.transport.TransportService
 
getHeader(String) - Method in class org.elasticsearch.transport.TransportMessage
 
getHeaderMap() - Method in class org.elasticsearch.common.Table
 
getHeaders() - Method in class org.elasticsearch.common.Table
 
getHeaders() - Method in exception org.elasticsearch.ElasticsearchException.WithRestHeaders
 
getHeaders() - Method in interface org.elasticsearch.rest.HasRestHeaders
 
getHeaders() - Method in class org.elasticsearch.rest.RestResponse
Returns custom headers that have been added, or null if none have been set.
getHeaders() - Method in class org.elasticsearch.transport.TransportMessage
 
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
 
getHeapUsedPrecent() - 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
 
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).
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.health.ClusterShardHealth
 
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 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 class org.elasticsearch.action.termvector.MultiTermVectorsItemResponse
The id of the document.
getId() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse.Failure
The id of the action.
getId() - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
getId() - Method in class org.elasticsearch.action.update.UpdateResponse
The id of the document indexed.
getId() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The unique id of the node.
getId() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
getId() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
The shard id.
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.filter.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.
getIdCache() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
 
getIdCache() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getIdCache() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
getIdle() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
getIncludeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
 
getIndex() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
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.status.IndexStatus
Deprecated.
 
getIndex(String) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
Deprecated.
 
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.delete.IndexDeleteResponse
The index the delete by query operation was executed against.
getIndex(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryResponse
The response of a specific index.
getIndex() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
The index the delete by query operation was executed against.
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.BroadcastShardOperationResponse
 
getIndex() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsItemResponse
The index name of the document.
getIndex() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse.Failure
The index name of the action.
getIndex() - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
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(GetIndexRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getIndex(GetIndexRequest, ActionListener<GetIndexResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getIndex() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getIndex() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
getIndex() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
Return the index id
getIndex() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
The index name.
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.filter.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
 
getIndexBalance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
Returns the index related weight factor.
getIndexConcurrency() - Method in class org.elasticsearch.index.engine.EngineConfig
Returns the index concurrency that directly translates into the number of thread states used in the engines IndexWriter.
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(Client) - Constructor for class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequestBuilder
 
GetIndexedScriptResponse - Class in org.elasticsearch.action.indexedscripts.get
The response of a get script action.
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.
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.
getIndexRecoveryProgress() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
getIndexRecoveryProgress() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
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(IndicesAdminClient, 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.IndexLookup
 
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.IndexService
 
getIndexShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
 
getIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
getIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
Deprecated.
 
getIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
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(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequestBuilder
 
GetIndexTemplatesRequestBuilder(IndicesAdminClient, 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
 
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.status.IndicesStatusResponse
Deprecated.
 
getIndices() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryResponse
The responses from all the different indices.
getIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
getIndicesRouting() - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
getIndicesStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
 
getInErrs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getInfos() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsInfo
 
getInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
getInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
getInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
getInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
Number of shards with the snapshot in the initializing stage
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
 
getInSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getInsertOrder() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
 
getInstance() - Static method in class org.elasticsearch.cluster.EmptyClusterInfoService
 
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.common.jna.Kernel32Library
 
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
 
getIpStackType() - Static method in class org.elasticsearch.common.network.NetworkUtils
Tries to determine the type of IP stack from the available interfaces and their addresses and from the system properties (java.net.preferIPv4Stack and java.net.preferIPv6Addresses)
getIPv4Localhost() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
getIPv6Localhost() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
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
 
getIter() - Method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
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.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
 
getKey() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The key value of the histogram.
getKey() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet.CountEntry
 
getKey() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet.FullEntry
 
getKeyAsDate() - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Bucket
 
getKeyAsGeoPoint() - Method in interface org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGrid.Bucket
 
getKeyAsNumber() - Method in interface org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGrid.Bucket
 
getKeyAsNumber() - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram.Bucket
 
getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
 
getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
 
getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTerms.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
 
getKeyAsText() - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters.Bucket
 
getKeyAsText() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
 
getKeyAsText() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
 
getKeyAsText() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
 
getKeyAsText() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
 
getKeyAsText() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.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
 
getLargest() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
getLastEmittedDocPerShard(SearchRequest, ScoreDoc[], int) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
getLastEmittedDocPerShard(ScoreDoc[], int) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
getLastGc() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
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.
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.common.lucene.search.LimitFilter
 
getLimit() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
 
getLimit() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
 
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
 
getLoadAverage() - Method in class org.elasticsearch.monitor.os.OsStats
 
getLoading() - Method in class org.elasticsearch.index.fielddata.FieldDataType
 
getLocalAddress() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
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
 
getLocalhost(NetworkUtils.StackType) - Static method in class org.elasticsearch.common.network.NetworkUtils
 
getLocalHostAddress(String) - Static method in class org.elasticsearch.common.network.NetworkUtils
 
getLocalHostName(String) - Static method in class org.elasticsearch.common.network.NetworkUtils
 
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
getLockID() - Method in class org.elasticsearch.index.store.DistributorDirectory
 
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
Just like Loggers.getLogger(Class,Settings,ShardId,String...) but String loggerName instead of Class.
getLogger(Class, Settings, Index, String...) - Static method in class org.elasticsearch.common.logging.Loggers
 
getLogger(Class, Settings, RiverName, 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, CompletionSuggestionContext) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionTerms
 
getLookup(CompletionFieldMapper, CompletionSuggestionContext) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.LookupFactory
 
getLowerBounds() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
 
getLowerVal() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
getLowFreqMinimumNumberShouldMatchSpec() - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
 
getMacAddress() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
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(GetMappingsRequest, ActionListener<GetMappingsResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getMappings(GetMappingsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequestBuilder
 
GetMappingsResponse - Class in org.elasticsearch.action.admin.indices.mapping.get
 
getMappingTypeToUpdate() - Method in exception org.elasticsearch.action.WriteFailureException
 
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.GarbageCollector.LastGc
 
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 interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The maximum value.
getMax() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
getMax() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
getMax() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
getMax() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The maximum value.
getMax() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet.CountEntry
 
getMax() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet.FullEntry
 
getMax() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getMax() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getMax() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The maximum value.
getMax() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
getMax() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
getMax() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
getMax() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
getMax() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
 
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.admin.indices.status.DocsStatus
Deprecated.
The max doc.
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() - Static method in class org.elasticsearch.monitor.process.JmxProcessProbe
 
getMaxFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessInfo
 
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
getMaxMerges() - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
getMaxMerges() - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
Maximum number of allowed running merges before index throttling kicks in.
getMaxMerges() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
Deprecated.
 
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
 
getMaxUpTime() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
The maximum uptime of a node in the cluster
getMaxWordLen() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getMaxWordLen() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Returns the maximum word length above which words will be ignored.
getMb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
getMbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
getMean() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The mean of this facet interval.
getMean() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
getMean() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
getMean() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
The mean of this facet interval.
getMean() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The mean of this facet interval.
getMean() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet.CountEntry
 
getMean() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet.FullEntry
 
getMean() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
The mean of this facet interval.
getMean() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getMean() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The mean (average) of the values.
getMean() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
getMean() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
getMean() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
getMean() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
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.OsInfo
 
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.filter.FilterCacheStats
 
getMemorySize() - Method in class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
getMemorySize() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
 
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.filter.FilterCacheStats
 
getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.fixedbitset.ShardFixedBitSetFilterCache
 
getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
 
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.
getMergePolicy() - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
getMergePolicy() - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
getMergePolicy() - Method in interface org.elasticsearch.index.merge.policy.MergePolicyProvider
 
getMergePolicy() - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
getMergePolicyProvider() - Method in class org.elasticsearch.index.engine.EngineConfig
Returns the MergePolicyProvider used to obtain a MergePolicy for the engines IndexWriter
getMergeScheduler() - Method in class org.elasticsearch.index.engine.EngineConfig
Returns the MergeSchedulerProvider used to obtain a MergeScheduler for the engines IndexWriter
getMergeStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Deprecated.
Total merges of this shard replication group.
getMergeStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
Total merges of this index.
getMergeStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
Index merge statistics.
getMergeThread(IndexWriter, MergePolicy.OneMerge) - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
getMergeThread(IndexWriter, MergePolicy.OneMerge) - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider.CustomSerialMergeScheduler
Deprecated.
 
getMessage() - Method in exception org.elasticsearch.action.ActionRequestValidationException
 
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.action.termvector.MultiTermVectorsResponse.Failure
The failure message.
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.
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.
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
 
getMhz() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
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 interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The minimum value.
getMin() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
getMin() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
getMin() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
getMin() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The minimum value.
getMin() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet.CountEntry
 
getMin() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet.FullEntry
 
getMin() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getMin() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getMin() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The minimum value.
getMin() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
getMin() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
getMin() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
getMin() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
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.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.
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.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
 
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.
getMissCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
 
getMissingCount() - Method in class org.elasticsearch.index.get.GetStats
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
getMissingCount() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet
The number of docs missing a value.
getMissingCount() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
getMissingCount() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet
The number of docs missing a value.
getMissingTime() - Method in class org.elasticsearch.index.get.GetStats
 
getMissingTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
 
getMode() - Method in class org.elasticsearch.search.facet.SearchContextFacets.Entry
 
getModel() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
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.
getMoreLikeFields() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getMostSpecificCause() - Method in exception org.elasticsearch.ElasticsearchException
Retrieve the most specific cause of this exception, that is, either the innermost cause (root cause) or this exception itself.
getMount() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getMultiValuedSeparator(String) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
getMultiValuedSeparator(String) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Returns the logical separator between values for multi-valued fields.
getName() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
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.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.index.store.VerifyingIndexOutput
Returns the name of the resource to verfiy
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.network.NetworkInfo.Interface
 
getName() - Method in class org.elasticsearch.repositories.RepositoryName
 
getName() - Method in class org.elasticsearch.river.RiverName
 
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 interface org.elasticsearch.search.facet.Facet
The "logical" name of the search facet.
getName() - Method in class org.elasticsearch.search.facet.InternalFacet
 
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 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
 
getNetwork() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
Network level information.
getNetwork() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
Network level statistics.
getNode() - Method in class org.elasticsearch.action.support.nodes.NodeOperationResponse
The node this information relates to.
getNodeDiskUsages() - Method in class org.elasticsearch.cluster.ClusterInfo
 
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.cluster.DiskUsage
 
getNodeId() - Method in class org.elasticsearch.search.SearchShardTarget
 
getNodeName() - Method in class org.elasticsearch.cluster.DiskUsage
 
getNodes() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse
 
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.NodesOperationResponse
 
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
getNodesMap() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
 
getNodesMap() - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
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
 
getNumberOfCommitted() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
 
getNumberOfDataNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
getNumberOfFiles() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
Returns number of files in the snapshot
getNumberOfNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
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.action.admin.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.admin.cluster.health.ClusterIndexHealth
 
getNumberOfShards() - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
 
getNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
getNumDocs() - Method in class org.elasticsearch.action.admin.indices.status.DocsStatus
Deprecated.
The number of docs.
getNumDocs() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
getNumDocs() - Method in class org.elasticsearch.index.engine.Segment
 
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.NumericDVIndexFieldData
 
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
 
getNumMultiValuesDocs() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
Returns the number distinct of document IDs associated with two or more values.
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() - Method in class org.elasticsearch.index.query.support.NestedScope
 
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
 
getOffsetForCurrentValue(String, int) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
getOffsetForCurrentValue(String, int) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
 
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() - Static method in class org.elasticsearch.monitor.process.JmxProcessProbe
 
getOpenFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessStats
 
getOpenIndexOutput(String) - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
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(long, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.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
 
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.FSTBytesAtomicFieldData
 
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
 
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
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
getOtherCount() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet
The count of terms other than the one provided by the entries.
getOutputUnigrams() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
 
getOutputUnigramsIfNoShingles() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
 
getOutRsts() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getOutSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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.
getPackageNameNoDomain(Class<?>) - Static method in class org.elasticsearch.common.Classes
 
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.
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.
getParentObjectMapper() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
getParentReader() - Method in class org.elasticsearch.search.lookup.IndexLookup
 
getParseContext() - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
getPartialValue() - Method in exception org.elasticsearch.common.inject.ConfigurationException
Returns a value that was only partially computed due to this exception.
getPassiveOpens() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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.filter.terms.TermsLookup
 
getPath() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getPattern() - Method in class org.elasticsearch.index.analysis.PatternReplaceCharFilterFactory
 
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
 
getPayloadScore() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
The score for the payload
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
 
getPeerRecoveryStatus() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
Peer recovery status (null if not applicable).
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 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
 
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
 
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
 
getPlugins() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
 
getPlugins() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
 
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
 
getPositionOffsetGap() - 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
 
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
 
getPrimaryBalance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
Returns the primary related weight factor.
getPrimaryInterface() - Method in class org.elasticsearch.monitor.network.NetworkInfo
 
getPrimaryStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Deprecated.
Returns only the primary shards store size in bytes.
getPrimaryStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
Returns only the primary shards store size in bytes.
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
 
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
 
getProfileName() - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
 
getProvidedKey() - Method in interface org.elasticsearch.common.inject.spi.ProviderBinding
Returns the key whose binding is used to provide instances.
getProvidedVersion() - Method in exception org.elasticsearch.index.engine.VersionConflictEngineException
 
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
getPublishTimeout() - Method in class org.elasticsearch.discovery.DiscoverySettings
Returns the current publish timeout
getQuery() - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
Returns this FilteredQuery's (unfiltered) Query
getQuery() - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
getQuery() - Method in class org.elasticsearch.index.search.child.CustomQueryWrappingFilter
returns the inner Query
getQueryCache() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getQueryCache() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
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.filter.terms.TermsLookup
 
getQueryTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
getQueryTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
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
 
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.IndexLookup
 
getReaderFromFile(Environment, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
 
getReclaimed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
getRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
How much of the index has been recovered.
getRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
How much of the index has been recovered.
getRecoveredTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
getRecoveredTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
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.network.NetworkInfo
 
getRefreshInterval() - Method in class org.elasticsearch.monitor.os.OsInfo
 
getRefreshInterval() - Method in class org.elasticsearch.monitor.process.ProcessInfo
 
getRefreshStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Deprecated.
 
getRefreshStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
 
getRefreshStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
Refresh stats.
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
 
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.action.admin.cluster.health.ClusterIndexHealth
 
getRelocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
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.
getRepositories(GetRepositoriesRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
getRepositories(GetRepositoriesRequest, ActionListener<GetRepositoriesResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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(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(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
Creates new get repository request builder
GetRepositoriesRequestBuilder(ClusterAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
Creates new get repository request builder
GetRepositoriesResponse - Class in org.elasticsearch.action.admin.cluster.repositories.get
Get repositories response
getRepository() - Method in class org.elasticsearch.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(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(Client) - Constructor for class org.elasticsearch.action.get.GetRequestBuilder
 
GetRequestBuilder(Client, String) - Constructor for class org.elasticsearch.action.get.GetRequestBuilder
 
getRequests() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
getRequiredSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
getRerouteInterval() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
 
getResident() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
getResponse() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The actual response (IndexResponse or DeleteResponse).
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.termvector.MultiTermVectorsItemResponse
The actual get response, null if its a failure.
getResponse() - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
 
getResponses() - Method in class org.elasticsearch.action.bulk.BulkShardResponse
 
getResponses() - Method in class org.elasticsearch.action.delete.IndexDeleteResponse
 
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.termvector.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
 
getRetransSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getReturnType(Method) - Method in class org.elasticsearch.common.inject.TypeLiteral
Returns the resolved generic return type of method.
getReusedIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
getReusedIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
getRootCause() - Method in exception org.elasticsearch.ElasticsearchException
Retrieve the innermost cause of this exception, if none, returns the current exception.
getRootFailure() - Method in interface org.elasticsearch.action.ActionFuture
The root (possibly) wrapped failure.
getRootFailure() - Method in class org.elasticsearch.action.support.AdapterActionFuture
 
getRootLogger() - Static method in class org.elasticsearch.common.logging.ESLoggerFactory
 
getRouting() - Method in class org.elasticsearch.indices.cache.filter.terms.TermsLookup
 
getRoutingNodes() - Method in class org.elasticsearch.cluster.ClusterState
 
getRoutingTable() - Method in class org.elasticsearch.cluster.ClusterState
 
getRoutingTable() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
getRows() - Method in class org.elasticsearch.common.Table
 
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
 
getScorer(String) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Returns the PassageScorer to use for ranking passages.
getScript() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptResponse
The source of the document (as a string).
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
 
getScriptParameterValue(String) - Method in class org.elasticsearch.script.ScriptParameterParser
 
getScriptValues() - Method in interface org.elasticsearch.index.fielddata.AtomicFieldData
Returns a "scripting" based values.
getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractAtomicOrdinalsFieldData
 
getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVAtomicFieldData
 
getScrollId() - Method in class org.elasticsearch.action.search.SearchResponse
If scrolling was enabled (SearchRequest.scroll(org.elasticsearch.search.Scroll), the scroll id that can be used to continue scrolling.
getScrollIds() - Method in class org.elasticsearch.action.search.ClearScrollRequest
 
getSearch() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getSearch() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
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
 
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
 
getSecureASTCustomizer(Settings, Set<String>) - Static method in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
Returns a customized ASTCustomizer that includes the whitelists and expression checker.
getSecureMungedAddress() - Static method in class org.elasticsearch.common.MacAddressProvider
 
getSegmentCount() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
getSegmentInfo(SegmentInfos) - Method in class org.elasticsearch.index.engine.Engine
 
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
 
getSerializableValue() - Method in enum org.elasticsearch.common.breaker.CircuitBreaker.Name
 
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(GetSettingsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getSettings(GetSettingsRequest, ActionListener<GetSettingsResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
 
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(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
 
GetSettingsResponse - Class in org.elasticsearch.action.admin.indices.settings.get
 
GetSettingsResponse(ImmutableOpenMap<String, Settings>) - 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.BroadcastOperationResponse
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.status.IndexShardStatus
Deprecated.
 
getShardId() - Method in class org.elasticsearch.action.bulk.BulkShardResponse
 
getShardId() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationResponse
 
getShardId() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Returns the shards id
getShardId() - Method in class org.elasticsearch.env.ShardLock
Returns the locks shards Id.
getShardId() - Method in class org.elasticsearch.index.engine.EngineConfig
Returns the engines shard ID
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
 
getShardMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
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.status.ShardStatus
Deprecated.
The shard routing information (cluster wide shard state).
getShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
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.status.IndexShardStatus
Deprecated.
 
getShards() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
A shard id to index shard status map (note, index shard status is the replication shard group that maps to the shard id).
getShards() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
Deprecated.
 
getShards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
getShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Returns a ImmutableList of shards
getShards(ClusterState, String, String, String, String, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
getShards(ClusterState, String, int, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
getShards(ClusterState, String, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
getShards(ClusterState, String, int, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
getShardSize() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
 
getShardSizes() - Method in class org.elasticsearch.cluster.ClusterInfo
 
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
 
getShardsToClearPostAllocationFlag() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
getShare() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
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.
getSnapshots(GetSnapshotsRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
getSnapshots(GetSnapshotsRequest, ActionListener<GetSnapshotsResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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(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(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
Constructs the new get snapshot request
GetSnapshotsRequestBuilder(ClusterAdminClient, 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.action.search.type.ParsedScrollId
 
getSource() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
 
getSource() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
 
getSource() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
 
getSource() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
 
getSource() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
 
getSource() - Method in interface org.elasticsearch.common.inject.spi.Element
Returns an arbitrary object containing information about the "place" where this element was configured.
getSource() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
 
getSource() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
 
getSource() - Method in class org.elasticsearch.common.inject.spi.Message
 
getSource() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
 
getSource() - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
 
getSource() - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
 
getSource() - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
 
getSource() - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
 
getSource() - Method in class org.elasticsearch.index.get.GetResult
 
getSource() - Method in class org.elasticsearch.index.translog.Translog.Create
 
getSource() - Method in class org.elasticsearch.index.translog.Translog.Delete
 
getSource() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
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
 
getSpanScore() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
Returns the SpanScorer score only.
getStage() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
Returns snapshot stage
getStage() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
getStage() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
Deprecated.
 
getStage() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
getStage() - Method in class org.elasticsearch.indices.recovery.RecoveryState
 
getStart() - 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.snapshots.status.SnapshotStats
Returns time when snapshot started
getStartTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
getStartTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
Deprecated.
 
getStartTime() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
getStartTime() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
getStartTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
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.action.admin.indices.status.ShardStatus
Deprecated.
The shard state (index/local state).
getState() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getState(long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
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(CircuitBreaker.Name) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
 
getStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
getStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
getStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
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(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
gets the RecoveryStatus for a given id.
getStatus() - Method in enum org.elasticsearch.rest.RestStatus
 
getStatusSafe(long, ShardId) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
Similar to RecoveriesCollection.getStatus(long) but throws an exception if no recovery is found
getStdDeviation() - Method in interface org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStats
The standard deviation of the collected values.
getStdDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
 
getStdDeviation() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getStdDeviation() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
Standard deviation of the values.
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
 
getStolen() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
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
 
getStoreDirectory(Directory) - Static method in class org.elasticsearch.index.store.DirectoryUtils
Try and extract a store directory out of a directory, tries to take into account the fact that a directory is a filter directory, and/or a compound dir.
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Deprecated.
Returns the full store size in bytes, of both primaries and replicas.
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
Returns the full store size in bytes, of both primaries and replicas.
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
The current size of the shard index storage.
getStrategyName() - Method in enum org.elasticsearch.common.geo.SpatialStrategy
 
getStream() - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
getStream() - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
getStream() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
getSubQuery() - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
getSubQuery() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
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
 
getSuccessfulShards() - Method in class org.elasticsearch.action.delete.IndexDeleteResponse
The successful number of shards the delete by query was executed on.
getSuccessfulShards() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
The successful number of shards the delete by query was executed on.
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.BroadcastOperationResponse
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.
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
 
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
 
getSumOfSquares() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getSumOfSquares() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The sum of squares of the values.
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
 
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.OsInfo
 
getSwap() - Method in class org.elasticsearch.monitor.os.OsStats
 
getSys() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
getSys() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu kernel time.
getSystemProperties() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
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
 
getTaskName() - Method in class org.elasticsearch.common.StopWatch.TaskInfo
Return the name of this task.
getTb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
getTbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
getTcp() - Method in class org.elasticsearch.monitor.network.NetworkStats
 
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(GetIndexTemplatesRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getTemplates(GetIndexTemplatesRequest, ActionListener<GetIndexTemplatesResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.TermEntry
 
getTerm() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet.Entry
 
getTerm() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
getTerm() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
getTermArrays() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
Returns a List of the terms in the multiphrase.
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.TermEntry
 
getTermAsNumber() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet.Entry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
getTermAsNumber() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
getTermVector(TermVectorRequest, String) - Method in class org.elasticsearch.index.termvectors.ShardTermVectorService
 
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
 
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
Returns a thread-pool mainly used to get estimated time stamps from ThreadPool.estimatedTimeInMillis() and to schedule async force merge calls on the ThreadPool.Names.OPTIMIZE thread-pool
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.action.admin.indices.status.GatewayRecoveryStatus
Deprecated.
 
getTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
Deprecated.
 
getTime() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
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 interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The time bucket start (in milliseconds).
getTime() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
getTime() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
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.
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.FsStats
 
getTimestamp() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
getTimestamp() - Method in class org.elasticsearch.monitor.network.NetworkStats
 
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.InternalRange.Bucket
 
getTo() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
 
getTo() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
getTo() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getToAsDate() - Method in interface org.elasticsearch.search.aggregations.bucket.range.date.DateRange.Bucket
 
getToAsDate() - Method in class org.elasticsearch.search.aggregations.bucket.range.date.InternalDateRange.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
 
getToAsString() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getTokenFilterFactory(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenFilters
 
getTokenizerFactory(Version) - Method in enum org.elasticsearch.indices.analysis.PreBuiltTokenizers
 
getTokens() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
 
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.termvector.TermVectorResponse
 
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.termvector.TermVectorResponse
 
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.FsStats
 
getTotal() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getTotal() - Method in class org.elasticsearch.monitor.os.OsInfo.Mem
 
getTotal() - Method in class org.elasticsearch.monitor.os.OsInfo.Swap
 
getTotal() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu time (sum of User and Sys).
getTotal() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The sum / total of the value field that fall within this key "interval".
getTotal() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
getTotal() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
getTotal() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
getTotal() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The sum / total of the value field that fall within this key "interval".
getTotal() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet.CountEntry
 
getTotal() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet.FullEntry
 
getTotal() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getTotal() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getTotal() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The total (sum) of values.
getTotal() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
getTotal() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
getTotal() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
getTotal() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
getTotalBytes() - Method in class org.elasticsearch.cluster.DiskUsage
 
getTotalBytes() - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
 
getTotalCapacity() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
getTotalCores() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getTotalCount() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The total count of values aggregated to compute the total.
getTotalCount() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
getTotalCount() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The total count of values aggregated to compute the total.
getTotalCount() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet.CountEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet.FullEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
getTotalCount() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet
The total count of terms.
getTotalCount() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
getTotalCount() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
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.
getTotalMemory() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
Utility method which computes total memory by adding FieldData, IdCache, 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
 
getTotalShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
Total number of shards
getTotalShards() - Method in class org.elasticsearch.action.delete.IndexDeleteResponse
The total number of shards the delete by query was executed on.
getTotalShards() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
The total number of shards the delete by query was executed on.
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.BroadcastOperationResponse
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
 
getTotalSockets() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
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
 
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.EngineConfig
Returns a instance
getTranslog() - Method in class org.elasticsearch.indices.recovery.RecoveryState
 
getTranslogId() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
The transaction log id.
getTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Deprecated.
 
getTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
 
getTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
The number of transaction operations in the transaction log.
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.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 class org.elasticsearch.action.search.type.ParsedScrollId
 
getType() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsItemResponse
The type of the document.
getType() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse.Failure
The type of the action.
getType() - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
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.indices.breaker.BreakerSettings
 
getType() - Method in class org.elasticsearch.indices.cache.filter.terms.TermsLookup
 
getType() - Method in class org.elasticsearch.indices.recovery.RecoveryState
 
getType() - Method in class org.elasticsearch.repositories.RepositoryName
 
getType() - Method in class org.elasticsearch.river.RiverName
 
getType() - Method in class org.elasticsearch.search.facet.datehistogram.InternalDateHistogramFacet
 
getType() - Method in interface org.elasticsearch.search.facet.Facet
The type of the facet.
getType() - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
getType() - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
getType() - Method in class org.elasticsearch.search.facet.histogram.InternalHistogramFacet
 
getType() - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
getType() - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
getType() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getType() - Method in class org.elasticsearch.search.facet.terms.InternalTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.termsstats.InternalTermsStatsFacet
 
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.threadpool.ThreadPool.Info
 
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.action.admin.cluster.health.ClusterIndexHealth
 
getUnassignedShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
getUniqueTermCount() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
Deprecated.
 
getUpperBounds() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
 
getUpperVal() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
getUptime() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
getUptime() - Method in class org.elasticsearch.monitor.os.OsStats
 
getUrl() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
We compute the URL for sites: "/_plugin/" + name + "/"
getUsableSpace(Directory) - Method in class org.elasticsearch.index.store.distributor.AbstractDistributor
 
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
 
getUsedPercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
getUser() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
getUser() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu user time.
getUserData() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
getUUID() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
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.action.admin.cluster.health.ClusterIndexHealth
 
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 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.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
 
getValues(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
 
getValues(AtomicReaderContext) - 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) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTermsAggregator
 
getValues(ValuesSource.Numeric) - 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
 
getVariance() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getVariance() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
Variance of the values.
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
 
getVendor() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getVersion() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
The current ES version
getVersion() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
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.delete.ShardDeleteResponse
 
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.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.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.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
 
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.
getWarmers(GetWarmersRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
getWarmers(GetWarmersRequest, ActionListener<GetWarmersResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
An that fetches IndexWarmersMetaData for a list or all existing index warmers in the cluster-state
GetWarmersRequest() - Constructor for class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequest
 
GetWarmersRequestBuilder - Class in org.elasticsearch.action.admin.indices.warmer.get
Builder for GetWarmersRequest
GetWarmersRequestBuilder(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequestBuilder
 
GetWarmersResponse - Class in org.elasticsearch.action.admin.indices.warmer.get
Holds a warmer-name to a list of IndexWarmersMetaData mapping for each warmer specified in the GetWarmersRequest.
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, Version) - 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
 
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.
global(boolean) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Should the facet run in global mode (not bounded by the search query) or not (bounded by the search query).
global - Variable in class org.elasticsearch.search.facet.FacetBuilder
 
global(boolean) - Method in class org.elasticsearch.search.facet.FacetBuilder
Marks the facet to run in a global scope, not bounded by any query.
global(boolean) - Method in class org.elasticsearch.search.facet.filter.FilterFacetBuilder
Marks the facet to run in a global scope, not bounded by any query.
global(boolean) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
Marks the facet to run in a global scope, not bounded by any query.
global(boolean) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
Should the facet run in global mode (not bounded by the search query) or not (bounded by the search query).
global(boolean) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
Marks the facet to run in a global scope, not bounded by any query.
global(boolean) - Method in class org.elasticsearch.search.facet.query.QueryFacetBuilder
Marks the facet to run in a global scope, not bounded by any query.
global(boolean) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
Should the facet run in global mode (not bounded by the search query) or not (bounded by the search query).
global(boolean) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
Should the facet run in global mode (not bounded by the search query) or not (bounded by the search query).
global(boolean) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetBuilder
Marks the facet to run in a global scope, not bounded by any query.
global(boolean) - Method in class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
Marks the facet to run in a global scope, not bounded by any query.
global(boolean) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
Should the fact run in global mode (not bounded by the search query) or not.
GlobalAggregator - Class in org.elasticsearch.search.aggregations.bucket.global
 
GlobalAggregator(String, AggregatorFactories, AggregationContext) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
 
GlobalAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.global
 
globalAtomicFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
globalBlockedException(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
globalBlockedRaiseException(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
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
 
globalFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
 
globalFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
globalForceSource(boolean) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight
 
globalIfd - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
globalLock() - Method in class org.elasticsearch.common.util.concurrent.KeyedLock.GlobalLockable
Returns a global lock guaranteeing exclusive access to the resource this KeyedLock is guarding.
GlobalLockable() - Constructor for class org.elasticsearch.common.util.concurrent.KeyedLock.GlobalLockable
 
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.FieldData
 
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, FieldMapper.Names, FieldDataType, long) - Constructor for class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
 
GlobalOrdinalsSignificantTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.significant
An global ordinal based implementation of significant terms, based on SignificantStringTermsAggregator.
GlobalOrdinalsSignificantTermsAggregator(String, AggregatorFactories, ValuesSource.Bytes.WithOrdinals.FieldData, long, long, TermsAggregator.BucketCountThresholds, IncludeExclude, AggregationContext, Aggregator, SignificantTermsAggregatorFactory) - 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.FieldData, long, long, Terms.Order, TermsAggregator.BucketCountThresholds, IncludeExclude, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, boolean) - 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
Variant of GlobalOrdinalsStringTermsAggregator that rebases hashes in order to make them dense.
globalOrdinalsValues(String) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
 
globalOrdinalsValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
globalOrdinalsValues() - 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
 
globalSettings() - Method in class org.elasticsearch.river.RiverSettings
 
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, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GreekAnalyzerProvider
 
GROOVY_SANDBOX_CLASS_WHITELIST - Static variable in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
 
GROOVY_SANDBOX_METHOD_BLACKLIST - Static variable in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
 
GROOVY_SANDBOX_PACKAGE_WHITELIST - Static variable in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
 
GROOVY_SCRIPT_BLACKLIST_PATCH - Static variable in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
GROOVY_SCRIPT_SANDBOX_ENABLED - Static variable in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
GROOVY_SCRIPT_SANDBOX_RECEIVER_WHITELIST - Static variable in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
 
GroovySandboxExpressionChecker - Class in org.elasticsearch.script.groovy
Class used to determine whether a Groovy expression should be allowed.
GroovySandboxExpressionChecker(Settings, Set<String>) - Constructor for class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
 
GroovyScript(Script, ESLogger) - Constructor for class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
GroovyScript(Script, SearchLookup, ESLogger) - Constructor for class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
GroovyScriptCompilationException - Exception in org.elasticsearch.script.groovy
Exception used to wrap groovy script compilation exceptions so they are correctly serialized between nodes.
GroovyScriptCompilationException(String) - Constructor for exception org.elasticsearch.script.groovy.GroovyScriptCompilationException
 
GroovyScriptEngineService - Class in org.elasticsearch.script.groovy
Provides the infrastructure for Groovy as a scripting language for Elasticsearch
GroovyScriptEngineService(Settings) - Constructor for class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
GroovyScriptEngineService.GroovyScript - Class in org.elasticsearch.script.groovy
 
GroovyScriptExecutionException - Exception in org.elasticsearch.script.groovy
Exception used to wrap groovy script execution exceptions so they are correctly serialized between nodes.
GroovyScriptExecutionException(String) - Constructor for exception org.elasticsearch.script.groovy.GroovyScriptExecutionException
 
GroovyScriptExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.script.groovy.GroovyScriptExecutionException
 
group - Variable in class org.elasticsearch.common.network.MulticastChannel.Config
 
group(Map<String, List<Suggest.Suggestion>>, Suggest) - Static method in class org.elasticsearch.search.suggest.Suggest
 
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
 
groupSettings() - Method in class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings
 
groupSettings() - Method in class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings
 
GroupShardsIterator - Class in org.elasticsearch.cluster.routing
This class implements a compilation of ShardIterators.
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
Make sure the SortingBinaryDocValues.values array can store at least SortingBinaryDocValues.count entries.
grow() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
Make sure the SortingNumericDoubleValues.values array can store at least SortingNumericDoubleValues.count entries.
gt(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
gt(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gt(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gt(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gt(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gt(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gt(Object) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
gt(int) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
gt(long) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
gt(float) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
gt(double) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
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.GeoDistanceRangeFilterBuilder
 
gte(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gte(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gte(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gte(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gte(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The from part of the filter query.
gte(Object) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
gte(int) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
gte(long) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
gte(float) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
gte(double) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The from part of the filter query.
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()
Guice - Class in org.elasticsearch.common.inject
The entry point to the Guice framework.

H

h1 - Variable in class org.elasticsearch.common.hash.MurmurHash3.Hash128
 
h2 - Variable in class org.elasticsearch.common.hash.MurmurHash3.Hash128
 
handle(Object, Errors) - Method in interface org.elasticsearch.common.inject.internal.ErrorHandler
Handles an error.
handle(Message) - Method in interface org.elasticsearch.common.inject.internal.ErrorHandler
Handles a user-reported error.
handle(int) - Method in interface org.elasticsearch.common.jna.Kernel32Library.ConsoleCtrlHandler
Handles the Ctrl event.
handle(T) - Method in interface org.elasticsearch.common.util.Callback
 
handleDownstream(ChannelHandlerContext, ChannelEvent) - Method in class org.elasticsearch.http.netty.pipelining.HttpPipeliningHandler
 
HandledTransportAction<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support
A TransportAction that self registers a handler into the transport service
HandledTransportAction(Settings, String, ThreadPool, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
 
handleException(TransportException) - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
 
handleException(TransportException) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
 
handleException(TransportException) - Method in class org.elasticsearch.transport.PlainTransportFuture
 
handleException(TransportException) - Method in interface org.elasticsearch.transport.TransportResponseHandler
 
handleMergeException(Throwable) - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
handleMergeException(Throwable) - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider.CustomSerialMergeScheduler
Deprecated.
 
handleParsedResponse(TransportResponse, TransportResponseHandler) - Method in class org.elasticsearch.transport.local.LocalTransport
 
handler(String, Version) - Method in class org.elasticsearch.transport.TransportService.Adapter
 
handler(String, Version) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.health.RestClusterHealthAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.node.hotthreads.RestNodesHotThreadsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.node.info.RestNodesInfoAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.node.restart.RestNodesRestartAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.node.shutdown.RestNodesShutdownAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.node.stats.RestNodesStatsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.repositories.delete.RestDeleteRepositoryAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.repositories.get.RestGetRepositoriesAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.repositories.put.RestPutRepositoryAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.repositories.verify.RestVerifyRepositoryAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.reroute.RestClusterRerouteAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.settings.RestClusterGetSettingsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.settings.RestClusterUpdateSettingsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.shards.RestClusterSearchShardsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.snapshots.create.RestCreateSnapshotAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.snapshots.delete.RestDeleteSnapshotAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.snapshots.get.RestGetSnapshotsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.snapshots.restore.RestRestoreSnapshotAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.snapshots.status.RestSnapshotsStatusAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.state.RestClusterStateAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.stats.RestClusterStatsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.cluster.tasks.RestPendingClusterTasksAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.alias.delete.RestIndexDeleteAliasesAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.alias.get.RestGetAliasesAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.alias.get.RestGetIndicesAliasesAction
Deprecated.
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.alias.head.RestAliasesExistAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.alias.put.RestIndexPutAliasAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.alias.RestIndicesAliasesAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.close.RestCloseIndexAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.create.RestCreateIndexAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.delete.RestDeleteIndexAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.exists.indices.RestIndicesExistsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.exists.types.RestTypesExistsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.flush.RestFlushAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.get.RestGetIndicesAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.mapping.delete.RestDeleteMappingAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.mapping.get.RestGetFieldMappingAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.mapping.get.RestGetMappingAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.mapping.put.RestPutMappingAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.open.RestOpenIndexAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.optimize.RestOptimizeAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.recovery.RestRecoveryAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.refresh.RestRefreshAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.segments.RestIndicesSegmentsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.settings.RestGetSettingsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.settings.RestUpdateSettingsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.stats.RestIndicesStatsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.status.RestIndicesStatusAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.template.delete.RestDeleteIndexTemplateAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.template.get.RestGetIndexTemplateAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.template.head.RestHeadIndexTemplateAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.template.put.RestPutIndexTemplateAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.upgrade.RestUpgradeAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.validate.query.RestValidateQueryAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.warmer.delete.RestDeleteWarmerAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.warmer.get.RestGetWarmerAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.admin.indices.warmer.put.RestPutWarmerAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.bulk.RestBulkAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.cat.RestCatAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.count.RestCountAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.delete.RestDeleteAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.deletebyquery.RestDeleteByQueryAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.exists.RestExistsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.explain.RestExplainAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.get.RestGetAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.get.RestGetSourceAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.get.RestHeadAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.get.RestMultiGetAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.index.RestIndexAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.main.RestMainAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.mlt.RestMoreLikeThisAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.percolate.RestMultiPercolateAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.percolate.RestPercolateAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.script.RestDeleteIndexedScriptAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.script.RestGetIndexedScriptAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.script.RestPutIndexedScriptAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.search.RestClearScrollAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.search.RestSearchAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.suggest.RestSuggestAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.termvector.RestMultiTermVectorsAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.termvector.RestTermVectorAction
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.action.update.RestUpdateAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.BaseRestHandler
 
handleRequest(RestRequest, RestChannel, Client) - Method in class org.elasticsearch.rest.BaseRestHandler
 
handleRequest(RestRequest, RestChannel) - Method in interface org.elasticsearch.rest.RestHandler
 
handleRequest(Channel, StreamInput, long, Version) - Method in class org.elasticsearch.transport.netty.MessageChannelHandler
 
handleResponse(TransportResponse.Empty) - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
 
handleResponse(T) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
 
handleResponse(StreamInput, LocalTransport, TransportResponseHandler) - Method in class org.elasticsearch.transport.local.LocalTransport
 
handleResponse(Channel, StreamInput, TransportResponseHandler) - Method in class org.elasticsearch.transport.netty.MessageChannelHandler
 
handleResponse(V) - Method in class org.elasticsearch.transport.PlainTransportFuture
 
handleResponse(T) - Method in interface org.elasticsearch.transport.TransportResponseHandler
 
handleShardLookup() - Method in class org.elasticsearch.search.internal.InternalSearchHits.StreamContext
 
HandlesStreamInput - Class in org.elasticsearch.common.io.stream
 
HandlesStreamInput(StreamInput) - Constructor for class org.elasticsearch.common.io.stream.HandlesStreamInput
 
HandlesStreamOutput - Class in org.elasticsearch.common.io.stream
 
HandlesStreamOutput(StreamOutput) - Constructor for class org.elasticsearch.common.io.stream.HandlesStreamOutput
 
handleTransportDisconnect(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
handleTransportDisconnect(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
 
handleUpstream(ChannelHandlerContext, ChannelEvent) - Method in class org.elasticsearch.common.netty.OpenChannelsHandler
 
HasAggregations - Interface in org.elasticsearch.search.aggregations
 
hasAlias(String) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
hasAliases(String[], String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
Checks if at least one of the specified aliases exists in the specified concrete indices.
hasAnalyzer(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
 
hasArg(boolean) - Method in class org.elasticsearch.common.cli.CliToolConfig.OptionBuilder
 
hasArray() - Method in class org.elasticsearch.common.bytes.BytesArray
 
hasArray() - Method in interface org.elasticsearch.common.bytes.BytesReference
Is there an underlying byte array for this bytes reference.
hasArray() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
 
hasArray() - Method in class org.elasticsearch.common.bytes.HashedBytesArray
 
hasArray() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
 
hasBinding(Injector, Matcher<Class>) - Static method in class org.elasticsearch.common.inject.Injectors
Returns true if a binding exists for the given matcher
hasBinding(Injector, Class<?>) - Static method in class org.elasticsearch.common.inject.Injectors
Returns true if a binding exists for the given base class
hasBinding(Injector, Key<?>) - Static method in class org.elasticsearch.common.inject.Injectors
Returns true if a binding exists for the given key
hasBytes() - Method in class org.elasticsearch.common.text.BytesText
 
hasBytes() - Method in class org.elasticsearch.common.text.StringAndBytesText
 
hasBytes() - Method in class org.elasticsearch.common.text.StringText
 
hasBytes() - Method in interface org.elasticsearch.common.text.Text
Are bytes available without the need to be converted into bytes when calling Text.bytes().
hasChanges() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
hasChannel(Channel) - Method in class org.elasticsearch.transport.netty.NettyTransport.NodeChannels
 
hasCharFilter(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
 
hasChildFilter(String, QueryBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
Constructs a child filter, with the child type and the query to run against child documents, with the result of the filter being the *parent* documents.
hasChildFilter(String, FilterBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
Constructs a child filter, with the child type and the filter to run against child documents, with the result of the filter being the *parent* documents.
HasChildFilterBuilder - Class in org.elasticsearch.index.query
 
HasChildFilterBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.index.query.HasChildFilterBuilder
 
HasChildFilterBuilder(String, FilterBuilder) - Constructor for class org.elasticsearch.index.query.HasChildFilterBuilder
 
HasChildFilterParser - Class in org.elasticsearch.index.query
 
HasChildFilterParser(InnerHitsQueryParserHelper) - Constructor for class org.elasticsearch.index.query.HasChildFilterParser
 
hasChildQuery(String, QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
Constructs a new NON scoring child query, with the child type and the query to run on the child documents.
HasChildQueryBuilder - Class in org.elasticsearch.index.query
 
HasChildQueryBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.index.query.HasChildQueryBuilder
 
HasChildQueryParser - Class in org.elasticsearch.index.query
 
HasChildQueryParser(InnerHitsQueryParserHelper) - Constructor for class org.elasticsearch.index.query.HasChildQueryParser
 
hasClauses() - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Returns true iff this filter builder has at least one should, must or mustNot clause.
hasClauses() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Returns true iff this query builder has at least one should, must or mustNot clause.
hasConcreteIndex(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
hasConflicts() - Method in class org.elasticsearch.index.mapper.DocumentMapper.MergeResult
Does the merge have conflicts or not?
hasConflicts() - Method in class org.elasticsearch.index.mapper.MergeContext
 
hasContent() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
hasContent() - Method in class org.elasticsearch.rest.RestRequest
 
hasCustomDataPath(Settings) - Static method in class org.elasticsearch.env.NodeEnvironment
 
hasDefaultTimestamp() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
hasDelimiter(BytesRef) - Static method in class org.elasticsearch.index.mapper.Uid
 
HasDependencies - Interface in org.elasticsearch.common.inject.spi
Implemented by bindings, providers and instances that expose their dependencies explicitly.
hasDocMapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
If the smart name was a typed field, with a type that we resolved, will return true.
hasDocMapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameObjectMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
hasDocValues() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
hasDocValues() - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
hasDynamicSetting(String) - Method in class org.elasticsearch.cluster.settings.DynamicSettings
 
hasEnoughMasterNodes(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.elect.ElectMasterService
 
hasErrors() - Method in class org.elasticsearch.common.inject.internal.Errors
 
hasExplanation() - Method in class org.elasticsearch.action.explain.ExplainResponse
 
hasExtensions(File, String...) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
hasFailures() - Method in class org.elasticsearch.action.bulk.BulkResponse
Has anything failed with the execution.
hasFetchSourceContext() - Method in class org.elasticsearch.percolator.PercolateContext
 
hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.SearchContext
 
hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
hasFieldDataFields() - Method in class org.elasticsearch.percolator.PercolateContext
 
hasFieldDataFields() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
hasFieldDataFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
hasFieldDataFields() - Method in class org.elasticsearch.search.internal.SearchContext
 
hasFieldDataFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
hasFieldNames() - Method in class org.elasticsearch.percolator.PercolateContext
 
hasFieldNames() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
hasFieldNames() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
hasFieldNames() - Method in class org.elasticsearch.search.internal.SearchContext
 
hasFieldNames() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
hasGlobal() - Method in class org.elasticsearch.search.facet.SearchContextFacets
Are there global facets that need to be computed on all the docs.
hasGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
hasGlobalBlock(int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
hasGlobalBlock(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
hasGlobalBlock(RestStatus) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
Is there a global block with the provided status?
hash() - Method in class org.elasticsearch.Build
 
hash(String) - Method in class org.elasticsearch.cluster.routing.operation.hash.djb.DjbHashFunction
 
hash(String, String) - Method in class org.elasticsearch.cluster.routing.operation.hash.djb.DjbHashFunction
 
hash(String) - Method in interface org.elasticsearch.cluster.routing.operation.hash.HashFunction
Calculate a hash value for routing
hash(String, String) - Method in interface org.elasticsearch.cluster.routing.operation.hash.HashFunction
Calculate a hash value for routing and its type
hash(String) - Method in class org.elasticsearch.cluster.routing.operation.hash.simple.SimpleHashFunction
 
hash(String, String) - Method in class org.elasticsearch.cluster.routing.operation.hash.simple.SimpleHashFunction
 
hash(String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
hash(String, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
hash - Variable in class org.elasticsearch.common.lucene.HashedBytesRef
 
hash() - Method in class org.elasticsearch.index.store.StoreFileMetaData
Returns a variable length hash of the file represented by this metadata object.
hash128(byte[], int, int, long, MurmurHash3.Hash128) - Static method in enum org.elasticsearch.common.hash.MurmurHash3
Compute the hash of the MurmurHash3_x64_128 hashing function.
Hash128() - Constructor for class org.elasticsearch.common.hash.MurmurHash3.Hash128
 
hash3_x64_128(byte[], int, int, long) - Static method in class org.elasticsearch.common.util.BloomFilter
 
hashCode() - Method in class org.apache.lucene.queries.BlendedTermQuery
 
hashCode() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
hashCode() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmVersion
 
hashCode() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
 
hashCode() - Method in class org.elasticsearch.action.GenericAction
 
hashCode() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
 
hashCode() - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
hashCode() - Method in class org.elasticsearch.cluster.ClusterName
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Id
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Entry
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.SnapshotId
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Entry
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData
 
hashCode() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
hashCode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
hashCode() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
hashCode() - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
hashCode() - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
 
hashCode() - Method in class org.elasticsearch.cluster.routing.RestoreSource
 
hashCode() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
hashCode() - Method in class org.elasticsearch.common.bytes.BytesArray
 
hashCode() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
 
hashCode() - Method in class org.elasticsearch.common.bytes.HashedBytesArray
 
hashCode() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
 
hashCode() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
 
hashCode() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
hashCode() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
 
hashCode() - Method in class org.elasticsearch.common.collect.Tuple
 
hashCode() - Method in class org.elasticsearch.common.compress.CompressedString
 
hashCode() - Method in class org.elasticsearch.common.geo.GeoPoint
 
hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
 
hashCode(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
Returns the hashCode of type.
hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
 
hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
 
hashCode() - Method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
 
hashCode() - Method in class org.elasticsearch.common.inject.Key
 
hashCode() - Method in class org.elasticsearch.common.inject.spi.Dependency
 
hashCode() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
 
hashCode() - Method in class org.elasticsearch.common.inject.spi.Message
 
hashCode() - Method in class org.elasticsearch.common.inject.TypeLiteral
 
hashCode() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
 
hashCode() - Method in class org.elasticsearch.common.lucene.HashedBytesRef
 
hashCode() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.ApplyAcceptedDocsFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.MatchAllDocsFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsQuery
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
Returns a hash code value for this object.
hashCode() - Method in class org.elasticsearch.common.lucene.search.NotFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.OrFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.RegexpFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
Returns a hash code value for this object.
hashCode() - Method in class org.elasticsearch.common.network.MulticastChannel.Config
 
hashCode() - Method in class org.elasticsearch.common.Priority
 
hashCode() - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
hashCode() - Method in class org.elasticsearch.common.text.BytesText
 
hashCode() - Method in class org.elasticsearch.common.text.StringAndBytesText
 
hashCode() - Method in class org.elasticsearch.common.text.StringText
 
hashCode() - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
hashCode() - Method in class org.elasticsearch.common.transport.LocalTransportAddress
 
hashCode() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
hashCode() - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
 
hashCode() - Method in class org.elasticsearch.common.unit.SizeValue
 
hashCode() - Method in class org.elasticsearch.common.unit.TimeValue
 
hashCode(ByteArray) - Method in class org.elasticsearch.common.util.BigArrays
 
hashCode() - Method in class org.elasticsearch.common.util.BloomFilter
 
hashCode() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
hashCode() - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
hashCode() - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
hashCode() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
hashCode() - Method in class org.elasticsearch.index.engine.Segment
 
hashCode() - Method in class org.elasticsearch.index.fielddata.FieldDataType
 
hashCode() - Method in class org.elasticsearch.index.Index
 
hashCode() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
 
hashCode() - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
hashCode() - Method in class org.elasticsearch.index.mapper.Uid
 
hashCode() - Method in class org.elasticsearch.index.query.ScriptFilterParser.ScriptFilter
 
hashCode() - Method in class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
 
hashCode() - Method in class org.elasticsearch.index.search.child.ChildrenQuery
 
hashCode() - Method in class org.elasticsearch.index.search.child.CustomQueryWrappingFilter
 
hashCode() - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
 
hashCode() - Method in class org.elasticsearch.index.search.child.ParentQuery
 
hashCode() - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
hashCode() - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.BytesFieldDataFilter
 
hashCode() - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.DoublesFieldDataFilter
 
hashCode() - Method in class org.elasticsearch.index.search.FieldDataTermsFilter
 
hashCode() - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.LongsFieldDataFilter
 
hashCode() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
hashCode() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
hashCode() - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
 
hashCode() - Method in class org.elasticsearch.index.search.nested.NonNestedDocsFilter
 
hashCode() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
hashCode() - Method in class org.elasticsearch.index.shard.ShardId
 
hashCode() - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache.Key
 
hashCode() - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
 
hashCode() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
 
hashCode() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
hashCode() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
hashCode() - Method in class org.elasticsearch.repositories.RepositoryName
 
hashCode() - Method in class org.elasticsearch.river.RiverName
 
hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
 
hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
 
hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
 
hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
 
hashCode() - Method in class org.elasticsearch.search.aggregations.support.OrderPath.Token
 
hashCode() - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
hashCode() - Method in class org.elasticsearch.search.SearchShardTarget
 
hashCode() - Method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
 
hashCode() - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
 
hashCode() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
 
hashCode() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
hashCode() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
 
hashCode() - Method in class org.elasticsearch.Version
 
hasHeader(String) - Method in class org.elasticsearch.transport.TransportMessage
 
HashedAggregator - Class in org.elasticsearch.search.facet.terms.strings
 
HashedAggregator() - Constructor for class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
HashedAggregator.BytesRefCountIterator - Interface in org.elasticsearch.search.facet.terms.strings
 
HashedBytesArray - Class in org.elasticsearch.common.bytes
A bytes array reference that caches the hash code.
HashedBytesArray(byte[]) - Constructor for class org.elasticsearch.common.bytes.HashedBytesArray
 
HashedBytesRef - Class in org.elasticsearch.common.lucene
A wrapped to BytesRef that also caches the hashCode for it.
HashedBytesRef() - Constructor for class org.elasticsearch.common.lucene.HashedBytesRef
 
HashedBytesRef(String) - Constructor for class org.elasticsearch.common.lucene.HashedBytesRef
 
HashedBytesRef(BytesRef) - Constructor for class org.elasticsearch.common.lucene.HashedBytesRef
 
HashedBytesRef(BytesRef, int) - Constructor for class org.elasticsearch.common.lucene.HashedBytesRef
 
HashedScriptAggregator - Class in org.elasticsearch.search.facet.terms.strings
 
HashedScriptAggregator(ImmutableSet<BytesRef>, Pattern, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.strings.HashedScriptAggregator
 
hashFile(Directory, String) - Static method in class org.elasticsearch.index.store.Store.MetadataSnapshot
Computes a strong hash value for small files.
hashFile(BytesRefBuilder, InputStream, long) - Static method in class org.elasticsearch.index.store.Store.MetadataSnapshot
Computes a strong hash value for small files.
HashFunction - Interface in org.elasticsearch.cluster.routing.operation.hash
Simple hash function interface used for shard routing.
hashMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
hashMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
hashSet - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
hashSet(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
hashShort() - Method in class org.elasticsearch.Build
 
hasInactivePrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
hasInactiveShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
hasInContext(Object) - Method in class org.elasticsearch.common.ContextHolder
Checks if the context contains an entry with the given key
hasIndex(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
hasIndex(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
hasIndex(String) - Method in class org.elasticsearch.indices.IndicesService
 
hasIndexAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
hasIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
hasJoinedOnce() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
true if the node has successfully joined the cluster before, null for nodes with a <1.4.0 version
hasLegacyChecksum() - Method in class org.elasticsearch.index.store.StoreFileMetaData
Returns true iff the checksum is not null and if the file has NOT been written by a Lucene version greater or equal to Lucene 4.8
hasLength(CharSequence) - Static method in class org.elasticsearch.common.Strings
Check that the given CharSequence is neither null nor of length 0.
hasLength(BytesReference) - Static method in class org.elasticsearch.common.Strings
Check that the given BytesReference is neither null nor of length 0 Note: Will return true for a BytesReference that purely consists of whitespace.
hasLength(String) - Static method in class org.elasticsearch.common.Strings
Check that the given String is neither null nor of length 0.
hasLockedKeys() - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
 
hasMapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
Has at least one mapper for the field.
hasMapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameObjectMapper
 
hasMapping(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
 
hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
hasNested() - Method in class org.elasticsearch.index.mapper.MapperService
 
hasNested() - Method in class org.elasticsearch.index.mapper.ObjectMappers
Is one of the object mappers has a nested mapping set?
hasNestedObjects() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
hasNext() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodeIterator
 
hasNext() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodesIterator
 
hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentileRanks.Iter
 
hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles.Iter
 
hasNext() - Method in class org.elasticsearch.search.lookup.PositionIterator
 
hasNodeFile() - Method in class org.elasticsearch.env.NodeEnvironment
 
hasParam(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
hasParam(String) - Method in class org.elasticsearch.rest.RestRequest
 
hasParentBucketAggregator(Aggregator) - Static method in class org.elasticsearch.search.aggregations.Aggregator
Returns whether any of the parent aggregators has Aggregator.BucketAggregationMode.PER_BUCKET as a bucket aggregation mode.
hasParentField() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
 
hasParentFilter(String, QueryBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
Constructs a parent filter, with the parent type and the query to run against parent documents, with the result of the filter being the *child* documents.
hasParentFilter(String, FilterBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
Constructs a parent filter, with the parent type and the filter to run against parent documents, with the result of the filter being the *child* documents.
HasParentFilterBuilder - Class in org.elasticsearch.index.query
Builder for the 'has_parent' filter.
HasParentFilterBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.index.query.HasParentFilterBuilder
 
HasParentFilterBuilder(String, FilterBuilder) - Constructor for class org.elasticsearch.index.query.HasParentFilterBuilder
 
HasParentFilterParser - Class in org.elasticsearch.index.query
 
HasParentFilterParser(InnerHitsQueryParserHelper) - Constructor for class org.elasticsearch.index.query.HasParentFilterParser
 
hasParentQuery(String, QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
Constructs a new NON scoring parent query, with the parent type and the query to run on the parent documents.
HasParentQueryBuilder - Class in org.elasticsearch.index.query
Builder for the 'has_parent' query.
HasParentQueryBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.index.query.HasParentQueryBuilder
 
HasParentQueryParser - Class in org.elasticsearch.index.query
 
HasParentQueryParser(InnerHitsQueryParserHelper) - Constructor for class org.elasticsearch.index.query.HasParentQueryParser
 
hasPartialFields() - Method in class org.elasticsearch.percolator.PercolateContext
 
hasPartialFields() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
hasPartialFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
hasPartialFields() - Method in class org.elasticsearch.search.internal.SearchContext
 
hasPath() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Id
 
hasPath() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
 
hasPath() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
hasPayloads() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
 
hasQuery() - Method in class org.elasticsearch.search.facet.SearchContextFacets
Are there facets that need to be computed on the query hits?
hasRecoveries() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
 
HasRestHeaders - Interface in org.elasticsearch.rest
Classes that carry rest headers should implement this interface.
hasRiverByName(String) - Method in class org.elasticsearch.river.routing.RiversRouting
 
hasScriptFields() - Method in class org.elasticsearch.percolator.PercolateContext
 
hasScriptFields() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
hasScriptFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
hasScriptFields() - Method in class org.elasticsearch.search.internal.SearchContext
 
hasScriptFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
hasSearchAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
hasSearchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
hasShard(int) - Method in class org.elasticsearch.index.IndexService
 
hasString() - Method in class org.elasticsearch.common.text.BytesText
 
hasString() - Method in class org.elasticsearch.common.text.StringAndBytesText
 
hasString() - Method in class org.elasticsearch.common.text.StringText
 
hasString() - Method in interface org.elasticsearch.common.text.Text
Is there a String representation of the text.
hasText(CharSequence) - Static method in class org.elasticsearch.common.Strings
Check whether the given CharSequence has actual text.
hasText(String) - Static method in class org.elasticsearch.common.Strings
Check whether the given String has actual text.
hasTextCharacters() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
hasTextCharacters() - Method in interface org.elasticsearch.common.xcontent.XContentParser
Method that can be used to determine whether calling of textCharacters() would be the most efficient way to access textual content for the event parser currently points to.
hasTokenFilter(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
 
hasTokenizer(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
 
hasType() - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
hasTypes() - Method in class org.elasticsearch.percolator.PercolateContext
 
hasTypes() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
hasTypes() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
hasTypes() - Method in class org.elasticsearch.search.internal.SearchContext
 
hasUnassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
hasUnassignedPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
hasUnassignedShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
hasUncommittedChanges() - Method in class org.elasticsearch.index.engine.Engine
Returns true the internal writer has any uncommitted changes.
hasUncommittedChanges() - Method in class org.elasticsearch.index.engine.InternalEngine
 
hasUncommittedChanges() - Method in class org.elasticsearch.index.engine.ShadowEngine
 
hasVersion() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards
 
hasVersion(long) - Method in class org.elasticsearch.index.gateway.CommitPoints
 
header(String, String...) - Static method in exception org.elasticsearch.ElasticsearchException.WithRestHeaders
 
header(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
header(String) - Method in class org.elasticsearch.rest.RestRequest
 
HEADER_SIZE - Static variable in class org.elasticsearch.transport.netty.NettyHeader
 
Headers - Class in org.elasticsearch.client.support
Client request headers picked up from the client settings.
Headers(Settings) - Constructor for class org.elasticsearch.client.support.Headers
 
headers() - Method in class org.elasticsearch.client.support.Headers
 
headers() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
headers() - Method in class org.elasticsearch.rest.RestRequest
 
health(ClusterHealthRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
The health of the cluster.
health(ClusterHealthRequest, ActionListener<ClusterHealthResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
The health of the cluster.
health(ClusterHealthRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
health(ClusterHealthRequest, ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
heapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
heapInit() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
heapMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
heapMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
returns the maximum heap size.
heapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
heapUsedPercent() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
returns the heap usage in percent.
hear(TypeLiteral<I>, TypeEncounter<I>) - Method in interface org.elasticsearch.common.inject.spi.TypeListener
Invoked when Guice encounters a new type eligible for constructor or members injection.
helpCmd(CliToolConfig.Cmd) - Method in class org.elasticsearch.common.cli.CliTool
 
Helper() - Constructor for class org.elasticsearch.common.bytes.BytesReference.Helper
 
Helper() - Constructor for class org.elasticsearch.common.settings.loader.SettingsLoader.Helper
 
Helper() - Constructor for class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatProvider.Helper
 
Helper() - Constructor for class org.elasticsearch.index.codec.postingsformat.PostingsFormatProvider.Helper
 
HelpPrinter - Class in org.elasticsearch.common.cli
 
HelpPrinter() - Constructor for class org.elasticsearch.common.cli.HelpPrinter
 
HierarchyCircuitBreakerService - Class in org.elasticsearch.indices.breaker
CircuitBreakerService that attempts to redistribute space between breakers if tripped
HierarchyCircuitBreakerService(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
HierarchyCircuitBreakerService.ApplySettings - Class in org.elasticsearch.indices.breaker
 
HIGH - Static variable in class org.elasticsearch.common.Priority
 
highFreqMinimumShouldMatch(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
Sets the minimum number of high frequent query terms that need to match in order to produce a hit when there are no low frequen terms.
highFreqOperator(CommonTermsQueryBuilder.Operator) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
Sets the operator to use for terms with a high document frequency (greater than or equal to CommonTermsQueryBuilder.cutoffFrequency(float).
highlight(String, Query, IndexSearcher, TopDocs) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Highlights the top passages from a single field.
highlight(String, Query, IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Highlights the top-N passages from a single field.
highlight() - Method in class org.elasticsearch.percolator.PercolateContext
 
highlight(SearchContextHighlight) - Method in class org.elasticsearch.percolator.PercolateContext
 
highlight() - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
A static factory method to construct new search highlights.
highlight(HighlightBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Adds highlight to perform as part of the search.
highlight(HighlighterContext) - Method in class org.elasticsearch.search.highlight.FastVectorHighlighter
 
highlight(HighlighterContext) - Method in interface org.elasticsearch.search.highlight.Highlighter
 
highlight(HighlighterContext) - Method in class org.elasticsearch.search.highlight.PlainHighlighter
 
highlight(HighlighterContext) - Method in class org.elasticsearch.search.highlight.PostingsHighlighter
 
highlight() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
highlight(SearchContextHighlight) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
highlight() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
highlight(SearchContextHighlight) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
highlight() - Method in class org.elasticsearch.search.internal.SearchContext
 
highlight(SearchContextHighlight) - Method in class org.elasticsearch.search.internal.SearchContext
 
highlight() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
highlight(SearchContextHighlight) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
highlight(String, String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
Setup highlighting for suggestions.
highlightBuilder() - Method in class org.elasticsearch.index.query.support.BaseInnerHitBuilder
 
highlightBuilder() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsBuilder
 
HighlightBuilder - Class in org.elasticsearch.search.highlight
A builder for search highlighting.
HighlightBuilder() - Constructor for class org.elasticsearch.search.highlight.HighlightBuilder
 
HighlightBuilder.Field - Class in org.elasticsearch.search.highlight
 
highlightDoc(String, BytesRef[], IndexSearcher, int, int) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
highlighter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
Highlighter - Interface in org.elasticsearch.search.highlight
 
HighlighterContext - Class in org.elasticsearch.search.highlight
 
HighlighterContext(String, SearchContextHighlight.Field, FieldMapper<?>, SearchContext, FetchSubPhase.HitContext, HighlighterContext.HighlightQuery) - Constructor for class org.elasticsearch.search.highlight.HighlighterContext
 
HighlighterContext.HighlightQuery - Class in org.elasticsearch.search.highlight
 
HighlighterParseElement - Class in org.elasticsearch.search.highlight
highlight : { tags_schema : "styled", pre_tags : ["tag1", "tag2"], post_tags : ["tag1", "tag2"], order : "score", highlight_filter : true, fields : { field1 : { }, field2 : { fragment_size : 100, number_of_fragments : 2 }, field3 : { number_of_fragments : 5, order : "simple", tags_schema : "styled" }, field4 : { number_of_fragments: 0, pre_tags : ["openingTagA", "openingTagB"], post_tags : ["closingTag"] } } }
HighlighterParseElement() - Constructor for class org.elasticsearch.search.highlight.HighlighterParseElement
 
Highlighters - Class in org.elasticsearch.search.highlight
 
Highlighters(Set<Highlighter>) - Constructor for class org.elasticsearch.search.highlight.Highlighters
 
highlighterType(String) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
Set type of highlighter to use.
highlighterType(String) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
Set type of highlighter to use.
highlighterType() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
highlightField(String, String[], BreakIterator, BytesRef[], int[], List<AtomicReaderContext>, int) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
 
HighlightField - Class in org.elasticsearch.search.highlight
A field highlighted with its highlighted fragments.
HighlightField(String, Text[]) - Constructor for class org.elasticsearch.search.highlight.HighlightField
 
highlightFields(String[], Query, IndexSearcher, TopDocs) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Highlights the top passages from multiple fields.
highlightFields(String[], Query, IndexSearcher, TopDocs, int[]) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Highlights the top-N passages from multiple fields.
highlightFields(String[], Query, IndexSearcher, int[], int[]) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Highlights the top-N passages from multiple fields, for the provided int[] docids.
highlightFields() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
highlightFields(Map<String, HighlightField>) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
highlightFields() - Method in interface org.elasticsearch.search.SearchHit
A map of highlighted fields.
highlightFieldsAsObjects(String[], Query, IndexSearcher, int[], int[]) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
 
highlightFilter(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 
highlightFilter(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
Set this to true when using the highlighterType fast-vector-highlighter and you want to provide highlighting on filter clauses in your query.
highlightFilter() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
highlightFilters - Static variable in class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
 
HighlightModule - Class in org.elasticsearch.search.highlight
 
HighlightModule() - Constructor for class org.elasticsearch.search.highlight.HighlightModule
 
HighlightPhase - Class in org.elasticsearch.search.highlight
 
HighlightPhase(Settings, Highlighters) - Constructor for class org.elasticsearch.search.highlight.HighlightPhase
 
highlightQuery(QueryBuilder) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
Sets a query to use for highlighting this field instead of the search query.
highlightQuery(QueryBuilder) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
Sets a query to be used for highlighting all fields instead of the search query.
HighlightQuery(Query, Query, boolean) - Constructor for class org.elasticsearch.search.highlight.HighlighterContext.HighlightQuery
 
highlightQuery() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
HighlightUtils - Class in org.elasticsearch.search.highlight
 
HindiAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
HindiAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.HindiAnalyzerProvider
 
HindiNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
Factory for HindiNormalizationFilter
HindiNormalizationFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.HindiNormalizationFilterFactory
 
histogram(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new Histogram aggregation with the given name.
Histogram - Interface in org.elasticsearch.search.aggregations.bucket.histogram
A histogram aggregation.
Histogram.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.histogram
A bucket in the histogram where documents fall in
Histogram.Order - Class in org.elasticsearch.search.aggregations.bucket.histogram
A strategy defining the order in which the buckets in this histogram are ordered.
HistogramAggregator - Class in org.elasticsearch.search.aggregations.bucket.histogram
 
HistogramAggregator(String, AggregatorFactories, Rounding, InternalOrder, boolean, long, ExtendedBounds, ValuesSource.Numeric, ValueFormatter, long, InternalHistogram.Factory<?>, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator
 
HistogramAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.histogram
 
HistogramBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
Builder for the Histogram aggregation.
HistogramBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramBuilder
Constructs a new histogram aggregation builder.
histogramFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
HistogramFacet - Interface in org.elasticsearch.search.facet.histogram
Numeric histogram facet.
HistogramFacet.ComparatorType - Enum in org.elasticsearch.search.facet.histogram
 
HistogramFacet.Entry - Interface in org.elasticsearch.search.facet.histogram
 
HistogramFacetBuilder - Class in org.elasticsearch.search.facet.histogram
A facet builder of histogram facets.
HistogramFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
Constructs a new histogram facet with the provided facet logical name.
HistogramFacetParser - Class in org.elasticsearch.search.facet.histogram
 
HistogramFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.histogram.HistogramFacetParser
 
HistogramParser - Class in org.elasticsearch.search.aggregations.bucket.histogram
Parses the histogram request
HistogramParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramParser
 
HistogramProc(long, LongLongOpenHashMap) - Constructor for class org.elasticsearch.search.facet.histogram.CountHistogramFacetExecutor.HistogramProc
 
HistogramProc(long, LongObjectOpenHashMap<InternalFullHistogramFacet.FullEntry>) - Constructor for class org.elasticsearch.search.facet.histogram.FullHistogramFacetExecutor.HistogramProc
 
HistogramProc(long, LongObjectOpenHashMap<InternalFullHistogramFacet.FullEntry>) - Constructor for class org.elasticsearch.search.facet.histogram.ValueHistogramFacetExecutor.HistogramProc
 
HistogramProc(long, SearchScript, LongObjectOpenHashMap<InternalFullHistogramFacet.FullEntry>) - Constructor for class org.elasticsearch.search.facet.histogram.ValueScriptHistogramFacetExecutor.HistogramProc
 
histogramScriptFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
HistogramScriptFacetBuilder - Class in org.elasticsearch.search.facet.histogram
 
HistogramScriptFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
hit() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
hitContext() - Method in class org.elasticsearch.percolator.PercolateContext
 
HitContext() - Constructor for class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
hitContext - Variable in class org.elasticsearch.search.highlight.HighlighterContext
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.explain.ExplainFetchSubPhase
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in interface org.elasticsearch.search.fetch.FetchSubPhase
Executes the hit level phase, with a reader and doc id (note, its a low level reader, and the matching doc).
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsFetchSubPhase
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsFetchSubPhase
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.matchedqueries.MatchedQueriesFetchSubPhase
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsFetchSubPhase
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsFetchSubPhase
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.source.FetchSourceSubPhase
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.version.VersionFetchSubPhase
 
hitExecute(SearchContext, FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.explain.ExplainFetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in interface org.elasticsearch.search.fetch.FetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsFetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsFetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.matchedqueries.MatchedQueriesFetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsFetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsFetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.source.FetchSourceSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.version.VersionFetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
hits(InternalSearchHits) - Method in class org.elasticsearch.search.fetch.FetchSearchResult
 
hits() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
 
hits() - Method in class org.elasticsearch.search.internal.InternalSearchHits
 
hits() - Method in class org.elasticsearch.search.internal.InternalSearchResponse
 
hits() - Method in interface org.elasticsearch.search.SearchHits
The hits of the search request (based on the search type, and from / size provided).
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.fetch.explain.ExplainFetchSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in interface org.elasticsearch.search.fetch.FetchSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsFetchSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsFetchSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.fetch.matchedqueries.MatchedQueriesFetchSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsFetchSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsFetchSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.fetch.source.FetchSourceSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.fetch.version.VersionFetchSubPhase
 
hitsExecute(SearchContext, InternalSearchHit[]) - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.explain.ExplainFetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in interface org.elasticsearch.search.fetch.FetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsFetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsFetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.matchedqueries.MatchedQueriesFetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsFetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsFetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.source.FetchSourceSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.fetch.version.VersionFetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
hls() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
 
hole(BaseLineStringBuilder<?>) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
Add a new hole to the polygon
hole() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
build new hole to the polygon
HOLE_CHARACTER - Static variable in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
 
holes - Variable in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
 
homeFile() - Method in class org.elasticsearch.env.Environment
The home of the installation.
HotThreads - Class in org.elasticsearch.monitor.jvm
 
HotThreads() - Constructor for class org.elasticsearch.monitor.jvm.HotThreads
 
HOUR - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
hours() - Method in class org.elasticsearch.common.unit.TimeValue
 
hours(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
hoursFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
HP - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on HP.
HppcMaps - Class in org.elasticsearch.common.collect
 
HppcMaps.Object - Class in org.elasticsearch.common.collect
 
HppcMaps.Object.Integer - Class in org.elasticsearch.common.collect
 
HtmlStripCharFilterFactory - Class in org.elasticsearch.index.analysis
 
HtmlStripCharFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.HtmlStripCharFilterFactory
 
http() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Should the node HTTP be returned.
http(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Should the node HTTP be returned.
http() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node HTTP be returned.
http(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node HTTP be returned.
HTTP_CORS_ALLOW_ORIGIN_SETTING - Static variable in class org.elasticsearch.rest.support.RestUtils
 
HTTP_ENABLED - Static variable in class org.elasticsearch.node.internal.InternalNode
 
HTTP_JSON_ENABLE - Static variable in class org.elasticsearch.rest.RestController
 
HTTP_SERVER_BOSS_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.netty.NettyTransport
 
HTTP_SERVER_WORKER_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.netty.NettyTransport
 
HttpChannel - Class in org.elasticsearch.http
 
HttpChannel(RestRequest, boolean) - Constructor for class org.elasticsearch.http.HttpChannel
 
HttpChannelPipelineFactory(NettyHttpServerTransport, boolean) - Constructor for class org.elasticsearch.http.netty.NettyHttpServerTransport.HttpChannelPipelineFactory
 
HttpDownloadHelper - Class in org.elasticsearch.common.http.client
 
HttpDownloadHelper() - Constructor for class org.elasticsearch.common.http.client.HttpDownloadHelper
 
HttpDownloadHelper.DownloadProgress - Interface in org.elasticsearch.common.http.client
Interface implemented for reporting progress of downloading.
HttpDownloadHelper.NullProgress - Class in org.elasticsearch.common.http.client
do nothing with progress info
HttpDownloadHelper.VerboseProgress - Class in org.elasticsearch.common.http.client
verbose progress system prints to some output stream
HttpException - Exception in org.elasticsearch.http
 
HttpException(String) - Constructor for exception org.elasticsearch.http.HttpException
 
HttpException(String, Throwable) - Constructor for exception org.elasticsearch.http.HttpException
 
HttpInfo - Class in org.elasticsearch.http
 
HttpInfo(BoundTransportAddress, long) - Constructor for class org.elasticsearch.http.HttpInfo
 
HttpPipeliningHandler - Class in org.elasticsearch.http.netty.pipelining
Implements HTTP pipelining ordering, ensuring that responses are completely served in the same order as their corresponding requests.
HttpPipeliningHandler(int) - Constructor for class org.elasticsearch.http.netty.pipelining.HttpPipeliningHandler
 
HttpRequest - Class in org.elasticsearch.http
 
HttpRequest() - Constructor for class org.elasticsearch.http.HttpRequest
 
HttpRequestHandler - Class in org.elasticsearch.http.netty
 
HttpRequestHandler(NettyHttpServerTransport, boolean) - Constructor for class org.elasticsearch.http.netty.HttpRequestHandler
 
HttpServer - Class in org.elasticsearch.http
 
HttpServer(Settings, Environment, HttpServerTransport, RestController, NodeService) - Constructor for class org.elasticsearch.http.HttpServer
 
HttpServerAdapter - Interface in org.elasticsearch.http
 
httpServerAdapter(HttpServerAdapter) - Method in interface org.elasticsearch.http.HttpServerTransport
 
httpServerAdapter - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
httpServerAdapter(HttpServerAdapter) - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
HttpServerModule - Class in org.elasticsearch.http
 
HttpServerModule(Settings) - Constructor for class org.elasticsearch.http.HttpServerModule
 
HttpServerTransport - Interface in org.elasticsearch.http
 
HttpStats - Class in org.elasticsearch.http
 
HttpStats(long, long) - Constructor for class org.elasticsearch.http.HttpStats
 
humanReadable(boolean) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
humanReadable() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
HungarianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
HungarianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.HungarianAnalyzerProvider
 
HUNSPELL_IGNORE_CASE - Static variable in class org.elasticsearch.indices.analysis.HunspellService
 
HUNSPELL_LAZY_LOAD - Static variable in class org.elasticsearch.indices.analysis.HunspellService
 
HUNSPELL_LOCATION - Static variable in class org.elasticsearch.indices.analysis.HunspellService
 
HunspellService - Class in org.elasticsearch.indices.analysis
Serves as a node level registry for hunspell dictionaries.
HunspellService(Settings, Environment) - Constructor for class org.elasticsearch.indices.analysis.HunspellService
 
HunspellService(Settings, Environment, Map<String, Dictionary>) - Constructor for class org.elasticsearch.indices.analysis.HunspellService
 
HunspellTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
HunspellTokenFilterFactory(Index, Settings, String, Settings, HunspellService) - Constructor for class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
 
HyperLogLogPlusPlus - Class in org.elasticsearch.search.aggregations.metrics.cardinality
Hyperloglog++ counter, implemented based on pseudo code from http://static.googleusercontent.com/media/research.google.com/fr//pubs/archive/40671.pdf and its appendix https://docs.google.com/document/d/1gyjfMHy43U9OWBXxfaeG-3MjGzejW1dlpyMwEYAAWEI/view?fullscreen This implementation is different from the original implementation in that it uses a hash table instead of a sorted list for linear counting.
HyperLogLogPlusPlus(int, BigArrays, long) - Constructor for class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
HyphenationCompoundWordTokenFilterFactory - Class in org.elasticsearch.index.analysis.compound
Uses the HyphenationCompoundWordTokenFilter to decompound tokens based on hyphenation rules.
HyphenationCompoundWordTokenFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.compound.HyphenationCompoundWordTokenFilterFactory
 
hypot(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 

I

IBSimilarityProvider - Class in org.elasticsearch.index.similarity
SimilarityProvider for IBSimilarity.
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 class org.elasticsearch.action.delete.ShardDeleteRequest
 
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 class org.elasticsearch.action.mlt.MoreLikeThisRequest
The id of document to load from which the "like" query will execute with.
id(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The id of document to load from which the "like" query will execute with.
id() - Method in exception org.elasticsearch.action.RoutingMissingException
 
id() - Method in enum org.elasticsearch.action.search.SearchType
The internal id of the type.
id() - Method in enum org.elasticsearch.action.support.replication.ReplicationType
The internal representation of the operation type.
id() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Returns the id of document the term vector is requested for.
id(String) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
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.ImmutableShardRouting
 
id() - Method in interface 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.PrePostRounding
 
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() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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() - 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.fs.BufferingFsTranslogFile
 
id() - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
id() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
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.monitor.process.ProcessInfo
The process id.
id() - Method in class org.elasticsearch.percolator.PercolateContext
 
ID - Static variable in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction.Fields
 
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 enum org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.ComparatorType
 
id() - Method in enum org.elasticsearch.search.facet.histogram.HistogramFacet.ComparatorType
 
id() - Method in enum org.elasticsearch.search.facet.terms.TermsFacet.ComparatorType
 
id() - Method in enum org.elasticsearch.search.facet.termsstats.TermsStatsFacet.ComparatorType
 
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
 
idCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
idCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
idCache - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
idCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
idCache() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
IdCacheStats - Class in org.elasticsearch.index.cache.id
Deprecated.
Id cache has been removed in favor for ParentChildIndexFieldData this class now reports field data memory usage for _parent field.
IdCacheStats() - Constructor for class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
IdCacheStats(long) - Constructor for class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
idCacheStats() - Method in class org.elasticsearch.index.shard.IndexShard
 
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.
IdentityHashSet<E> - Class in org.elasticsearch.common.collect
 
IdentityHashSet() - Constructor for class org.elasticsearch.common.collect.IdentityHashSet
 
IdentityHashSet(Collection<? extends E>) - Constructor for class org.elasticsearch.common.collect.IdentityHashSet
 
IdentityHashSet(int) - Constructor for class org.elasticsearch.common.collect.IdentityHashSet
 
idFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
IdFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
IdFieldMapper() - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
IdFieldMapper(FieldType) - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
IdFieldMapper(String, String, FieldType, Boolean) - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
IdFieldMapper(String, String, float, FieldType, Boolean, String, PostingsFormatProvider, DocValuesFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
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
 
idle() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
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.termvector.MultiTermVectorsRequest
 
ids(String...) - Method in class org.elasticsearch.index.query.IdsFilterBuilder
Adds ids to the filter.
ids(String...) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
Adds ids to the filter.
ids(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
 
idsFilter(String...) - Static method in class org.elasticsearch.index.query.FilterBuilders
Creates a new ids filter with the provided doc/mapping types.
IdsFilterBuilder - Class in org.elasticsearch.index.query
A filter that will return only documents matching specific ids (and a type).
IdsFilterBuilder(String...) - Constructor for class org.elasticsearch.index.query.IdsFilterBuilder
Create an ids filter based on the type.
IdsFilterParser - Class in org.elasticsearch.index.query
 
IdsFilterParser() - Constructor for class org.elasticsearch.index.query.IdsFilterParser
 
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
 
ifconfig() - Method in class org.elasticsearch.monitor.network.JmxNetworkProbe
 
ifconfig() - Method in interface org.elasticsearch.monitor.network.NetworkProbe
 
ifconfig() - Method in class org.elasticsearch.monitor.network.NetworkService
 
ifd - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
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_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
 
ignoreConflicts() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
 
ignoreConflicts(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
 
ignoreConflicts() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
If there is already a mapping definition registered against the type, then it will be merged.
ignoreConflicts(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
If there is already a mapping definition registered against the type, then it will be merged.
ignoreDisable(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
ignoreDisable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
ignoredUnassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
ignoredValue(String, String) - Method in class org.elasticsearch.index.mapper.ParseContext
 
ignoredValue(String) - Method in class org.elasticsearch.index.mapper.ParseContext
 
ignoredValue(String, String) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
ignoredValue(String) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
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
 
IgnoreGatewayRecoveryException - Exception in org.elasticsearch.index.gateway
An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
IgnoreGatewayRecoveryException(ShardId, String) - Constructor for exception org.elasticsearch.index.gateway.IgnoreGatewayRecoveryException
 
IgnoreGatewayRecoveryException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.gateway.IgnoreGatewayRecoveryException
 
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
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
 
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)
IgnoreRecoveryException - Exception in org.elasticsearch.indices.recovery
An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
IgnoreRecoveryException(String) - Constructor for exception org.elasticsearch.indices.recovery.IgnoreRecoveryException
 
IgnoreRecoveryException(String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.IgnoreRecoveryException
 
ignoreReplicaException(Throwable) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
Should an exception be ignored when the operation is performed on the replica.
ignoreReplicas() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
Should the operations be performed on the replicas as well.
ignoreTF(boolean) - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
 
ignoreTF(boolean) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
 
ignoreUnavailable() - Method in class org.elasticsearch.action.support.IndicesOptions
 
ignoreUnmapped(boolean) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
Deprecated.
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
 
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
 
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
 
ImmutableOpenLongMap<VType> - Class in org.elasticsearch.common.collect
An immutable map implementation based on open hash map.
ImmutableOpenLongMap.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
 
ImmutableSettings - Class in org.elasticsearch.common.settings
An immutable implementation of Settings.
ImmutableSettings.Builder - Class in org.elasticsearch.common.settings
A builder allowing to put different settings and then ImmutableSettings.Builder.build() an immutable settings implementation.
ImmutableShardRouting - Class in org.elasticsearch.cluster.routing
ImmutableShardRouting immutably encapsulates information about shard routings like id, state, version, etc.
ImmutableShardRouting(ShardRouting) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ImmutableShardRouting(ShardRouting, long) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ImmutableShardRouting(String, int, String, String, boolean, ShardRoutingState, long) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ImmutableShardRouting(String, int, String, String, RestoreSource, boolean, ShardRoutingState, long) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ImmutableShardRouting(String, int, String, boolean, ShardRoutingState, long) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
IMPL - Static variable in class org.elasticsearch.common.util.BigArraysModule
 
IMPL - Static variable in class org.elasticsearch.indices.breaker.CircuitBreakerModule
 
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.
in - Variable in class org.elasticsearch.client.FilterClient.ClusterAdmin
 
in() - Method in class org.elasticsearch.client.FilterClient.ClusterAdmin
Returns the delegate Client
in - Variable in class org.elasticsearch.client.FilterClient
 
in() - Method in class org.elasticsearch.client.FilterClient
Returns the delegate Client
in - Variable in class org.elasticsearch.client.FilterClient.IndicesAdmin
 
in() - Method in class org.elasticsearch.client.FilterClient.IndicesAdmin
Returns the delegate Client
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
 
in - Variable in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
INACTIVE_SHARD_INDEXING_BUFFER - Static variable in class org.elasticsearch.index.engine.EngineConfig
 
INACTIVE_SHARD_TRANSLOG_BUFFER - Static variable in interface org.elasticsearch.index.translog.Translog
 
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.action.mlt.MoreLikeThisRequest
Whether to include the queried document.
include() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Whether to include the queried document.
include(boolean) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
 
INCLUDE - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
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, int) - 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.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(Pattern, Pattern, Set<BytesRef>, Set<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.Parser - 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.metadata.SnapshotMetaData.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.AbstractFieldMapper.Builder
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
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(Boolean) - Method in interface org.elasticsearch.index.mapper.internal.AllFieldMapper.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
 
includeInAllIfNotSet(Boolean) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
includeInObject() - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
includeInObject() - Method in interface org.elasticsearch.index.mapper.RootMapper
Should the mapper be included in the root ObjectMapper.
includeLower(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
includeLower(boolean) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
Should the lower bound be included or not.
includeLower(boolean) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
Should the lower bound be included or not.
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, FixedBitSetFilter) - Constructor for class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
 
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.partial.PartialFieldsContext.PartialField
 
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.GeoDistanceRangeFilterBuilder
 
includeUpper(boolean) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
Should the upper bound be included or not.
includeUpper(boolean) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
Should the upper bound be included or not.
includeUpper(boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
Should the upper bound be included or not.
increaseRefCount() - Method in class org.elasticsearch.index.translog.fs.RafReference
Increases the ref count, and returns true if it managed to actually increment it.
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() - Method in class jsr166e.LongAdder
Equivalent to add(1).
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.
incrementalFactor(int) - Method in class org.elasticsearch.index.query.TopChildrenQueryBuilder
Sets the incremental factor when the query needs to be re-run in order to fetch more results.
incrementBucketDocCount(long, int) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
Utility method to increment the doc counts of the given bucket (identified by the bucket ordinal)
incrementRecoveredOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
 
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
 
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.mlt.MoreLikeThisRequest
The index to load the document from which the "like" query will run with.
index() - Method in exception org.elasticsearch.action.RoutingMissingException
 
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() - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
index - Variable in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
index() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
index(String) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
index(String) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
index() - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
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.SingleShardOperationRequest
 
index() - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
index(String) - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
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(IndexRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
index(IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
index() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
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() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
index(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
index() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
index(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
index - Variable in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
index() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
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 interface 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(DocumentMapper, Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.Index
 
Index(DocumentMapper, Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long) - Constructor for class org.elasticsearch.index.engine.Engine.Index
 
Index(DocumentMapper, 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.gateway.SnapshotStatus
 
Index() - Constructor for class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
Index - Class in org.elasticsearch.index
 
Index(String) - Constructor for class org.elasticsearch.index.Index
 
index() - Method in interface org.elasticsearch.index.IndexComponent
 
index() - Method in exception org.elasticsearch.index.IndexException
 
index(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
index(boolean) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Builder
 
index() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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.query.QueryParseContext
 
index(Engine.Index) - Method in class org.elasticsearch.index.shard.IndexShard
 
index() - Method in class org.elasticsearch.index.shard.ShardId
 
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_ANALYZER - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
 
INDEX_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.index.engine.EngineConfig
Index setting to control the initial index buffer size.
INDEX_CACHE_QUERY_ENABLED - Static variable in class org.elasticsearch.indices.cache.query.IndicesQueryCache
A setting to enable or disable query caching on an index level.
INDEX_CHECKSUM_ON_MERGE - Static variable in class org.elasticsearch.index.engine.EngineConfig
Index setting to enable / disable checksum checks on merge This setting is realtime updateable.
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.merge.policy.AbstractMergePolicyProvider
 
INDEX_COMPOUND_ON_FLUSH - Static variable in class org.elasticsearch.index.engine.EngineConfig
Index setting for compound file on flush.
INDEX_CONCURRENCY_SETTING - Static variable in class org.elasticsearch.index.engine.EngineConfig
Index setting for index concurrency / number of threadstates in the indexwriter.
INDEX_CONTENT_TYPE - Static variable in class org.elasticsearch.client.Requests
The default content type to use to generate source documents when indexing.
INDEX_DELETED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
 
INDEX_ENGINE_TYPE - Static variable in class org.elasticsearch.index.engine.IndexEngineModule.EngineSettings
 
INDEX_FAIL_ON_CORRUPTION_SETTING - Static variable in class org.elasticsearch.index.engine.EngineConfig
Index setting to enable / disable engine failures on detected index corruptions.
INDEX_FAIL_ON_MERGE_FAILURE_SETTING - Static variable in class org.elasticsearch.index.engine.EngineConfig
Index setting to enable / disable engine failures on merge exceptions.
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.store.support.AbstractIndexStore
 
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.slowlog.ShardSlowLogIndexingService
 
INDEX_INDEXING_SLOWLOG_REFORMAT - Static variable in class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService
 
INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_DEBUG - Static variable in class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService
 
INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_INFO - Static variable in class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService
 
INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_TRACE - Static variable in class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService
 
INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_WARN - Static variable in class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService
 
INDEX_MERGE_POLICY_CALIBRATE_SIZE_BY_DELETES - Static variable in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
INDEX_MERGE_POLICY_CALIBRATE_SIZE_BY_DELETES - Static variable in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
INDEX_MERGE_POLICY_EXPUNGE_DELETES_ALLOWED - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
INDEX_MERGE_POLICY_FLOOR_SEGMENT - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
INDEX_MERGE_POLICY_MAX_MERGE_AT_ONCE - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
INDEX_MERGE_POLICY_MAX_MERGE_AT_ONCE_EXPLICIT - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
INDEX_MERGE_POLICY_MAX_MERGE_DOCS - Static variable in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
INDEX_MERGE_POLICY_MAX_MERGE_DOCS - Static variable in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
INDEX_MERGE_POLICY_MAX_MERGE_SIZE - Static variable in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
INDEX_MERGE_POLICY_MAX_MERGED_SEGMENT - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
INDEX_MERGE_POLICY_MERGE_FACTOR - Static variable in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
INDEX_MERGE_POLICY_MERGE_FACTOR - Static variable in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
INDEX_MERGE_POLICY_MIN_MERGE_DOCS - Static variable in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
INDEX_MERGE_POLICY_MIN_MERGE_SIZE - Static variable in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
INDEX_MERGE_POLICY_RECLAIM_DELETES_WEIGHT - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
INDEX_MERGE_POLICY_SEGMENTS_PER_TIER - Static variable in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
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.mapper.internal.IdFieldMapper.Defaults
 
INDEX_NAME - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
INDEX_NAME - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
 
INDEX_NAME - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
 
INDEX_NAME - Static variable in class org.elasticsearch.index.query.GeoShapeFilterParser.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_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.local.LocalGatewayAllocator
 
INDEX_REFRESH_INTERVAL - Static variable in class org.elasticsearch.index.shard.IndexShard
Controls how frequently we automatically refresh the near-real-time searcher.
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_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.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_REFORMAT - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_DEBUG - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_INFO - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_TRACE - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_WARN - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_DEBUG - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_INFO - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_TRACE - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_WARN - Static variable in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
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.support.AbstractIndexStore
 
INDEX_STORE_THROTTLE_TYPE - Static variable in class org.elasticsearch.index.store.support.AbstractIndexStore
 
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_DISABLE_FLUSH - Static variable in class org.elasticsearch.index.translog.TranslogService
 
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.fs.FsTranslog
 
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
 
indexAction - Variable in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
IndexAlias - Class in org.elasticsearch.index.aliases
 
IndexAlias(String, CompressedString, Filter) - Constructor for class org.elasticsearch.index.aliases.IndexAlias
 
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, Settings, 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
 
indexAnalyzer - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
indexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
indexAnalyzer - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
indexAnalyzer() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
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(Analyzer) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
A smart analyzer used for indexing that takes into account specific analyzers configured per FieldMapper with a custom default analyzer for no explicit field analyzer.
indexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
indexAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
indexAnalyzer() - Method in interface org.elasticsearch.index.mapper.FieldMapper
The analyzer that will be used to index the field.
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
 
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, Settings, FilterCache, QueryParserCache, DocSetCache, FixedBitSetFilterCache) - Constructor for class org.elasticsearch.index.cache.IndexCache
 
indexCache - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
 
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
 
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
 
indexCreated(Settings) - Static method in class org.elasticsearch.Version
Return the Version of Elasticsearch that has been used to create an index given its settings.
indexCreatedVersion() - 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
 
IndexDeleteByQueryResponse - Class in org.elasticsearch.action.deletebyquery
Delete by query response executed on a specific index.
IndexDeleteResponse - Class in org.elasticsearch.action.delete
Delete by query response executed on a specific index.
IndexDynamicSettings - Annotation Type in org.elasticsearch.index.settings
 
IndexDynamicSettingsModule - Class in org.elasticsearch.index.settings
 
IndexDynamicSettingsModule() - Constructor for class org.elasticsearch.index.settings.IndexDynamicSettingsModule
 
INDEXED_SUFFIX - Static variable in class org.elasticsearch.script.ScriptParameterParser
 
IndexedGeoBoundingBoxFilter - Class in org.elasticsearch.index.search.geo
 
IndexedGeoBoundingBoxFilter() - Constructor for class org.elasticsearch.index.search.geo.IndexedGeoBoundingBoxFilter
 
indexedShapeIndex(String) - Method in class org.elasticsearch.index.query.GeoShapeFilterBuilder
Sets the name of the index where the indexed Shape can be found
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.GeoShapeFilterBuilder
Sets the path of the field in the indexed Shape document that has the Shape itself
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.AbstractFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
indexedValueForSearch(Object) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the indexed value used to construct search "values".
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
IndexEngine - Interface in org.elasticsearch.index.engine
An "index" scoped engine that provides some meta engine for the engine, and can be used to store index level data structures that an engine requires.
indexEngine() - Method in class org.elasticsearch.index.query.QueryParseContext
 
IndexEngineModule - Class in org.elasticsearch.index.engine
 
IndexEngineModule(Settings) - Constructor for class org.elasticsearch.index.engine.IndexEngineModule
 
IndexEngineModule.EngineSettings - Class in org.elasticsearch.index.engine
 
IndexException - Exception in org.elasticsearch.index
 
IndexException(Index, String) - Constructor for exception org.elasticsearch.index.IndexException
 
IndexException(Index, String, Throwable) - Constructor for exception org.elasticsearch.index.IndexException
 
IndexException(Index, boolean, String, Throwable) - Constructor for exception org.elasticsearch.index.IndexException
 
indexExists(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
 
IndexFailedEngineException - Exception in org.elasticsearch.index.engine
 
IndexFailedEngineException(ShardId, Engine.Index, Throwable) - 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, IndexLookup) - Constructor for class org.elasticsearch.search.lookup.IndexField
 
IndexFieldData<FD extends AtomicFieldData> - Interface in org.elasticsearch.index.fielddata
Thread-safe utility class that allows to get per-segment values via the IndexFieldData.load(AtomicReaderContext) method.
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
 
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.FieldBased - Class in org.elasticsearch.index.fielddata
The resident field data cache is a *per field* cache that keeps all the values in memory.
IndexFieldDataCache.Listener - Interface in org.elasticsearch.index.fielddata
 
IndexFieldDataCache.None - Class in org.elasticsearch.index.fielddata
 
IndexFieldDataCache.Resident - Class in org.elasticsearch.index.fielddata
 
IndexFieldDataCache.Soft - 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, Settings, IndicesFieldDataCache, CircuitBreakerService, IndicesFieldDataCacheListener) - 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() - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
IndexFieldMapper(String, String) - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
IndexFieldMapper(String, String, float, FieldType, Boolean, EnabledAttributeMapper, PostingsFormatProvider, DocValuesFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
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, IndexLookup, 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.gateway.CommitPoint
 
indexFiles() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
Returns list of files in the shard
IndexGateway - Interface in org.elasticsearch.index.gateway
 
IndexGatewayModule - Class in org.elasticsearch.index.gateway
 
IndexGatewayModule(Settings, Gateway) - Constructor for class org.elasticsearch.index.gateway.IndexGatewayModule
 
IndexGeoPointFieldData - Interface in org.elasticsearch.index.fielddata
Specialization of IndexFieldData for geo points.
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
 
IndexingOperation(DocumentMapper, Term, ParsedDocument, long, VersionType, Engine.Operation.Origin, long, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.IndexingOperation
 
IndexingOperation(DocumentMapper, 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
 
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
Deprecated.
Used for backward comp. since we now use Lucene compressed codec.
indexInput(IndexInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
indexLocations(Index) - Method in class org.elasticsearch.env.NodeEnvironment
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.SearchLookup
 
indexMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
IndexMetaData - Class in org.elasticsearch.cluster.metadata
 
indexMetaData(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
IndexMetaData.Builder - Class in org.elasticsearch.cluster.metadata
 
IndexMetaData.Custom - Interface in org.elasticsearch.cluster.metadata
 
IndexMetaData.Custom.Factory<T extends 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
 
indexMetaDataLock(String) - Method in class org.elasticsearch.cluster.metadata.MetaDataService
 
IndexMissingException - Exception in org.elasticsearch.indices
 
IndexMissingException(Index) - Constructor for exception org.elasticsearch.indices.IndexMissingException
 
IndexModule - Class in org.elasticsearch.index
 
IndexModule(Settings) - Constructor for class org.elasticsearch.index.IndexModule
 
indexModules() - Method in class org.elasticsearch.plugins.AbstractPlugin
Defaults to return an empty list.
indexModules(Settings) - Method in class org.elasticsearch.plugins.AbstractPlugin
Defaults to return an empty list.
indexModules() - Method in interface org.elasticsearch.plugins.Plugin
Per index modules.
indexModules(Settings) - Method in interface org.elasticsearch.plugins.Plugin
Per index modules.
indexModules() - Method in class org.elasticsearch.plugins.PluginsService
 
indexModules(Settings) - Method in class org.elasticsearch.plugins.PluginsService
 
indexName - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
indexName() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The indexed name of the field.
indexName(String) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
Returns the field mappers based on the mapper index name.
indexName - Variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns FieldMappers for all the FieldMappers that are registered under the given indexName across all the different DocumentMapper types.
indexName(String) - Method in class org.elasticsearch.index.query.QueryParseContext
 
indexName(Settings) - Static method in class org.elasticsearch.river.RiverIndexName.Conf
 
indexNameClean() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The cleaned index name, before any "path" modifications performed on it.
IndexNameModule - Class in org.elasticsearch.index
 
IndexNameModule(Index) - Constructor for class org.elasticsearch.index.IndexNameModule
 
IndexNumericFieldData - Interface in org.elasticsearch.index.fielddata
 
IndexNumericFieldData.NumericType - Enum in org.elasticsearch.index.fielddata
 
indexOptions(FieldInfo.IndexOptions) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
indexOptionsSet - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
indexOptionToString(FieldInfo.IndexOptions) - Static method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
IndexOrdinalsFieldData - Interface in org.elasticsearch.index.fielddata
Specialization of IndexFieldData for data that is indexed with ordinals.
IndexParentChildFieldData - Interface in org.elasticsearch.index.fielddata
Soecialization of IndexFieldData for parent/child mappings.
indexPaths(Index) - Method in class org.elasticsearch.env.NodeEnvironment
Returns all data paths excluding custom index paths.
IndexPluginsModule - Class in org.elasticsearch.plugins
 
IndexPluginsModule(Settings, PluginsService) - Constructor for class org.elasticsearch.plugins.IndexPluginsModule
 
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(Index) - Constructor for exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
 
IndexQueryParserModule - Class in org.elasticsearch.index.query
 
IndexQueryParserModule(Settings) - Constructor for class org.elasticsearch.index.query.IndexQueryParserModule
 
IndexQueryParserModule.QueryParsersProcessor - Class in org.elasticsearch.index.query
A custom processor that can be extended to process and bind custom implementations of QueryParserFactory, and FilterParser.
IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings - Class in org.elasticsearch.index.query
 
IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings - Class in org.elasticsearch.index.query
 
IndexQueryParserService - Class in org.elasticsearch.index.query
 
IndexQueryParserService(Index, Settings, IndicesQueriesRegistry, CacheRecycler, ScriptService, AnalysisService, MapperService, IndexCache, IndexFieldDataService, IndexEngine, FixedBitSetFilterCache, SimilarityService, Map<String, QueryParserFactory>, Map<String, FilterParserFactory>) - Constructor for class org.elasticsearch.index.query.IndexQueryParserService
 
indexQueryParserService() - Method in class org.elasticsearch.index.query.QueryParseContext
 
IndexQueryParserService.Defaults - Class in org.elasticsearch.index.query
 
IndexReplicationOperationRequest<T extends IndexReplicationOperationRequest> - Class in org.elasticsearch.action.support.replication
IndexReplicationOperationRequest(String, TimeValue, ReplicationType, WriteConsistencyLevel, String[], IndicesOptions, ActionRequest) - Constructor for class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
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(Client) - Constructor for class org.elasticsearch.action.index.IndexRequestBuilder
 
IndexRequestBuilder(Client, 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
The IndexRoutingTable represents routing information for a single index.
indexRoutingTable(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
IndexRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
 
indexRoutingTableChanged(String) - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
IndexSegments - Class in org.elasticsearch.action.admin.indices.segments
 
IndexService - Class in org.elasticsearch.index
 
IndexService(Injector, Index, Settings, NodeEnvironment, AnalysisService, MapperService, IndexQueryParserService, SimilarityService, IndexAliasesService, IndexCache, IndexEngine, IndexGateway, IndexStore, IndexSettingsService, IndexFieldDataService, FixedBitSetFilterCache, IndicesService) - Constructor for class org.elasticsearch.index.IndexService
 
indexService() - Method in class org.elasticsearch.index.shard.IndexShard
 
indexService - Variable in class org.elasticsearch.index.store.support.AbstractIndexStore
 
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.AbstractPlugin
Defaults to return an empty list.
indexServices() - Method in interface 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
Returns an IndexService for the specified index if exists otherwise a IndexMissingException is thrown.
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.mapper.Mapper.BuilderContext
 
indexSettings() - Method in class org.elasticsearch.index.mapper.ParseContext
 
indexSettings() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
IndexSettings - Annotation Type in org.elasticsearch.index.settings
 
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
 
IndexSettingsProvider - Class in org.elasticsearch.index.settings
A wrapper around the IndexSettingsService allowing to get the current settings associated with an index (thus, allowing to change those settings and new shards will use the new settings).
IndexSettingsProvider(IndexSettingsService) - Constructor for class org.elasticsearch.index.settings.IndexSettingsProvider
 
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, Settings, IndexSettingsService, IndicesLifecycle, Store, MergeSchedulerProvider, Translog, ThreadPool, MapperService, IndexQueryParserService, IndexCache, IndexAliasesService, ShardIndexingService, ShardGetService, ShardSearchService, ShardIndexWarmerService, ShardFilterCache, ShardFieldData, PercolatorQueriesRegistry, ShardPercolateService, CodecService, ShardTermVectorService, IndexFieldDataService, IndexService, ShardSuggestService, ShardQueryCache, ShardFixedBitSetFilterCache, IndicesWarmer, SnapshotDeletionPolicy, AnalysisService, SimilarityService, MergePolicyProvider, EngineFactory, ClusterService) - 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
 
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
 
IndexShardComponent - Interface in org.elasticsearch.index.shard
 
IndexShardCreationException - Exception in org.elasticsearch.index.shard
 
IndexShardCreationException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.shard.IndexShardCreationException
 
IndexShardException - Exception in org.elasticsearch.index.shard
 
IndexShardException(ShardId, String) - Constructor for exception org.elasticsearch.index.shard.IndexShardException
 
IndexShardException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.shard.IndexShardException
 
IndexShardGateway - Interface in org.elasticsearch.index.gateway
 
IndexShardGatewayException - Exception in org.elasticsearch.index.gateway
 
IndexShardGatewayException(ShardId, String) - Constructor for exception org.elasticsearch.index.gateway.IndexShardGatewayException
 
IndexShardGatewayException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.gateway.IndexShardGatewayException
 
IndexShardGatewayModule - Class in org.elasticsearch.index.gateway
 
IndexShardGatewayModule(IndexGateway) - Constructor for class org.elasticsearch.index.gateway.IndexShardGatewayModule
 
IndexShardGatewayRecoveryException - Exception in org.elasticsearch.index.gateway
 
IndexShardGatewayRecoveryException(ShardId, String) - Constructor for exception org.elasticsearch.index.gateway.IndexShardGatewayRecoveryException
 
IndexShardGatewayRecoveryException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.gateway.IndexShardGatewayRecoveryException
 
IndexShardGatewayService - Class in org.elasticsearch.index.gateway
 
IndexShardGatewayService(ShardId, Settings, ThreadPool, IndexShard, IndexShardGateway, IndexShardSnapshotAndRestoreService, ClusterService) - Constructor for class org.elasticsearch.index.gateway.IndexShardGatewayService
 
IndexShardGatewayService.RecoveryListener - Interface in org.elasticsearch.index.gateway
 
IndexShardGatewaySnapshotFailedException - Exception in org.elasticsearch.index.gateway
 
IndexShardGatewaySnapshotFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.gateway.IndexShardGatewaySnapshotFailedException
 
IndexShardGatewaySnapshotNotAllowedException - Exception in org.elasticsearch.index.gateway
 
IndexShardGatewaySnapshotNotAllowedException(ShardId, String) - Constructor for exception org.elasticsearch.index.gateway.IndexShardGatewaySnapshotNotAllowedException
 
IndexShardMissingException - Exception in org.elasticsearch.index
 
IndexShardMissingException(ShardId) - Constructor for exception org.elasticsearch.index.IndexShardMissingException
 
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
 
IndexShardNotStartedException - Exception in org.elasticsearch.index.shard
 
IndexShardNotStartedException(ShardId, IndexShardState) - 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
 
IndexShardRelocatedException - Exception in org.elasticsearch.index.shard
 
IndexShardRelocatedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
 
IndexShardRepository - Interface in org.elasticsearch.index.snapshots
Shard-level snapshot repository

IndexShardRepository is used on data node to create snapshots of individual shards.

indexShardRepository(String) - Method in class org.elasticsearch.repositories.RepositoriesService
Returns registered index shard repository

This method is called only on data nodes

indexShardRestoreCompleted(SnapshotId, ShardId) - Method in class org.elasticsearch.snapshots.RestoreService
This method is used by IndexShardSnapshotAndRestoreService 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
 
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
 
IndexShardRoutingTable - Class in org.elasticsearch.cluster.routing
IndexShardRoutingTable encapsulates all instances of a single shard.
IndexShardRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
 
indexShards(ClusterState, String, String, String, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
indexShards(ClusterState, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
IndexShardSegments - Class in org.elasticsearch.action.admin.indices.segments
 
IndexShardSnapshotAndRestoreService - Class in org.elasticsearch.index.snapshots
Shard level snapshot and restore service

Performs snapshot and restore operations on the shard level.

IndexShardSnapshotAndRestoreService(ShardId, Settings, IndexShard, RepositoriesService, RestoreService) - Constructor for class org.elasticsearch.index.snapshots.IndexShardSnapshotAndRestoreService
 
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
 
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
 
IndexShardSnapshotModule - Class in org.elasticsearch.index.snapshots
This shard-level module configures IndexShardSnapshotAndRestoreService
IndexShardSnapshotModule() - Constructor for class org.elasticsearch.index.snapshots.IndexShardSnapshotModule
 
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
 
IndexShardState - Enum in org.elasticsearch.index.shard
 
indexShardStateChanged(IndexShard, IndexShardState, IndexShardState, String) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called after a shard's IndexShardState changes.
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
 
IndexShardStatus - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
IndexStats - Class in org.elasticsearch.action.admin.indices.stats
 
IndexStats(String, ShardStats[]) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexStats
 
IndexStatus - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
indexStore - Variable in class org.elasticsearch.index.store.fs.FsDirectoryService
 
IndexStore - Interface in org.elasticsearch.index.store
Index store is an index level information of the Store each shard will use.
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
 
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, CompressedString>, 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
 
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.core.AbstractFieldMapper
 
indexUUID() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
indexUUID() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
indexUUID() - Method in class org.elasticsearch.index.IndexService
 
indexVersion() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
Returns index version
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
 
IndexWarmerMissingException - Exception in org.elasticsearch.search.warmer
 
IndexWarmerMissingException(String...) - 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
 
IndexWarmersMetaData.Factory - Class in org.elasticsearch.search.warmer
 
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

The list of indices supports multi-index syntax.

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

The list of indices supports multi-index syntax.

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

The list of indices supports multi-index syntax.

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

The list of indices supports multi-index syntax.

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(String[]) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
Sets the indices this delete mapping operation will execute on.
indices() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
The indices the mappings will be removed from.
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() - 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.delete.ShardDeleteRequest
 
indices() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
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.BroadcastOperationRequest
 
indices() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
indices(String...) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
indices() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
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.IndexReplicationOperationRequest
 
indices - Variable in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
indices() - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
indices(String[]) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
The indices the request will execute against.
indices() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
indices() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ReplicaOperationRequest
 
indices() - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
indices() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.ShardSingleOperationRequest
 
indices() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
indices() - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
indices() - Method in class org.elasticsearch.action.termvector.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.client.FilterClient
 
indices() - Method in class org.elasticsearch.client.node.NodeAdminClient
 
indices() - Method in class org.elasticsearch.client.transport.support.InternalTransportAdminClient
 
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.MappingUpdatedAction.MappingUpdatedRequest
 
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() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
indices() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Entry
Returns list of indices
indices() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Entry
 
indices(Collection<String>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets list of indices in the snapshot
indices(String[]) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets list of indices in the snapshot
indices() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns indices that were included into this snapshot
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 interface 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_FILTER_CLEAN_INTERVAL - Static variable in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
INDICES_CACHE_FILTER_CONCURRENCY_LEVEL - Static variable in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
INDICES_CACHE_FILTER_EXPIRE - Static variable in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
INDICES_CACHE_FILTER_MINIMUM_ENTRY_WEIGHT - Static variable in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
INDICES_CACHE_FILTER_SIZE - Static variable in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
INDICES_CACHE_QUERY_CLEAN_INTERVAL - Static variable in class org.elasticsearch.indices.cache.query.IndicesQueryCache
 
INDICES_CACHE_QUERY_CONCURRENCY_LEVEL - Static variable in class org.elasticsearch.indices.cache.query.IndicesQueryCache
 
INDICES_CACHE_QUERY_EXPIRE - Static variable in class org.elasticsearch.indices.cache.query.IndicesQueryCache
 
INDICES_CACHE_QUERY_SIZE - Static variable in class org.elasticsearch.indices.cache.query.IndicesQueryCache
 
INDICES_FOLDER - Static variable in class org.elasticsearch.env.NodeEnvironment
 
INDICES_MAPPING_ADDITIONAL_MAPPING_CHANGE_TIME - Static variable in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
INDICES_OPTIONS - Static variable in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
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_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
 
IndicesAction<Request extends ActionRequest,Response extends ActionResponse,RequestBuilder extends ActionRequestBuilder<Request,Response,RequestBuilder,IndicesAdminClient>> - Class in org.elasticsearch.action.admin.indices
Indices action (used with IndicesAdminClient API).
IndicesAction(String) - Constructor for class org.elasticsearch.action.admin.indices.IndicesAction
 
IndicesAdmin(IndicesAdminClient) - Constructor for class org.elasticsearch.client.FilterClient.IndicesAdmin
Creates a new IndicesAdmin
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(IndicesAdminClient) - 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.
IndicesAnalysisModule - Class in org.elasticsearch.indices.analysis
 
IndicesAnalysisModule() - Constructor for class org.elasticsearch.indices.analysis.IndicesAnalysisModule
 
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(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(IndicesAdminClient, 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
 
indicesFilter(FilterBuilder, String...) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
IndicesFilterBuilder - Class in org.elasticsearch.index.query
A filter that will execute the wrapped filter only for the specified indices, and "match_all" when it does not match those indices (by default).
IndicesFilterBuilder(FilterBuilder, String...) - Constructor for class org.elasticsearch.index.query.IndicesFilterBuilder
 
IndicesFilterCache - Class in org.elasticsearch.indices.cache.filter
 
IndicesFilterCache(Settings, ThreadPool, NodeSettingsService) - Constructor for class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
IndicesFilterParser - Class in org.elasticsearch.index.query
 
IndicesFilterParser(ClusterService) - Constructor for class org.elasticsearch.index.query.IndicesFilterParser
 
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
 
IndicesModule(Settings) - 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(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
 
indicesOptions() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
 
indicesOptions() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
 
indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
 
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() - 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 class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
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.mlt.MoreLikeThisRequest
 
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.BroadcastOperationRequest
 
indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
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.IndexReplicationOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ReplicaOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.ShardSingleOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
indicesOptions() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
indicesOptions() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
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
IndicesQueriesModule - Class in org.elasticsearch.indices.query
 
IndicesQueriesModule() - Constructor for class org.elasticsearch.indices.query.IndicesQueriesModule
 
IndicesQueriesRegistry - Class in org.elasticsearch.indices.query
 
IndicesQueriesRegistry(Settings, Set<QueryParser>, Set<FilterParser>) - 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
The indices query cache allows to cache a shard level query stage responses, helping with improving similar requests that are potentially expensive (because of aggs for example).
IndicesQueryCache(Settings, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.indices.cache.query.IndicesQueryCache
 
IndicesQueryCache.Key - Class in org.elasticsearch.indices.cache.query
 
IndicesQueryCache.Value - Class in org.elasticsearch.indices.cache.query
 
IndicesQueryParser - Class in org.elasticsearch.index.query
 
IndicesQueryParser(ClusterService) - Constructor for class org.elasticsearch.index.query.IndicesQueryParser
 
IndicesReplicationOperationRequest<T extends IndicesReplicationOperationRequest> - Class in org.elasticsearch.action.support.replication
 
IndicesReplicationOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
IndicesReplicationOperationRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
IndicesReplicationOperationRequestBuilder<Request extends IndicesReplicationOperationRequest<Request>,Response extends ActionResponse,RequestBuilder extends IndicesReplicationOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.replication
 
IndicesReplicationOperationRequestBuilder(Client, Request) - Constructor for class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequestBuilder
 
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
 
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(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
 
indicesService - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
IndicesService - Class in org.elasticsearch.indices
 
IndicesService(Settings, IndicesLifecycle, IndicesAnalysisService, Injector, NodeEnvironment) - Constructor for class org.elasticsearch.indices.IndicesService
 
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(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
IndicesStatsResponse - Class in org.elasticsearch.action.admin.indices.stats
 
IndicesStatusAction - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
IndicesStatusRequest - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
IndicesStatusRequest() - Constructor for class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Deprecated.
 
IndicesStatusRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Deprecated.
 
indicesStatusRequest(String...) - Static method in class org.elasticsearch.client.Requests
Deprecated.
IndicesStatusRequestBuilder - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
IndicesStatusRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
Deprecated.
 
IndicesStatusResponse - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
indicesStore() - Method in interface org.elasticsearch.index.store.IndexStore
 
indicesStore - Variable in class org.elasticsearch.index.store.support.AbstractIndexStore
 
indicesStore() - Method in class org.elasticsearch.index.store.support.AbstractIndexStore
 
IndicesStore - Class in org.elasticsearch.indices.store
 
IndicesStore(Settings, NodeEnvironment, NodeSettingsService, IndicesService, ClusterService, TransportService) - Constructor for class org.elasticsearch.indices.store.IndicesStore
 
IndicesTermsFilterCache - Class in org.elasticsearch.indices.cache.filter.terms
 
IndicesTermsFilterCache(Settings, Client) - Constructor for class org.elasticsearch.indices.cache.filter.terms.IndicesTermsFilterCache
 
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, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.IndicNormalizationFilterFactory
 
IndonesianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
IndonesianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.IndonesianAnalyzerProvider
 
inErrs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
InetSocketTransportAddress - Class in org.elasticsearch.common.transport
A transport address used for IP socket address (wraps InetSocketAddress).
InetSocketTransportAddress(String, int) - 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
 
inFilter(String, String...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
inFilter(String, int...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
inFilter(String, long...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
inFilter(String, float...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
inFilter(String, double...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
inFilter(String, Object...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
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() - Constructor for class org.elasticsearch.monitor.fs.FsStats.Info
 
Info(String, String, String, long, long, long, long, long, long, long, double, double) - Constructor for class org.elasticsearch.monitor.fs.FsStats.Info
 
info() - Method in class org.elasticsearch.monitor.jvm.JvmService
 
info() - Method in class org.elasticsearch.monitor.network.NetworkService
 
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, boolean) - Method in class org.elasticsearch.node.service.NodeService
 
info() - Method in class org.elasticsearch.plugins.PluginsService
Get information about plugins (jvm and site plugins).
info() - Method in class org.elasticsearch.threadpool.ThreadPool
 
info(String) - Method in class org.elasticsearch.threadpool.ThreadPool
 
Info(String, String) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
 
Info(String, String, int) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
 
Info(String, String, 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
 
init(String[]) - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
init() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
 
init() - Method in interface org.elasticsearch.watcher.ResourceWatcher
Called once when the resource watcher is added to ResourceWatcherService
INIT_SCRIPT - 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(BlobStore, BlobPath, ByteSizeValue, RateLimiter, RateLimiter, BlobStoreIndexShardRepository.RateLimiterListener) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
Called by BlobStoreRepository on repository startup
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
 
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, ImmutableList<String>, MetaData) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
Starts snapshotting process
initializeSnapshot(SnapshotId, ImmutableList<String>, MetaData) - Method in interface org.elasticsearch.repositories.Repository
Starts snapshotting process
initializing() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
initializing() - Method in interface 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
 
initialStateReceived() - Method in class org.elasticsearch.discovery.DiscoveryService
Returns true if the initial state was received within the timeout waiting for it on DiscoveryService.doStart().
initInjector(Injector) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
 
initReader(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
initScript(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the init script.
initScriptFile(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the init script file.
initScriptId(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the indexed init script id.
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.internal.InternalNode
 
Injectors - Class in org.elasticsearch.common.inject
 
Injectors() - Constructor for class org.elasticsearch.common.inject.Injectors
 
InMemoryGeoBoundingBoxFilter - Class in org.elasticsearch.index.search.geo
 
InMemoryGeoBoundingBoxFilter(GeoPoint, GeoPoint, IndexGeoPointFieldData) - Constructor for class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
InMemoryGeoBoundingBoxFilter.GeoBoundingBoxDocSet - Class in org.elasticsearch.index.search.geo
 
InMemoryGeoBoundingBoxFilter.Meridian180GeoBoundingBoxDocSet - Class in org.elasticsearch.index.search.geo
 
innerDocs(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
Get a FixedBitSet that matches the inner documents.
innerExecute(String, CompletionSuggestionContext, IndexReader, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggester
 
innerExecute(String, PhraseSuggestionContext, IndexReader, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
 
innerExecute(String, T, IndexReader, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.Suggester
 
innerExecute(String, TermSuggestionContext, IndexReader, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.term.TermSuggester
 
InnerFilter(QueryParseContext, String...) - Constructor for class org.elasticsearch.index.query.support.XContentStructure.InnerFilter
 
innerGet(String, String, String[], boolean, long, VersionType, FetchSourceContext, boolean) - Method in class org.elasticsearch.index.get.ShardGetService
 
innerHit(QueryInnerHitBuilder) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
Sets inner hit definition in the scope of this filter and reusing the defined type and query.
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.HasParentFilterBuilder
Sets inner hit definition in the scope of this filter 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.NestedFilterBuilder
Sets inner hit definition in the scope of this nested filter and reusing the defined path 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(InnerHitsContext) - Method in class org.elasticsearch.percolator.PercolateContext
 
innerHits() - Method in class org.elasticsearch.percolator.PercolateContext
 
innerHits() - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.BaseInnerHits
 
innerHits(InnerHitsContext) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
innerHits() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
innerHits(InnerHitsContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
innerHits() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
innerHits(InnerHitsContext) - Method in class org.elasticsearch.search.internal.SearchContext
 
innerHits() - Method in class org.elasticsearch.search.internal.SearchContext
 
innerHits(InnerHitsContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
innerHits() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
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(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
 
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.Murmur3FieldMapper
 
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.internal.BoostFieldMapper
 
innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
innerParseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
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.internal.ShardSearchLocalRequest
 
innerReadFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
 
innerReadFrom(StreamInput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
 
innerToString(String) - Method in class org.elasticsearch.common.lucene.search.NoCacheQuery
 
innerToString(String) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.LateParsingQuery
 
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 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, 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.
inputArguments() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
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
 
inQuery(String, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
not used Will be removed in elasticsearch 2.0.0
inQuery(String, int...) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
not used Will be removed in elasticsearch 2.0.0
inQuery(String, long...) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
not used Will be removed in elasticsearch 2.0.0
inQuery(String, float...) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
not used Will be removed in elasticsearch 2.0.0
inQuery(String, double...) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
not used Will be removed in elasticsearch 2.0.0
inQuery(String, Object...) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
not used Will be removed in elasticsearch 2.0.0
inQuery(String, Collection<?>) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
not used Will be removed in elasticsearch 2.0.0
inSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
insert(String, T) - Method in class org.elasticsearch.common.path.PathTrie
 
insert(String[], int, T) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
 
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.
inStage(ContextIndexSearcher.Stage) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
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
 
INSTALL - Static variable in class org.elasticsearch.plugins.PluginManager.ACTION
 
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.restart.NodesRestartAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
 
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.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.get.GetIndexAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingAction
 
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.optimize.OptimizeAction
 
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.stats.IndicesStatsAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.status.IndicesStatusAction
Deprecated.
 
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.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
 
INSTANCE - Static variable in class org.elasticsearch.action.delete.DeleteAction
 
INSTANCE - Static variable in class org.elasticsearch.action.deletebyquery.DeleteByQueryAction
 
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.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.mlt.MoreLikeThisAction
 
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.termvector.MultiTermVectorsAction
 
INSTANCE - Static variable in class org.elasticsearch.action.termvector.TermVectorAction
 
INSTANCE - Static variable in class org.elasticsearch.action.update.UpdateAction
 
INSTANCE - Static variable in class org.elasticsearch.common.compress.lzf.LZFCompressorContext
 
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.index.search.nested.NonNestedDocsFilter
 
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 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
 
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(Client, 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(FieldMapper.Names, int, float, FieldType, Boolean, Integer, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.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.TypeParser - Class in org.elasticsearch.index.mapper.core
 
Interface(String, String, String) - Constructor for class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
interfaceHasIPAddresses(NetworkInterface, NetworkUtils.StackType) - Static method in class org.elasticsearch.common.network.NetworkUtils
A function to check if an interface supports an IP version (i.e has addresses defined for that IP version).
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
An internal implementation of Aggregation.
InternalAggregation() - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation
Constructs an un initialized addAggregation (used for serialization)
InternalAggregation(String) - 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
An internal implementation of 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) - Constructor for class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
 
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) - 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.ClusterInfoUpdateJob - Class in org.elasticsearch.cluster
Runnable class that performs a to retrieve disk usages for nodes in the cluster and an IndicesStatsRequest to retrieve the sizes of all shards to ensure they can fit on nodes during shard balancing.
InternalClusterInfoService.SubmitReschedulingClusterInfoUpdatedJob - Class in org.elasticsearch.cluster
Class used to submit InternalClusterInfoService.ClusterInfoUpdateJobs on the InternalClusterInfoService threadpool, these jobs will reschedule themselves by placing a new instance of this class onto the scheduled threadpool.
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
 
InternalCountDateHistogramFacet - Class in org.elasticsearch.search.facet.datehistogram
 
InternalCountDateHistogramFacet(String, DateHistogramFacet.ComparatorType, InternalCountDateHistogramFacet.CountEntry[]) - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
InternalCountDateHistogramFacet.CountEntry - Class in org.elasticsearch.search.facet.datehistogram
A histogram entry representing a single entry within the result of a histogram facet.
InternalCountHistogramFacet - Class in org.elasticsearch.search.facet.histogram
 
InternalCountHistogramFacet(String, HistogramFacet.ComparatorType, InternalCountHistogramFacet.CountEntry[]) - Constructor for class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
InternalCountHistogramFacet.CountEntry - Class in org.elasticsearch.search.facet.histogram
A histogram entry representing a single entry within the result of a histogram facet.
InternalDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
 
InternalDateHistogramFacet - Class in org.elasticsearch.search.facet.datehistogram
 
InternalDateHistogramFacet() - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalDateHistogramFacet
 
InternalDateHistogramFacet(String) - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalDateHistogramFacet
 
InternalDateRange - Class in org.elasticsearch.search.aggregations.bucket.range.date
 
InternalDateRange.Bucket - 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
 
internalDispatchRequest(HttpRequest, HttpChannel) - Method in class org.elasticsearch.http.HttpServer
 
InternalDoubleTermsFacet - Class in org.elasticsearch.search.facet.terms.doubles
 
InternalDoubleTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalDoubleTermsFacet.DoubleEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
InternalDoubleTermsFacet.DoubleEntry - Class in org.elasticsearch.search.facet.terms.doubles
 
InternalEngine - Class in org.elasticsearch.index.engine
 
InternalEngine(EngineConfig) - 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(String, long, double, double, double, double, double, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
 
InternalFacet - Class in org.elasticsearch.search.facet
 
InternalFacet() - Constructor for class org.elasticsearch.search.facet.InternalFacet
Here just for streams...
InternalFacet(String) - Constructor for class org.elasticsearch.search.facet.InternalFacet
 
InternalFacet.ReduceContext - Class in org.elasticsearch.search.facet
 
InternalFacet.Stream - Interface in org.elasticsearch.search.facet
 
InternalFacet.Streams - Class in org.elasticsearch.search.facet
 
InternalFacets - Class in org.elasticsearch.search.facet
 
InternalFacets(List<Facet>) - Constructor for class org.elasticsearch.search.facet.InternalFacets
Constructs a new facets.
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
 
InternalFilterFacet - Class in org.elasticsearch.search.facet.filter
 
InternalFilterFacet(String, long) - Constructor for class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
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) - 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
 
InternalFullDateHistogramFacet - Class in org.elasticsearch.search.facet.datehistogram
 
InternalFullDateHistogramFacet(String, DateHistogramFacet.ComparatorType, List<InternalFullDateHistogramFacet.FullEntry>) - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
InternalFullDateHistogramFacet.FullEntry - Class in org.elasticsearch.search.facet.datehistogram
A histogram entry representing a single entry within the result of a histogram facet.
InternalFullHistogramFacet - Class in org.elasticsearch.search.facet.histogram
 
InternalFullHistogramFacet(String, HistogramFacet.ComparatorType, List<InternalFullHistogramFacet.FullEntry>) - Constructor for class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
InternalFullHistogramFacet.FullEntry - Class in org.elasticsearch.search.facet.histogram
A histogram entry representing a single entry within the result of a histogram facet.
InternalGeoBounds - Class in org.elasticsearch.search.aggregations.metrics.geobounds
 
InternalGeoDistance - Class in org.elasticsearch.search.aggregations.bucket.range.geodistance
 
InternalGeoDistance(String, List<InternalGeoDistance.Bucket>, ValueFormatter, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.geodistance.InternalGeoDistance
 
InternalGeoDistanceFacet - Class in org.elasticsearch.search.facet.geodistance
 
InternalGeoDistanceFacet(String, GeoDistanceFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
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>) - 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.
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
 
InternalHistogramFacet - Class in org.elasticsearch.search.facet.histogram
 
InternalHistogramFacet() - Constructor for class org.elasticsearch.search.facet.histogram.InternalHistogramFacet
 
InternalHistogramFacet(String) - Constructor for class org.elasticsearch.search.facet.histogram.InternalHistogramFacet
 
internalHits() - Method in class org.elasticsearch.search.internal.InternalSearchHits
 
InternalIndexEngine - Class in org.elasticsearch.index.engine.internal
 
InternalIndexEngine(Index) - Constructor for class org.elasticsearch.index.engine.internal.InternalIndexEngine
 
InternalIndexEngine(Index, Settings) - Constructor for class org.elasticsearch.index.engine.internal.InternalIndexEngine
 
InternalIndexEngineModule - Class in org.elasticsearch.index.engine.internal
 
InternalIndexEngineModule() - Constructor for class org.elasticsearch.index.engine.internal.InternalIndexEngineModule
 
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) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
 
InternalIPv4Range.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range.ipv4
 
InternalLineStringBuilder(MultiLineStringBuilder) - Constructor for class org.elasticsearch.common.geo.builders.MultiLineStringBuilder.InternalLineStringBuilder
 
InternalLongTermsFacet - Class in org.elasticsearch.search.facet.terms.longs
 
InternalLongTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalLongTermsFacet.LongEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
InternalLongTermsFacet.LongEntry - Class in org.elasticsearch.search.facet.terms.longs
 
internalMap() - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
 
InternalMapper - Interface in org.elasticsearch.index.mapper
A marker interface for internal mappings.
InternalMax - Class in org.elasticsearch.search.aggregations.metrics.max
 
InternalMax(String, double, ValueFormatter) - 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) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMetricsAggregation
 
InternalMin - Class in org.elasticsearch.search.aggregations.metrics.min
 
InternalMin(String, double, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.InternalMin
 
InternalMissing - Class in org.elasticsearch.search.aggregations.bucket.missing
 
InternalNested - Class in org.elasticsearch.search.aggregations.bucket.nested
 
InternalNested() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
 
InternalNested(String, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
 
InternalNestedIdentity(String, int, InternalSearchHit.InternalNestedIdentity) - Constructor for class org.elasticsearch.search.internal.InternalSearchHit.InternalNestedIdentity
 
InternalNode - Class in org.elasticsearch.node.internal
 
InternalNode() - Constructor for class org.elasticsearch.node.internal.InternalNode
 
InternalNode(Settings, boolean) - Constructor for class org.elasticsearch.node.internal.InternalNode
 
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(String, Settings, DocumentMapperParser, DocumentMapper, ContentPath) - Constructor for class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
InternalPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
InternalPercentileRanks(String, double[], TDigestState, boolean, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentileRanks
 
InternalPercentileRanks.Iter - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
InternalPercentiles - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
InternalPercentiles(String, double[], TDigestState, boolean, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
InternalPercentiles.Iter - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
InternalQueryFacet - Class in org.elasticsearch.search.facet.query
 
InternalQueryFacet(String, long) - Constructor for class org.elasticsearch.search.facet.query.InternalQueryFacet
 
InternalRange<B extends InternalRange.Bucket> - 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) - 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>> - Class in org.elasticsearch.search.aggregations.bucket.range
 
InternalRangeFacet - Class in org.elasticsearch.search.facet.range
 
InternalRangeFacet(String, RangeFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.range.InternalRangeFacet
 
InternalReverseNested - Class in org.elasticsearch.search.aggregations.bucket.nested
 
InternalReverseNested() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
 
InternalReverseNested(String, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
 
InternalScriptedMetric - Class in org.elasticsearch.search.aggregations.metrics.scripted
 
InternalScriptedMetric(String, Object, String, ScriptService.ScriptType, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
 
internalScrollSearchRequest(long, SearchScrollRequest) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
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
 
internalSearchRequest(ShardRouting, int, SearchRequest, String[], long, boolean) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
InternalSearchResponse - Class in org.elasticsearch.search.internal
 
InternalSearchResponse(InternalSearchHits, InternalFacets, InternalAggregations, Suggest, 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 - 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, Collection<InternalSignificantTerms.Bucket>) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
 
InternalSignificantTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.significant
 
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) - 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....
InternalStatisticalFacet - Class in org.elasticsearch.search.facet.statistical
 
InternalStatisticalFacet(String, double, double, double, double, long) - Constructor for class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
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) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
InternalStringTermsFacet - Class in org.elasticsearch.search.facet.terms.strings
 
InternalStringTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalStringTermsFacet.TermEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
InternalStringTermsFacet.TermEntry - Class in org.elasticsearch.search.facet.terms.strings
 
InternalSum - Class in org.elasticsearch.search.aggregations.metrics.sum
 
InternalTerms - 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<InternalTerms.Bucket>, boolean, long, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
InternalTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
 
InternalTermsFacet - Class in org.elasticsearch.search.facet.terms
 
InternalTermsFacet() - Constructor for class org.elasticsearch.search.facet.terms.InternalTermsFacet
 
InternalTermsFacet(String) - Constructor for class org.elasticsearch.search.facet.terms.InternalTermsFacet
 
InternalTermsStatsDoubleFacet - Class in org.elasticsearch.search.facet.termsstats.doubles
 
InternalTermsStatsDoubleFacet() - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
InternalTermsStatsDoubleFacet(String, TermsStatsFacet.ComparatorType, int, Collection<InternalTermsStatsDoubleFacet.DoubleEntry>, long) - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
InternalTermsStatsDoubleFacet.DoubleEntry - Class in org.elasticsearch.search.facet.termsstats.doubles
 
InternalTermsStatsFacet - Class in org.elasticsearch.search.facet.termsstats
 
InternalTermsStatsFacet() - Constructor for class org.elasticsearch.search.facet.termsstats.InternalTermsStatsFacet
 
InternalTermsStatsFacet(String) - Constructor for class org.elasticsearch.search.facet.termsstats.InternalTermsStatsFacet
 
InternalTermsStatsLongFacet - Class in org.elasticsearch.search.facet.termsstats.longs
 
InternalTermsStatsLongFacet() - Constructor for class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
InternalTermsStatsLongFacet(String, TermsStatsFacet.ComparatorType, int, Collection<InternalTermsStatsLongFacet.LongEntry>, long) - Constructor for class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
InternalTermsStatsLongFacet.LongEntry - Class in org.elasticsearch.search.facet.termsstats.longs
 
InternalTermsStatsStringFacet - Class in org.elasticsearch.search.facet.termsstats.strings
 
InternalTermsStatsStringFacet() - Constructor for class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
InternalTermsStatsStringFacet(String, TermsStatsFacet.ComparatorType, int, Collection<InternalTermsStatsStringFacet.StringEntry>, long) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
InternalTermsStatsStringFacet.StringEntry - Class in org.elasticsearch.search.facet.termsstats.strings
 
InternalTopHits - Class in org.elasticsearch.search.aggregations.metrics.tophits
 
InternalTopHits(String, int, int, TopDocs, InternalSearchHits) - Constructor for class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
 
InternalTopHits(String, InternalSearchHits) - 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
 
InternalTransportAdminClient - Class in org.elasticsearch.client.transport.support
 
InternalTransportAdminClient(Settings, InternalTransportIndicesAdminClient, InternalTransportClusterAdminClient) - Constructor for class org.elasticsearch.client.transport.support.InternalTransportAdminClient
 
InternalTransportClient - Class in org.elasticsearch.client.transport.support
 
InternalTransportClient(Settings, ThreadPool, TransportService, TransportClientNodesService, InternalTransportAdminClient, Map<String, GenericAction>, Headers) - Constructor for class org.elasticsearch.client.transport.support.InternalTransportClient
 
InternalTransportClusterAdminClient - Class in org.elasticsearch.client.transport.support
 
InternalTransportClusterAdminClient(Settings, TransportClientNodesService, ThreadPool, TransportService, Map<String, GenericAction>, Headers) - Constructor for class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
InternalTransportIndicesAdminClient - Class in org.elasticsearch.client.transport.support
 
InternalTransportIndicesAdminClient(Settings, TransportClientNodesService, TransportService, ThreadPool, Map<String, GenericAction>, Headers) - Constructor for class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
InternalValueCount - Class in org.elasticsearch.search.aggregations.metrics.valuecount
An internal implementation of ValueCount.
InternalValueCount(String, long, ValueFormatter) - 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.percentiles.PercentileRanksBuilder
 
internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesBuilder
 
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.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(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
interval(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Set the interval in milliseconds.
interval(DateHistogram.Interval) - 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.
interval(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
The interval used to control the bucket "size" where each key value of a hit will fall into.
interval(long) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
The interval used to control the bucket "size" where each key value of a hit will fall into.
interval(long, TimeUnit) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
The interval used to control the bucket "size" where each key value of a hit will fall into.
interval(long) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
intField(FieldInfo, int) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
intIntMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
intIntMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
intObjectMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
intObjectMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
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 jsr166e.DoubleAdder
Returns the sum() as an int after a narrowing primitive conversion.
intValue() - Method in class jsr166e.DoubleMaxUpdater
Returns the DoubleMaxUpdater.max() as an int after a narrowing primitive conversion.
intValue() - Method in class jsr166e.LongAdder
Returns the LongAdder.sum() as an int after a narrowing primitive conversion.
intValue() - Method in class jsr166e.LongMaxUpdater
Returns the LongMaxUpdater.max() as an int after a narrowing primitive conversion.
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
 
InvalidAliasNameException - Exception in org.elasticsearch.indices
 
InvalidAliasNameException(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
 
InvalidIndexNameException - Exception in org.elasticsearch.indices
 
InvalidIndexNameException(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
 
InvalidIndexTemplateException - Exception in org.elasticsearch.indices
 
InvalidIndexTemplateException(String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexTemplateException
 
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
 
InvalidTypeNameException - Exception in org.elasticsearch.indices
 
InvalidTypeNameException(String) - Constructor for exception org.elasticsearch.indices.InvalidTypeNameException
 
ipField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
IpFieldMapper - Class in org.elasticsearch.index.mapper.ip
 
IpFieldMapper(FieldMapper.Names, int, float, FieldType, Boolean, String, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.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.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
 
ipRange(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new IPv4Range aggregation with the given name.
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
 
IPv4_SETTING - Static variable in class org.elasticsearch.common.network.NetworkUtils
 
IPv4Formatter() - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormatter.IPv4Formatter
 
IPv4Range - Interface in org.elasticsearch.search.aggregations.bucket.range.ipv4
A range aggregation on ipv4 values.
IPv4Range.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.range.ipv4
 
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.
IPv6_SETTING - Static variable in class org.elasticsearch.common.network.NetworkUtils
 
IrishAnalyzerProvider - Class in org.elasticsearch.index.analysis
Provider for IrishAnalyzer
IrishAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.IrishAnalyzerProvider
 
isA(ValueType) - Method in enum org.elasticsearch.search.aggregations.support.ValueType
 
isAccessibleDirectory(File, 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
isAllIndices(String[]) - Static method in class org.elasticsearch.cluster.metadata.MetaData
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[]) - 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
isArray(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
isArtificial() - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
isAuthorized(Expression) - Method in class org.elasticsearch.script.groovy.GroovySandboxExpressionChecker
Checks whether the expression to be compiled is allowed
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
 
isCacheable() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.AllDocIdSet
Does not go to the reader and ask for data, so can be cached.
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.AndDocIdSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet
 
isCached(Filter) - Static method in class org.elasticsearch.common.lucene.search.CachedFilter
 
isCancelled() - Method in class org.elasticsearch.common.util.CancellableThreads
 
isCancelled() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
 
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
 
isChecksumOnMerge() - Method in class org.elasticsearch.index.engine.EngineConfig
Returns true iff checksums are checked on merge
isClientNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
isCloseConnectionException(Throwable) - Static method in class org.elasticsearch.common.transport.NetworkExceptionHelper
 
isClosed - Variable in class org.elasticsearch.index.engine.Engine
 
isClosed() - Method in class org.elasticsearch.node.internal.InternalNode
 
isClosed() - Method in interface org.elasticsearch.node.Node
Returns true if the node is closed.
isCommitted() - Method in class org.elasticsearch.index.engine.Segment
 
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.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(byte[], int, int) - 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(byte[]) - Static method in class org.elasticsearch.common.compress.CompressorFactory
 
isCompressed(byte[], int, int) - 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.lzf.LZFCompressor
 
isCompressed(byte[], int, int) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
isCompressed(ChannelBuffer) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
isCompressed(IndexInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
isConcrete(Class<?>) - Static method in class org.elasticsearch.common.Classes
 
isConflictException(Throwable) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
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.ContextHolder
Checks if the context is empty.
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 otherwise false.
isCountedDown() - Method in class org.elasticsearch.common.util.concurrent.CountDown
Returns true iff the count-down has reached zero.
isCreated() - Method in class org.elasticsearch.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
isCustomPathsEnabled() - Method in class org.elasticsearch.env.NodeEnvironment
return true if custom paths are allowed for indices
isDataNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
Should this node hold data (shards) or not.
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
 
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.termvector.MultiTermVectorsRequest
 
isEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
isEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
 
isEmpty() - Method in class org.elasticsearch.common.collect.IdentityHashSet
Returns true if this set contains no elements.
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.ImmutableOpenLongMap.Builder
 
isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
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.docset.DocIdSets
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.index.mapper.ObjectMappers
 
isEmpty() - Method in class org.elasticsearch.river.routing.RiversRouting
 
isEmpty() - Method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
isEmpty() - Method in class org.elasticsearch.search.lookup.DocLookup
 
isEmpty() - Method in class org.elasticsearch.search.lookup.FieldLookup
 
isEmpty() - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
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
 
isEnableGcDeletes() - Method in class org.elasticsearch.index.engine.EngineConfig
Returns true iff delete garbage collection in the engine should be enabled.
isEnableGeohashPrefix() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
isEnableLatLon() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
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
 
isEscapeChar(char) - Static method in class org.elasticsearch.script.mustache.JsonEscapingMustacheFactory
 
isExecuting() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
 
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.termvector.TermVectorResponse
 
isExists() - Method in class org.elasticsearch.index.get.GetResult
Does the document exists.
isExplicitAllPattern(String[]) - Static method in class org.elasticsearch.cluster.metadata.MetaData
Identifies whether the array containing index names given as argument explicitly refers to all indices The empty or null array doesn't explicitly map to all indices
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.termvector.MultiTermVectorsItemResponse
Is this a failed execution?
isFailEngineOnCorruption() - Method in class org.elasticsearch.index.engine.EngineConfig
Returns true if the engine should be failed in the case of a corrupted index.
isFailOnMergeFailure() - Method in class org.elasticsearch.index.engine.EngineConfig
Returns true iff the engine should be failed if a merge error is hit.
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?
isFastIterator(DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocIdSets
Is DocIdSetIterator implemented in a "fast" manner.
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.BaseTransportRequestHandler
Default force execution to false.
isForceExecution() - Method in interface org.elasticsearch.transport.TransportRequestHandler
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.delete.ShardDeleteResponse
 
isFound() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
Returns true if a doc was found to delete.
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.AbstractFieldMapper
Returns if this field is only generated when indexing.
isGenerated() - Method in class org.elasticsearch.index.mapper.core.Murmur3FieldMapper
 
isGenerated() - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
 
isGenerated() - Method in interface 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
 
isGeoPoint() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
 
isGlobal() - Method in class org.elasticsearch.search.facet.SearchContextFacets.Entry
 
isGlobalStateEquals(MetaData, MetaData) - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
isHighlighted() - Method in class org.apache.lucene.search.postingshighlight.Snippet
 
isIncludeInParent() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Nested
 
isIncludeInRoot() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Nested
 
isIncludeLower() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
isIncludeRelocations() - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
 
isIncludeUpper() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
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.
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
 
isInnerClass(Class<?>) - Static method in class org.elasticsearch.common.Classes
 
isIPv4() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
isJvm() - Method in class org.elasticsearch.action.admin.cluster.node.info.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
 
isLastGcEnabled() - Static method in class org.elasticsearch.monitor.jvm.JvmStats
 
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
 
isMergedSegment(AtomicReader) - 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.
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
 
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.
isNumeric() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
isNumeric() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
isNumeric() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
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.
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.
isPatternMatchingAllIndices(String[], String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
Identifies whether the first argument (an array containing index names) is a pattern that matches all indices
isPrimaryActive() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
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
 
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.
isRiverNode(DiscoveryNode) - Static method in class org.elasticsearch.river.cluster.RiverNodeHelper
 
isRiverNode(DiscoveryNode, RiverName) - Static method in class org.elasticsearch.river.cluster.RiverNodeHelper
 
isRunning() - Method in class org.elasticsearch.common.StopWatch
Return whether the stop watch is currently running.
isSame(StoreFileMetaData) - Method in class org.elasticsearch.index.gateway.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(StoreFileMetaData) - Method in class org.elasticsearch.index.store.StoreFileMetaData
Returns true iff the length and the checksums are the same.
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
 
isSet(CommonStatsFlags.Flag) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
 
isShardNotAvailableException(Throwable) - Static method in class org.elasticsearch.action.support.TransportActions
 
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.action.admin.cluster.node.info.PluginInfo
 
isSortable() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
isSortable() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
isSortable() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
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.
isStackAvailable(boolean) - Static method in class org.elasticsearch.common.network.NetworkUtils
 
isStoringPayloads() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
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.TransportShardSingleOperationAction
Tells whether the action is a main one or a subaction.
isSubAction() - Method in class org.elasticsearch.action.termvector.TransportSingleShardMultiTermsVectorAction
 
isSucceeded() - Method in class org.elasticsearch.action.search.ClearScrollResponse
 
isSynthetic() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
 
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
 
isWithinMultiFields() - Method in class org.elasticsearch.index.mapper.ParseContext
 
isWithinNewMapper() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
isWithinNewMapper() - Method in class org.elasticsearch.index.mapper.ParseContext
 
ItalianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ItalianAnalyzerProvider(Index, Settings, 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, Text) - Constructor for class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response.Item
 
Item(SearchResponse, String) - 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
 
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[], TDigestState) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentileRanks.Iter
 
Iter(double[], TDigestState) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles.Iter
 
iterate(PortsRange.PortCallback) - Method in class org.elasticsearch.common.transport.PortsRange
 
iterator() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
iterator() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
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.status.IndexShardStatus
Deprecated.
 
iterator() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Deprecated.
 
iterator() - Method in class org.elasticsearch.action.bulk.BulkResponse
 
iterator() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryResponse
 
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.NodesOperationResponse
 
iterator() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
iterator() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse
 
iterator() - Method in class org.elasticsearch.action.termvector.TermVectorFields
 
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.IdentityHashSet
Returns an iterator over the elements in this set.
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.ImmutableOpenLongMap.Builder
 
iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
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.lucene.docset.AllDocIdSet
 
Iterator(int) - Constructor for class org.elasticsearch.common.lucene.docset.AllDocIdSet.Iterator
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.AndDocIdSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet
 
iterator() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
Returns an iterator on the clauses in this query.
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.aliases.IndexAliasesService
 
iterator() - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
Deprecated.
 
iterator(TermsEnum) - 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.gateway.CommitPoints
 
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.FieldMappers
 
iterator() - Method in class org.elasticsearch.index.mapper.ObjectMappers
 
iterator() - Method in class org.elasticsearch.index.mapper.ParseContext.Document
 
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.FsStats
 
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.river.routing.RiversRouting
 
iterator() - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
 
iterator() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
Iterates over the Aggregations.
iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentileRanks
 
iterator() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
iterator() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
iterator() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
iterator() - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
iterator() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
iterator() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
iterator() - Method in class org.elasticsearch.search.facet.InternalFacets
Iterates over the Facets.
iterator() - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
iterator() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
iterator() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
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
 
Iterators2 - Enum in org.elasticsearch.common.collect
 

J

JdkESLogger - Class in org.elasticsearch.common.logging.jdk
 
JdkESLogger(String, Logger) - Constructor for class org.elasticsearch.common.logging.jdk.JdkESLogger
 
JdkESLoggerFactory - Class in org.elasticsearch.common.logging.jdk
 
JdkESLoggerFactory() - Constructor for class org.elasticsearch.common.logging.jdk.JdkESLoggerFactory
 
JLHScore - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
JLHScore.JLHScoreBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
JLHScore.JLHScoreParser - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
JLHScoreBuilder() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore.JLHScoreBuilder
 
JLHScoreParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore.JLHScoreParser
 
JmxFsProbe - Class in org.elasticsearch.monitor.fs
 
JmxFsProbe(Settings, NodeEnvironment) - Constructor for class org.elasticsearch.monitor.fs.JmxFsProbe
 
JmxNetworkProbe - Class in org.elasticsearch.monitor.network
 
JmxNetworkProbe(Settings) - Constructor for class org.elasticsearch.monitor.network.JmxNetworkProbe
 
JmxOsProbe - Class in org.elasticsearch.monitor.os
 
JmxOsProbe(Settings) - Constructor for class org.elasticsearch.monitor.os.JmxOsProbe
 
JmxProcessProbe - Class in org.elasticsearch.monitor.process
 
JmxProcessProbe(Settings) - Constructor for class org.elasticsearch.monitor.process.JmxProcessProbe
 
Joda - Class in org.elasticsearch.common.joda
 
Joda() - Constructor for class org.elasticsearch.common.joda.Joda
 
Join - Class in org.elasticsearch.common.inject.internal
Utility for joining pieces of text separated by a delimiter.
join(String, Iterable<?>) - Static method in class org.elasticsearch.common.inject.internal.Join
Returns a string containing the tokens, converted to strings if necessary, separated by delimiter.
join(String, Object[]) - Static method in class org.elasticsearch.common.inject.internal.Join
Returns a string containing the tokens, converted to strings if necessary, separated by delimiter.
join(String, Object, Object...) - Static method in class org.elasticsearch.common.inject.internal.Join
Returns a string containing the tokens, converted to strings if necessary, separated by delimiter.
join(String, Iterator<?>) - Static method in class org.elasticsearch.common.inject.internal.Join
Returns a string containing the tokens, converted to strings if necessary, separated by delimiter.
join(String, String, Map<?, ?>) - Static method in class org.elasticsearch.common.inject.internal.Join
Returns a string containing the contents of map, with entries separated by entryDelimiter, and keys and values separated with keyValueSeparator.
join(T, String, Iterable<?>) - Static method in class org.elasticsearch.common.inject.internal.Join
Appends each of the tokens to appendable, separated by delimiter.
join(T, String, Object[]) - Static method in class org.elasticsearch.common.inject.internal.Join
Appends each of the tokens to appendable, separated by delimiter.
join(T, String, Object, Object...) - Static method in class org.elasticsearch.common.inject.internal.Join
Appends each of the tokens to appendable, separated by delimiter.
join(T, String, Iterator<?>) - Static method in class org.elasticsearch.common.inject.internal.Join
Appends each of the tokens to appendable, separated by delimiter.
join(T, String, String, Map<?, ?>) - Static method in class org.elasticsearch.common.inject.internal.Join
Appends the contents of map to appendable, with entries separated by entryDelimiter, and keys and values separated with keyValueSeparator.
join(boolean) - Method in class org.elasticsearch.index.query.NestedFilterBuilder
 
join(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
 
join(BytesRef, BytesRef, BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
 
join(BytesRef, BytesRefBuilder, BytesRef, BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
 
join(BytesRef, BytesRefBuilder, BytesRef...) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
 
Join.JoinException - Exception in org.elasticsearch.common.inject.internal
Exception thrown in response to an IOException from the supplied Appendable.
joiningCluster() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
returns true if zen discovery is started and there is a currently a background thread active for (re)joining the cluster used for testing.
jsonBuilder() - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Returns a content builder using JSON format (XContentType.JSON.
jsonBuilder(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.
JsonEscapingMustacheFactory - Class in org.elasticsearch.script.mustache
A MustacheFactory that does simple JSON escaping.
JsonEscapingMustacheFactory() - Constructor for class org.elasticsearch.script.mustache.JsonEscapingMustacheFactory
 
JsonSettingsLoader - Class in org.elasticsearch.common.settings.loader
Settings loader that loads (parses) the settings in a json format by flattening them into a map.
JsonSettingsLoader() - Constructor for class org.elasticsearch.common.settings.loader.JsonSettingsLoader
 
JsonXContent - Class in org.elasticsearch.common.xcontent.json
A JSON based content implementation using Jackson.
jsonXContent - Static variable in class org.elasticsearch.common.xcontent.json.JsonXContent
 
JsonXContentGenerator - Class in org.elasticsearch.common.xcontent.json
 
JsonXContentGenerator(JsonGenerator) - Constructor for class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
JsonXContentParser - Class in org.elasticsearch.common.xcontent.json
 
JsonXContentParser(JsonParser) - Constructor for class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
jsr166e - package jsr166e
 
JTS_AVAILABLE - Static variable in class org.elasticsearch.common.geo.ShapesAvailability
 
jtsGeometry(Geometry) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
 
JustSourceFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
 
JustSourceFieldsVisitor() - Constructor for class org.elasticsearch.index.fieldvisitor.JustSourceFieldsVisitor
 
JustUidFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
 
JustUidFieldsVisitor() - Constructor for class org.elasticsearch.index.fieldvisitor.JustUidFieldsVisitor
 
jvm() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Should the node JVM be returned.
jvm(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Should the node JVM be returned.
jvm() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node JVM be returned.
jvm(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node JVM be returned.
JVMCheck - Class in org.elasticsearch.bootstrap
Checks that the JVM is ok and won't cause index corruption
JVMCheck() - Constructor for class org.elasticsearch.bootstrap.JVMCheck
 
JvmInfo - Class in org.elasticsearch.monitor.jvm
 
jvmInfo() - Static method in class org.elasticsearch.monitor.jvm.JvmInfo
 
JvmInfo.Mem - Class in org.elasticsearch.monitor.jvm
 
JvmMonitorService - Class in org.elasticsearch.monitor.jvm
 
JvmMonitorService(Settings, ThreadPool) - Constructor for class org.elasticsearch.monitor.jvm.JvmMonitorService
 
JvmService - Class in org.elasticsearch.monitor.jvm
 
JvmService(Settings) - Constructor for class org.elasticsearch.monitor.jvm.JvmService
 
jvmService() - Method in class org.elasticsearch.monitor.MonitorService
 
JvmStats - Class in org.elasticsearch.monitor.jvm
 
JvmStats(long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats
 
jvmStats() - Static method in class org.elasticsearch.monitor.jvm.JvmStats
 
JvmStats.BufferPool - Class in org.elasticsearch.monitor.jvm
 
JvmStats.GarbageCollector - Class in org.elasticsearch.monitor.jvm
 
JvmStats.GarbageCollector.LastGc - Class in org.elasticsearch.monitor.jvm
 
JvmStats.GarbageCollectors - Class in org.elasticsearch.monitor.jvm
 
JvmStats.Mem - Class in org.elasticsearch.monitor.jvm
 
JvmStats.MemoryPool - Class in org.elasticsearch.monitor.jvm
 
JvmStats.Threads - Class in org.elasticsearch.monitor.jvm
 

K

kb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
kbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
keepAlive() - Method in class org.elasticsearch.percolator.PercolateContext
 
keepAlive(long) - Method in class org.elasticsearch.percolator.PercolateContext
 
keepAlive() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
keepAlive(long) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
keepAlive() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
keepAlive(long) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
keepAlive() - Method in class org.elasticsearch.search.internal.SearchContext
 
keepAlive(long) - Method in class org.elasticsearch.search.internal.SearchContext
 
keepAlive(long) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
keepAlive() - Method in class org.elasticsearch.search.Scroll
How long the resources will be kept open to support the scroll request.
KEEPALIVE_INTERVAL_KEY - Static variable in class org.elasticsearch.search.SearchService
 
KeepFrameDecoder - Class in org.elasticsearch.common.netty
A marker to not remove frame decoder from the resulting jar so plugins can use it.
KeepFrameDecoder() - Constructor for class org.elasticsearch.common.netty.KeepFrameDecoder
 
KeepLastNDeletionPolicy - Class in org.elasticsearch.index.deletionpolicy
 
KeepLastNDeletionPolicy(ShardId, Settings) - Constructor for class org.elasticsearch.index.deletionpolicy.KeepLastNDeletionPolicy
 
KeepOnlyLastDeletionPolicy - Class in org.elasticsearch.index.deletionpolicy
This IndexDeletionPolicy implementation that keeps only the most recent commit and immediately removes all prior commits after a new commit is done.
KeepOnlyLastDeletionPolicy(ShardId, Settings) - Constructor for class org.elasticsearch.index.deletionpolicy.KeepOnlyLastDeletionPolicy
 
keepTaskList(boolean) - Method in class org.elasticsearch.common.StopWatch
Determine whether the TaskInfo array is built over time.
KeepTypesFilterFactory - Class in org.elasticsearch.index.analysis
A TokenFilterFactory for TypeFilter.
KeepTypesFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeepTypesFilterFactory
 
KeepWordFilterFactory - Class in org.elasticsearch.index.analysis
A TokenFilterFactory for KeepWordFilter.
KeepWordFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeepWordFilterFactory
 
Kernel32Library - Class in org.elasticsearch.common.jna
Library for Windows/Kernel32
Kernel32Library.ConsoleCtrlHandler - Interface in org.elasticsearch.common.jna
 
Key<T> - Class in org.elasticsearch.common.inject
Binding key consisting of an injection type and an optional annotation.
Key(Class<? extends Annotation>) - Constructor for class org.elasticsearch.common.inject.Key
Constructs a new key.
Key(Annotation) - Constructor for class org.elasticsearch.common.inject.Key
Constructs a new key.
Key() - Constructor for class org.elasticsearch.common.inject.Key
Constructs a new key.
key - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
 
Key(byte[]) - Constructor for class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
Key(String) - Constructor for class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
KEY - Static variable in enum org.elasticsearch.index.mapper.FieldMapper.Loading
 
key - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
 
KEY - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
 
key - Variable in class org.elasticsearch.search.aggregations.support.OrderPath.Token
 
KEY_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.InternalAggregation.CommonFields
 
KEY_ASC - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.Histogram.Order
 
KEY_DESC - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.Histogram.Order
 
KEY_SCRIPT_FILE - Static variable in class org.elasticsearch.script.ScriptService
 
KEY_SCRIPT_ID - Static variable in class org.elasticsearch.script.ScriptService
 
KEY_SCRIPT_INLINE - Static variable in class org.elasticsearch.script.ScriptService
 
keyed - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
KeyedLock<T> - Class in org.elasticsearch.common.util.concurrent
This class manages locks.
KeyedLock() - Constructor for class org.elasticsearch.common.util.concurrent.KeyedLock
 
KeyedLock.GlobalLockable<T> - Class in org.elasticsearch.common.util.concurrent
A KeyedLock that allows to acquire a global lock that guarantees exclusive access to the resource the KeyedLock is guarding.
keyField(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
The field name to use in order to control where the hit will "fall into" within the histogram entries.
keyField(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
The field name to use in order to control where the hit will "fall into" within the histogram entries.
keyField(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
keyField(String) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
The field name to use in order to control where the hit will "fall into" within the range entries.
keyField(String) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
 
keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
 
keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
Returns a specialized view of the keys of this associated container.
keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
Returns a specialized view of the keys of this associated container.
keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
 
keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
Returns a specialized view of the keys of this associated container.
keys - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
keyScript(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
keyScript(String) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
 
keySet() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
keySet() - Method in class org.elasticsearch.common.util.MinimalMap
 
keySet() - Method in class org.elasticsearch.search.lookup.DocLookup
 
keySet() - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
keySet() - Method in class org.elasticsearch.search.lookup.SourceLookup
 
keysFieldName() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesParser
 
keysFieldName() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksParser
 
keysFieldName() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesParser
 
keysIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
Returns a direct iterator over the keys.
keysIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
Returns a direct iterator over the keys.
keysIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
Returns a direct iterator over the keys.
keyTypeIsSet() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
KeyValueRangeFacetExecutor - Class in org.elasticsearch.search.facet.range
 
KeyValueRangeFacetExecutor(IndexNumericFieldData, IndexNumericFieldData, RangeFacet.Entry[], SearchContext) - Constructor for class org.elasticsearch.search.facet.range.KeyValueRangeFacetExecutor
 
KeyValueRangeFacetExecutor.RangeProc - Class in org.elasticsearch.search.facet.range
 
KEYWORD_ANALYZER - Static variable in class org.elasticsearch.common.lucene.Lucene
 
KeywordAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
KeywordAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeywordAnalyzerProvider
 
KeywordMarkerTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
KeywordMarkerTokenFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeywordMarkerTokenFilterFactory
 
KeywordTokenizerFactory - Class in org.elasticsearch.index.analysis
 
KeywordTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeywordTokenizerFactory
 
kilo() - Method in class org.elasticsearch.common.unit.SizeValue
 
kiloFrac() - Method in class org.elasticsearch.common.unit.SizeValue
 
KStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
KStemTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KStemTokenFilterFactory
 

L

label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
 
label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
 
label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
 
lang(String) - Method in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionBuilder
Sets the language of the script.
lang(String) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
Sets the script language.
lang() - Method in class org.elasticsearch.script.CompiledScript
 
lang() - Method in class org.elasticsearch.script.ScriptParameterParser
 
lang(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the script language.
lang(String) - Method in class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
 
lang(String) - Method in class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
Sets the language of the script (if one is defined).
lang(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
The language of the value script.
lang(String) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
lang(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
The language of the script.
lang(String) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
The language of the script.
lang(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
The language of the script.
lang(String) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
The language of the script.
lang(String) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
The language of the script.
lang(String) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
The language of the script.
LANG_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
 
LANGUID - Static variable in class org.elasticsearch.common.Priority
 
Laplace(double) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.Laplace
Creates a Laplace smoothing model.
LaplaceScorer - Class in org.elasticsearch.search.suggest.phrase
 
LaplaceScorer(IndexReader, Terms, String, double, BytesRef, double) - Constructor for class org.elasticsearch.search.suggest.phrase.LaplaceScorer
 
largest(Version, Version) - Static method in class org.elasticsearch.Version
Returns the largest version between the 2.
lastAccessTime() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
return the last time this RecoveryStatus was used (based on System.nanoTime()
lastAccessTime() - Method in class org.elasticsearch.percolator.PercolateContext
 
lastAccessTime() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
lastAccessTime() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
lastAccessTime() - Method in class org.elasticsearch.search.internal.SearchContext
 
lastChunk() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
Returns true if this chunk is the last chunk in the stream.
lastEmittedDoc(ScoreDoc) - Method in class org.elasticsearch.percolator.PercolateContext
 
lastEmittedDoc() - Method in class org.elasticsearch.percolator.PercolateContext
 
lastEmittedDoc() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
 
lastEmittedDoc(ScoreDoc) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
lastEmittedDoc() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
lastEmittedDoc(ScoreDoc) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
lastEmittedDoc() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
lastEmittedDoc(ScoreDoc) - Method in class org.elasticsearch.search.internal.SearchContext
 
lastEmittedDoc() - Method in class org.elasticsearch.search.internal.SearchContext
 
lastEmittedDoc(ScoreDoc) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
lastGc() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
LastGc(long, long, long, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
lastRefreshTimestamp - Variable in class org.elasticsearch.common.util.SingleObjectCache
 
lastTaskName() - Method in class org.elasticsearch.common.StopWatch
Return the name of the last task.
lastTaskTime() - Method in class org.elasticsearch.common.StopWatch
Return the time taken by the last task.
lastToken() - Method in class org.elasticsearch.search.aggregations.support.OrderPath
 
lat() - Method in class org.elasticsearch.common.geo.GeoPoint
 
LAT - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
lat(double) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
lat(double) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
lat() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
lat() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
lat(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
Set the latitude of the point to calculate distances from.
lat(double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The latitude to create the range distance facets from.
LAT_SUFFIX - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
LatchedActionListener<T> - Class in org.elasticsearch.action
An action listener that allows passing in a CountDownLatch that will be counted down after onResponse or onFailure is called
LatchedActionListener(ActionListener<T>, CountDownLatch) - Constructor for class org.elasticsearch.action.LatchedActionListener
 
LateParsingQuery(Object, Object, boolean, boolean, DateTimeZone, DateMathParser) - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper.LateParsingQuery
 
LATEST - Static variable in class org.elasticsearch.index.translog.TranslogStreams
 
LATEST_POSTINGS_FORMAT - Static variable in class org.elasticsearch.common.lucene.Lucene
 
latitude() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
 
LATITUDE - Static variable in class org.elasticsearch.common.geo.GeoUtils
 
latlon(String, double, double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
latlon(double, double) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
latMapper() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
LatvianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
LatvianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LatvianAnalyzerProvider
 
LAZY_VALUE - Static variable in enum org.elasticsearch.index.mapper.FieldMapper.Loading
 
LeafOnly(String, String, ValuesSourceConfig<VS>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory.LeafOnly
 
LEAST_USED_DISTRIBUTOR - Static variable in class org.elasticsearch.index.store.StoreModule
 
LeastUsedDistributor - Class in org.elasticsearch.index.store.distributor
Implements directory distributor that always return the directory is the most available space
LeastUsedDistributor(DirectoryService) - Constructor for class org.elasticsearch.index.store.distributor.LeastUsedDistributor
 
LEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
LEGACY_TRANSLOG_STREAM - Static variable in class org.elasticsearch.index.translog.TranslogStreams
V0, no header, no checksums
LegacyChecksums() - Constructor for class org.elasticsearch.index.store.Store.LegacyChecksums
 
legacyChecksums() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
LegacyTranslogStream - Class in org.elasticsearch.index.translog
Version 0 of the translog format, there is no header in this file
length() - Method in interface org.elasticsearch.common.blobstore.BlobMetaData
 
length() - Method in class org.elasticsearch.common.blobstore.support.PlainBlobMetaData
 
length() - Method in class org.elasticsearch.common.bytes.BytesArray
 
length() - Method in interface org.elasticsearch.common.bytes.BytesReference
The length.
length() - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
 
length() - Method in class org.elasticsearch.common.bytes.HashedBytesArray
 
length() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
 
length() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
Deprecated.
 
length() - Method in class org.elasticsearch.common.io.FastStringReader
 
length() - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSet
 
length() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.NotBits
 
length() - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
 
length() - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
The size of the expected results, including potential null values.
length() - Method in class org.elasticsearch.index.gateway.CommitPoint.FileInfo
 
length() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
File length
length() - Method in class org.elasticsearch.index.store.StoreFileMetaData
the actual file size on "disk", if compressed, the compressed size
length() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
length() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
Returns the internal length (*not* number of operations) of this snapshot.
length() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
length() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
file length *
length - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
lengthInBytes() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
lengthInBytes() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
The length in bytes of this stream.
LengthTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
LengthTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LengthTokenFilterFactory
 
lenient(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
lenient() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
lenient() - Static method in class org.elasticsearch.action.support.IndicesOptions
Deprecated.
in favor of IndicesOptions.lenientExpandOpen() whose name makes it clearer what the method actually does.
lenient(boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
Sets whether format based failures will be ignored.
lenient(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Sets the query string parser to be lenient when parsing field values, defaults to the index setting and if not set, defaults to false.
lenient(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryParser.Settings
 
lenient() - Method in class org.elasticsearch.index.query.SimpleQueryParser.Settings
 
lenient(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
 
lenient - Variable in class org.elasticsearch.index.search.MatchQuery
 
lenientExpandOpen() - Static method in class org.elasticsearch.action.support.IndicesOptions
 
lessThan(SignificantTerms.Bucket, SignificantTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.significant.BucketSignificancePriorityQueue
 
lessThan(Terms.Bucket, Terms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.support.BucketPriorityQueue
 
lessThan(TermsStringOrdinalsFacetExecutor.ReaderAggregator, TermsStringOrdinalsFacetExecutor.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor.AggregatorPriorityQueue
 
lessThan(TermsFacet.Entry, TermsFacet.Entry) - Method in class org.elasticsearch.search.facet.terms.support.EntryPriorityQueue
 
LetterTokenizerFactory - Class in org.elasticsearch.index.analysis
 
LetterTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LetterTokenizerFactory
 
levels() - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
lfAtEnd() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
lifecycle - Variable in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
Lifecycle - Class in org.elasticsearch.common.component
Lifecycle state.
Lifecycle() - Constructor for class org.elasticsearch.common.component.Lifecycle
 
Lifecycle.State - Enum in org.elasticsearch.common.component
 
LifecycleComponent<T> - Interface in org.elasticsearch.common.component
 
LifecycleListener - Class in org.elasticsearch.common.component
 
LifecycleListener() - Constructor for class org.elasticsearch.common.component.LifecycleListener
 
lifecycleState() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
lifecycleState() - Method in interface org.elasticsearch.common.component.LifecycleComponent
 
like(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Return a query that will return docs like the passed lucene document ID.
like(String, Reader...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Return a query that will return docs like the passed Readers.
like(Terms...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Return a query that will return docs like the passed Terms.
like(Fields...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Return a query that will return docs like the passed Fields.
LIKE_TEXT - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
likeText(String) - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
The text to use in order to find documents that are "like" this.
likeText(String) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
The text to use in order to find documents that are "like" this.
likeText(String) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
The text to use in order to find documents that are "like" this.
likeText(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
The text to use in order to find documents that are "like" this.
limit - Variable in class org.elasticsearch.percolator.PercolateContext
 
LIMIT - Static variable in class org.elasticsearch.search.facet.terms.support.EntryPriorityQueue
 
LIMIT_HEAP - Static variable in class org.elasticsearch.cache.recycler.PageCacheRecycler
 
LIMIT_PER_THREAD - Static variable in class org.elasticsearch.cache.recycler.PageCacheRecycler
 
LIMIT_PORTS_COUNT - Static variable in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
LimitDocIdSet(int, Bits, int) - Constructor for class org.elasticsearch.common.lucene.search.LimitFilter.LimitDocIdSet
 
LimitFilter - Class in org.elasticsearch.common.lucene.search
 
LimitFilter(int) - Constructor for class org.elasticsearch.common.lucene.search.LimitFilter
 
limitFilter(int) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter that limits the results to the provided limit value (per shard!).
LimitFilter.LimitDocIdSet - Class in org.elasticsearch.common.lucene.search
 
LimitFilterBuilder - Class in org.elasticsearch.index.query
 
LimitFilterBuilder(int) - Constructor for class org.elasticsearch.index.query.LimitFilterBuilder
 
LimitFilterParser - Class in org.elasticsearch.index.query
 
LimitFilterParser() - Constructor for class org.elasticsearch.index.query.LimitFilterParser
 
LimitTokenCountFilterFactory - Class in org.elasticsearch.index.analysis
 
LimitTokenCountFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LimitTokenCountFilterFactory
 
line(BaseLineStringBuilder<?>) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
 
linearDecayFunction(String, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
linearDecayFunction(String, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
LinearDecayFunctionBuilder - Class in org.elasticsearch.index.query.functionscore.lin
 
LinearDecayFunctionBuilder(String, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.lin.LinearDecayFunctionBuilder
 
LinearDecayFunctionParser - Class in org.elasticsearch.index.query.functionscore.lin
 
LinearDecayFunctionParser() - Constructor for class org.elasticsearch.index.query.functionscore.lin.LinearDecayFunctionParser
 
LinearInterpoatingScorer - Class in org.elasticsearch.search.suggest.phrase
 
LinearInterpoatingScorer(IndexReader, Terms, String, double, BytesRef, double, double, double) - Constructor for class org.elasticsearch.search.suggest.phrase.LinearInterpoatingScorer
 
LinearInterpolation(double, double, double) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.LinearInterpolation
Creates a linear interpolation smoothing model.
linearRing(GeometryFactory, ArrayList<Coordinate>) - Static method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
 
linestring() - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
 
linestring(BaseLineStringBuilder<?>) - Method in class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
 
LineStringBuilder - Class in org.elasticsearch.common.geo.builders
 
LineStringBuilder() - Constructor for class org.elasticsearch.common.geo.builders.LineStringBuilder
 
LinkedBindingBuilder<T> - Interface in org.elasticsearch.common.inject.binder
See the EDSL examples at Binder.
LinkedBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
 
LinkedBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Key<? extends T>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedBindingImpl
 
LinkedBindingImpl(Object, Key<T>, Scoping, Key<? extends T>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedBindingImpl
 
LinkedKeyBinding<T> - Interface in org.elasticsearch.common.inject.spi
A binding to a linked key.
LinkedProviderBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
 
LinkedProviderBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Key<? extends Provider<? extends T>>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
 
LINUX - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on Linux.
list(String[], TimeValue) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
list(ShardId, String[], TimeValue) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
list(ShardId, boolean, String[], TimeValue) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
LIST - Static variable in class org.elasticsearch.plugins.PluginManager.ACTION
 
listAll() - Method in class org.elasticsearch.index.store.DistributorDirectory
 
listBlobs() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
listBlobs() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
listBlobs() - Method in class org.elasticsearch.common.blobstore.url.URLBlobContainer
This operation is not supported by URLBlobContainer
listBlobsByPrefix(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
listBlobsByPrefix(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
listBlobsByPrefix(String) - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
 
listBlobsByPrefix(String) - Method in class org.elasticsearch.common.blobstore.url.URLBlobContainer
This operation is not supported by URLBlobContainer
listedNodes() - Method in class org.elasticsearch.client.transport.TransportClient
Returns the listed nodes in the transport client (ones added to it).
listedNodes() - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
ListenableActionFuture<T> - Interface in org.elasticsearch.action
An ActionFuture that listeners can be added to.
listener - Variable in class org.elasticsearch.action.ActionRunnable
 
listener - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
listener - Variable in class org.elasticsearch.common.network.MulticastChannel
 
Listener() - Constructor for class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.Listener
 
listener() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
listener() - Method in class org.elasticsearch.index.mapper.ParseContext
 
Listener() - Constructor for class org.elasticsearch.indices.IndicesLifecycle.Listener
 
Listener() - Constructor for class org.elasticsearch.indices.IndicesWarmer.Listener
 
LISTENER - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
listeners - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
 
listeners() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
Returns a list of listeners
listenerThreaded() - Method in class org.elasticsearch.action.ActionRequest
Should the response listener be executed on a thread or not.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.ActionRequest
Sets if the response listener be executed on a thread or not.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
 
listFactories() - Static method in class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormats
 
listFactories() - Static method in class org.elasticsearch.index.codec.postingsformat.PostingFormats
 
listFactories() - Static method in class org.elasticsearch.index.similarity.Similarities
Returns the list of pre-defined SimilarityProvider Factories
listInstalledPlugins() - Method in class org.elasticsearch.plugins.PluginManager
 
listOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
Returns a type modelling a List whose elements are of type elementType.
LMDirichletSimilarityProvider - Class in org.elasticsearch.index.similarity
SimilarityProvider for LMDirichletSimilarity.
LMDirichletSimilarityProvider(String, Settings) - Constructor for class org.elasticsearch.index.similarity.LMDirichletSimilarityProvider
 
LMJelinekMercerSimilarityProvider - Class in org.elasticsearch.index.similarity
SimilarityProvider for LMJelinekMercerSimilarity.
LMJelinekMercerSimilarityProvider(String, Settings) - Constructor for class org.elasticsearch.index.similarity.LMJelinekMercerSimilarityProvider
 
load(InputStream) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
 
load(DataInput) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
 
load(String) - Method in class org.elasticsearch.common.settings.loader.PropertiesSettingsLoader
 
load(byte[]) - Method in class org.elasticsearch.common.settings.loader.PropertiesSettingsLoader
 
load(String) - Method in interface org.elasticsearch.common.settings.loader.SettingsLoader
Loads (parses) the settings from a source string.
load(byte[]) - Method in interface org.elasticsearch.common.settings.loader.SettingsLoader
Loads (parses) the settings from a source bytes.
load(String) - Method in class org.elasticsearch.common.settings.loader.XContentSettingsLoader
 
load(byte[]) - Method in class org.elasticsearch.common.settings.loader.XContentSettingsLoader
 
load(XContentParser) - Method in class org.elasticsearch.common.settings.loader.XContentSettingsLoader
 
load(String) - Method in class org.elasticsearch.common.settings.loader.YamlSettingsLoader
 
load(AtomicReaderContext) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
Loads the atomic field data for the reader, possibly cached.
load(AtomicReaderContext, IFD) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
load(IndexReader, IFD) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
load(AtomicReaderContext, IFD) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
 
load(IndexReader, IFD) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
 
load(AtomicReaderContext, IFD) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
 
load(IndexReader, IFD) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVNumericIndexFieldData
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.GeoPointBinaryDVIndexFieldData
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.IndexIndexFieldData
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.NumericDVIndexFieldData
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
 
load(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
 
load(IndexFieldData<?>, SearchContext) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData
 
load(IndexInput) - Method in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
 
load(IndexInput) - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionLookupProvider
 
load(String, Map<String, Object>) - Static method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
Load the specification of a CategoryContextMapping
load(String, Map<String, Object>) - Static method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
load a GeolocationContextMapping by configuration.
LOAD_PLUGIN_FROM_CLASSPATH - Static variable in class org.elasticsearch.plugins.PluginsService
 
LOAD_RANDOM_ACCESS_FILTERS_EAGERLY - Static variable in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
loadAverage() - Method in class org.elasticsearch.monitor.os.OsStats
 
loadClass(ClassLoader, String, String, String) - Static method in class org.elasticsearch.common.Classes
 
loadClass(ClassLoader, String, String, String, String) - Static method in class org.elasticsearch.common.Classes
 
loadClass(String) - Method in class org.elasticsearch.common.io.ThrowableObjectInputStream
 
loadConfig(Path, ImmutableSettings.Builder) - Static method in class org.elasticsearch.common.logging.log4j.LogConfigurator
 
loadConfigSettings(boolean) - Method in class org.elasticsearch.node.NodeBuilder
Should the node builder automatically try and load config settings from the file system / classpath.
loadCurrentFieldValue() - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
loadDirect(AtomicReaderContext) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
Loads directly the atomic field data for the reader, ignoring any caching involved.
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVNumericIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.DisabledIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.DoubleArrayIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.FloatArrayIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.FSTBytesIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.GeoPointBinaryDVIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.GeoPointCompressedIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.IndexIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.NumericDVIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.PackedArrayIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
 
loadDirect(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
 
loadDocIdAndVersion(IndexReader, Term) - Static method in class org.elasticsearch.common.lucene.uid.Versions
Load the internal doc ID and version for the uid from the reader, returning null if the uid wasn't found, a doc ID and a version otherwise, the version being potentially set to Versions.NOT_SET if the uid has no associated version
loaderFromResource(String) - Static method in class org.elasticsearch.common.settings.loader.SettingsLoaderFactory
Returns a SettingsLoader based on the resource name.
loaderFromSource(String) - Static method in class org.elasticsearch.common.settings.loader.SettingsLoaderFactory
Returns a SettingsLoader based on the actual settings source.
loadFieldValues(IndexSearcher, String[], int[], int) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
loadFieldValues(IndexSearcher, String[], int[], int) - Method in class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Loads the String values for each field X docID to be highlighted.
loadFromClasspath(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Loads settings from classpath that represents them using the SettingsLoaderFactory.loaderFromSource(String).
loadFromDelimitedString(String, char) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
 
loadFromSource(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Loads settings from the actual string content that represents them using the SettingsLoaderFactory.loaderFromSource(String).
loadFromStream(String, InputStream) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Loads settings from a stream that represents them using the SettingsLoaderFactory.loaderFromSource(String).
loadFromUrl(URL) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Loads settings from a url that represents them using the SettingsLoaderFactory.loaderFromSource(String).
loadGlobal(IndexReader) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Global
 
loadGlobal(IndexReader) - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
Load a global view of the ordinals for the given IndexReader, potentially from a cache.
loadGlobal(IndexReader) - Method in interface org.elasticsearch.index.fielddata.IndexParentChildFieldData
Load a global view of the ordinals for the given IndexReader, potentially from a cache.
loadGlobal(IndexReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
 
loadGlobal(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
 
loadGlobal(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.IndexIndexFieldData
 
loadGlobal(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
 
loadGlobal(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
 
loadIntoContext(ShardSearchRequest, SearchContext, QueryPhase) - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache
Loads the cache result, computing it if needed by executing the query phase and otherwise deserializing the cached value into the context's query result.
loadLatestState(ESLogger, File...) - Method in class org.elasticsearch.gateway.local.state.meta.MetaDataStateFormat
Tries to load the latest state from the given data-locations.
loadMapping(String, Map<String, Object>) - Static method in class org.elasticsearch.search.suggest.context.ContextBuilder
 
loadMappings(Object) - Static method in class org.elasticsearch.search.suggest.context.ContextBuilder
 
loadMetaState() - Method in class org.elasticsearch.gateway.local.state.meta.LocalGatewayMetaState
 
loadNestedFromMap(Map) - Static method in class org.elasticsearch.common.settings.loader.SettingsLoader.Helper
 
loadShardInfo(ShardId) - Method in class org.elasticsearch.gateway.local.state.shards.LocalGatewayShardsState
 
loadSource() - Method in class org.elasticsearch.index.engine.Engine.Get
 
loadSource(boolean) - Method in class org.elasticsearch.index.engine.Engine.Get
 
loadVersion(IndexReader, Term) - Static method in class org.elasticsearch.common.lucene.uid.Versions
Load the version for the uid from the reader, returning Versions.NOT_FOUND if no matching doc exists, Versions.NOT_SET if no version is available, the version associated with the provided uid otherwise
loadWordList(Reader, String) - Static method in class org.elasticsearch.index.analysis.Analysis
 
local - Variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
 
local(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
Indicate whether the receiving node should operate based on local index information or forward requests, where needed, to other nodes.
local() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
 
local - Variable in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequest
 
local(boolean) - Method in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequest
 
local() - Method in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequest
 
LOCAL - Static variable in class org.elasticsearch.common.network.NetworkService
 
local(boolean) - Method in class org.elasticsearch.node.NodeBuilder
Is the node a local node.
LOCAL_MLOCKALL - Static variable in class org.elasticsearch.common.jna.Natives
 
LOCAL_TRANSPORT_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.local.LocalTransport
 
LocalAllocateDangledIndices - Class in org.elasticsearch.gateway.local.state.meta
 
LocalAllocateDangledIndices(Settings, TransportService, ClusterService, AllocationService) - Constructor for class org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices
 
LocalAllocateDangledIndices.AllocateDangledResponse - Class in org.elasticsearch.gateway.local.state.meta
 
LocalAllocateDangledIndices.Listener - Interface in org.elasticsearch.gateway.local.state.meta
 
LocalDiscovery - Class in org.elasticsearch.discovery.local
 
LocalDiscovery(Settings, ClusterName, TransportService, ClusterService, DiscoveryNodeService, Version, DiscoverySettings) - Constructor for class org.elasticsearch.discovery.local.LocalDiscovery
 
LocalDiscoveryModule - Class in org.elasticsearch.discovery.local
 
LocalDiscoveryModule() - Constructor for class org.elasticsearch.discovery.local.LocalDiscoveryModule
 
locale(Locale) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
locale() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
locale() - Method in class org.elasticsearch.common.joda.FormatDateTimeFormatter
 
locale(Locale) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
locale(Locale) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
 
locale(Locale) - Method in class org.elasticsearch.index.query.SimpleQueryParser.Settings
 
locale() - Method in class org.elasticsearch.index.query.SimpleQueryParser.Settings
 
locale(Locale) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
 
LocaleUtils - Class in org.elasticsearch.common.util
Utilities for for dealing with Locale objects
LocaleUtils() - Constructor for class org.elasticsearch.common.util.LocaleUtils
 
localExecute(Request) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
localExecute(Request) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeReadOperationAction
 
LocalGateway - Class in org.elasticsearch.gateway.local
 
LocalGateway(Settings, ClusterService, NodeEnvironment, LocalGatewayShardsState, LocalGatewayMetaState, TransportNodesListGatewayMetaState, ClusterName) - Constructor for class org.elasticsearch.gateway.local.LocalGateway
 
LocalGatewayAllocator - Class in org.elasticsearch.gateway.local
 
LocalGatewayAllocator(Settings, TransportNodesListGatewayStartedShards, TransportNodesListShardStoreMetaData) - Constructor for class org.elasticsearch.gateway.local.LocalGatewayAllocator
 
LocalGatewayMetaState - Class in org.elasticsearch.gateway.local.state.meta
 
LocalGatewayMetaState(Settings, ThreadPool, NodeEnvironment, TransportNodesListGatewayMetaState, LocalAllocateDangledIndices, IndicesService, ClusterService) - Constructor for class org.elasticsearch.gateway.local.state.meta.LocalGatewayMetaState
 
LocalGatewayModule - Class in org.elasticsearch.gateway.local
 
LocalGatewayModule() - Constructor for class org.elasticsearch.gateway.local.LocalGatewayModule
 
LocalGatewayShardsState - Class in org.elasticsearch.gateway.local.state.shards
 
LocalGatewayShardsState(Settings, NodeEnvironment, TransportNodesListGatewayStartedShards) - Constructor for class org.elasticsearch.gateway.local.state.shards.LocalGatewayShardsState
 
localGlobalDirect(IndexReader) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Global
 
localGlobalDirect(IndexReader) - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
Load a global view of the ordinals for the given IndexReader.
localGlobalDirect(IndexReader) - Method in interface org.elasticsearch.index.fielddata.IndexParentChildFieldData
Load a global view of the ordinals for the given IndexReader.
localGlobalDirect(IndexReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
 
localGlobalDirect(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
 
localGlobalDirect(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.IndexIndexFieldData
 
localGlobalDirect(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
 
localGlobalDirect(IndexReader) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
 
LocalIndexGateway - Class in org.elasticsearch.index.gateway.local
 
LocalIndexGateway(Index, Settings) - Constructor for class org.elasticsearch.index.gateway.local.LocalIndexGateway
 
LocalIndexGatewayModule - Class in org.elasticsearch.index.gateway.local
 
LocalIndexGatewayModule() - Constructor for class org.elasticsearch.index.gateway.local.LocalIndexGatewayModule
 
LocalIndexShardGateway - Class in org.elasticsearch.index.gateway.local
 
LocalIndexShardGateway(ShardId, Settings, ThreadPool, MappingUpdatedAction, IndexService, IndexShard) - Constructor for class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
localNode() - Method in interface org.elasticsearch.cluster.ClusterService
The local node.
localNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
 
localNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Get the local node
localNode() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
localNode() - Method in interface org.elasticsearch.discovery.Discovery
 
localNode() - Method in class org.elasticsearch.discovery.DiscoveryService
 
localNode() - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
localNode() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
localNodeId(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
localNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Get the id of the local node
localNodeId() - Method in class org.elasticsearch.env.NodeEnvironment
 
LocalNodeId - Annotation Type in org.elasticsearch.index
 
LocalNodeIdModule - Class in org.elasticsearch.index
 
LocalNodeIdModule(String) - Constructor for class org.elasticsearch.index.LocalNodeIdModule
 
localNodeMaster() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
localNodeMaster() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Returns true if the local node is the master node.
LocalNodeMasterListener - Interface in org.elasticsearch.cluster
Enables listening to master changes events of the local node (when the local node becomes the master, and when the local node cease being a master).
LocalTransport - Class in org.elasticsearch.transport.local
 
LocalTransport(Settings, ThreadPool, Version) - Constructor for class org.elasticsearch.transport.local.LocalTransport
 
LocalTransportAddress - Class in org.elasticsearch.common.transport
 
LocalTransportAddress(String) - Constructor for class org.elasticsearch.common.transport.LocalTransportAddress
 
LocalTransportChannel - Class in org.elasticsearch.transport.local
 
LocalTransportChannel(LocalTransport, TransportServiceAdapter, LocalTransport, String, long, Version) - Constructor for class org.elasticsearch.transport.local.LocalTransportChannel
 
Location(long, long, int) - Constructor for class org.elasticsearch.index.translog.Translog.Location
 
location(String) - Static method in class org.elasticsearch.search.suggest.context.ContextBuilder
location(String, int, boolean) - Static method in class org.elasticsearch.search.suggest.context.ContextBuilder
Create a new GeolocationContextMapping with given precision and neighborhood usage
locations() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
lock() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
 
lockAllForIndex(Index, Settings, long) - Method in class org.elasticsearch.env.NodeEnvironment
Tries to lock all local shards for the given index.
locked(Recycler<T>) - Static method in enum org.elasticsearch.common.recycler.Recyclers
Wrap the provided recycler so that calls to Recycler.obtain() and Releasable.close() are protected by a lock.
lockedShards() - Method in class org.elasticsearch.env.NodeEnvironment
Returns all currently lock shards
lockInterruptibly() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
 
log(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log10(Short) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log10(Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log10(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log10(Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log10(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
log1p(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
Log4jESLogger - Class in org.elasticsearch.common.logging.log4j
 
Log4jESLogger(String, Logger) - Constructor for class org.elasticsearch.common.logging.log4j.Log4jESLogger
 
Log4jESLoggerFactory - Class in org.elasticsearch.common.logging.log4j
 
Log4jESLoggerFactory() - Constructor for class org.elasticsearch.common.logging.log4j.Log4jESLoggerFactory
 
LogByteSizeMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
LogByteSizeMergePolicyProvider(Store, IndexSettingsService) - Constructor for class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
LogConfigurator - Class in org.elasticsearch.common.logging.log4j
 
LogConfigurator() - Constructor for class org.elasticsearch.common.logging.log4j.LogConfigurator
 
logDeleteFile(String, String) - Method in class org.elasticsearch.index.store.Store
Log that we are about to delete this file, to the index.store.deletes component.
logDeleteFile(Directory, String, String) - Static method in class org.elasticsearch.index.store.Store
Log that we are about to delete this file, to the index.store.deletes component.
LogDocMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
LogDocMergePolicyProvider(Store, IndexSettingsService) - Constructor for class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
logger - Variable in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
logger - Variable in class org.elasticsearch.cluster.ClusterStateObserver
 
logger - Variable in class org.elasticsearch.common.component.AbstractComponent
 
LOGGER - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
 
logger() - Method in class org.elasticsearch.common.logging.jdk.JdkESLogger
 
logger() - Method in class org.elasticsearch.common.logging.log4j.Log4jESLogger
 
logger() - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLogger
 
logger - Variable in class org.elasticsearch.index.AbstractIndexComponent
 
logger - Variable in class org.elasticsearch.index.engine.Engine
 
logger - Variable in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData
 
logger - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
logger() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
 
logger - Variable in class org.elasticsearch.indices.recovery.RecoverySourceHandler
 
logger - Variable in class org.elasticsearch.river.AbstractRiverComponent
 
logger - Variable in class org.elasticsearch.transport.netty.MessageChannelHandler
 
LoggerInfoStream - Class in org.elasticsearch.common.lucene
An InfoStream (for Lucene's IndexWriter) that redirects messages to "lucene.iw.ifd" and "lucene.iw" Logger.trace.
LoggerInfoStream(ESLogger) - Constructor for class org.elasticsearch.common.lucene.LoggerInfoStream
 
LoggerMessageFormat - Class in org.elasticsearch.common.logging.support
 
LoggerMessageFormat() - Constructor for class org.elasticsearch.common.logging.support.LoggerMessageFormat
 
Loggers - Class in org.elasticsearch.common.logging
A set of utilities around Logging.
Loggers() - Constructor for class org.elasticsearch.common.logging.Loggers
 
LoggingRunnable - Class in org.elasticsearch.common.util.concurrent
 
LoggingRunnable(ESLogger, Runnable) - Constructor for class org.elasticsearch.common.util.concurrent.LoggingRunnable
 
logsFile() - Method in class org.elasticsearch.env.Environment
 
lon() - Method in class org.elasticsearch.common.geo.GeoPoint
 
LON - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
lon(double) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
lon(double) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
lon() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
lon() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
lon(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
Set the longitude of the point to calculate distances from.
lon(double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The longitude to create the range distance facets from.
LON_SUFFIX - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
LONG_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.BigArrays
 
LongAccessor() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
 
LongAdder - Class in jsr166e
One or more variables that together maintain an initially zero long sum.
LongAdder() - Constructor for class jsr166e.LongAdder
Creates a new adder with initial sum of zero.
LongArray - Interface in org.elasticsearch.common.util
Abstraction of an array of long values.
LongEntry(long, int) - Constructor for class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
LongEntry(long, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
longestOnly() - Method in class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
 
LongFacetAggregatorBase - Class in org.elasticsearch.search.facet
Simple Facet aggregator base class for LongValues
LongFacetAggregatorBase() - Constructor for class org.elasticsearch.search.facet.LongFacetAggregatorBase
 
longField(FieldInfo, long) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
longField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
LongFieldMapper - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper(FieldMapper.Names, int, float, FieldType, Boolean, Long, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper
 
LongFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper.CustomLongNumericField - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
LongHash - Class in org.elasticsearch.common.util
Specialized hash table implementation similar to BytesRefHash that maps long values to ids.
LongHash(long, BigArrays) - Constructor for class org.elasticsearch.common.util.LongHash
 
LongHash(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.LongHash
 
longIntMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
longIntMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
longitude() - Method in class org.elasticsearch.common.geo.builders.PointBuilder
 
LONGITUDE - Static variable in class org.elasticsearch.common.geo.GeoUtils
 
longLongMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
longLongMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
LongMaxUpdater - Class in jsr166e
One or more variables that together maintain a running long maximum with initial value Long.MIN_VALUE.
LongMaxUpdater() - Constructor for class jsr166e.LongMaxUpdater
Creates a new instance with initial maximum of Long.MIN_VALUE.
longObjectMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
longObjectMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
LongObjectPagedHashMap<T> - Class in org.elasticsearch.common.util
A hash table from native longs to objects.
LongObjectPagedHashMap(BigArrays) - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap
 
LongObjectPagedHashMap(long, BigArrays) - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap
 
LongObjectPagedHashMap(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap
 
LongObjectPagedHashMap.Cursor<T> - Class in org.elasticsearch.common.util
 
longPage(boolean) - Method in class org.elasticsearch.cache.recycler.PageCacheRecycler
 
Longs(SortedNumericDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
 
LongsFieldDataFilter(IndexNumericFieldData, LongOpenHashSet) - Constructor for class org.elasticsearch.index.search.FieldDataTermsFilter.LongsFieldDataFilter
 
LongTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
 
LongTerms(String, Terms.Order, ValueFormatter, int, int, long, List<InternalTerms.Bucket>, boolean, long, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
 
LongTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
 
LongTermsAggregator(String, AggregatorFactories, ValuesSource.Numeric, ValueFormat, long, Terms.Order, TermsAggregator.BucketCountThresholds, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, boolean, IncludeExclude.LongFilter) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
longToBytes(long) - Static method in class org.elasticsearch.common.Numbers
Converts a long to a byte array.
longToIp(long) - Static method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
longValue() - Method in class jsr166e.DoubleAdder
Returns the sum() as a long after a narrowing primitive conversion.
longValue() - Method in class jsr166e.DoubleMaxUpdater
Returns the DoubleMaxUpdater.max() as a long after a narrowing primitive conversion.
longValue() - Method in class jsr166e.LongAdder
Equivalent to LongAdder.sum().
longValue() - Method in class jsr166e.LongMaxUpdater
Equivalent to LongMaxUpdater.max().
longValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
longValue(boolean) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
longValue(boolean) - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
longValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
longValue() - Method in class org.elasticsearch.script.ScoreAccessor
 
longValue() - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.LongAccessor
 
longValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
 
longValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
Get the current LongValues.
longValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
 
longValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
 
LongValuesComparatorSource - Class in org.elasticsearch.index.fielddata.fieldcomparator
Comparator source for long values.
LongValuesComparatorSource(IndexNumericFieldData, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
 
lonMapper() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
 
lookup(Settings, String, Map<String, DocValuesFormatProvider.Factory>) - Static method in class org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatProvider.Helper
Looks up and creates DocValuesFormatProvider for the given name.
lookup(Settings, String, Map<String, PostingsFormatProvider.Factory>) - Static method in class org.elasticsearch.index.codec.postingsformat.PostingsFormatProvider.Helper
Looks up and creates PostingsFormatProvider for the given name.
lookup() - Method in class org.elasticsearch.index.query.QueryParseContext
 
lookup() - Method in class org.elasticsearch.percolator.PercolateContext
 
lookup() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
lookup() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
lookup() - Method in class org.elasticsearch.search.internal.SearchContext
 
lookup() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
lookupCache(boolean) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
 
lookupFactory(String) - Static method in class org.elasticsearch.cluster.ClusterState
 
lookupFactory(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
lookupFactory(String) - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
lookupFactory(String) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
 
LookupFactory() - Constructor for class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.LookupFactory
 
lookupFactorySafe(String) - Static method in class org.elasticsearch.cluster.ClusterState
 
lookupFactorySafe(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
lookupFactorySafe(String) - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
lookupFactorySafe(String) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
 
lookupId(String) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
Sets the doc id to lookup the terms from.
lookupIndex(String) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
Sets the index name to lookup the terms from.
lookupOrd(long) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalMapping
 
lookupOrd(long) - Method in interface org.elasticsearch.index.fielddata.ordinals.Ordinals.ValuesHolder
 
lookupPath(String) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
Sets the path within the document to lookup the terms from.
lookupRouting(String) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
 
lookupType(String) - Method in class org.elasticsearch.index.query.TermsLookupFilterBuilder
Sets the index type to lookup the terms from.
LOW - Static variable in class org.elasticsearch.common.Priority
 
LowCardinality(String, AggregatorFactories, ValuesSource.Bytes.WithOrdinals.FieldData, long, long, Terms.Order, TermsAggregator.BucketCountThresholds, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.LowCardinality
 
lowercase() - Method in enum org.elasticsearch.action.index.IndexRequest.OpType
 
lowercaseExpandedTerms() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
lowercaseExpandedTerms(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
lowercaseExpandedTerms(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Whether terms of wildcard, prefix, fuzzy and range queries are to be automatically lower-cased or not.
lowercaseExpandedTerms(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryParser.Settings
 
lowercaseExpandedTerms() - Method in class org.elasticsearch.index.query.SimpleQueryParser.Settings
 
lowercaseExpandedTerms(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
 
LowerCaseTokenFilterFactory - Class in org.elasticsearch.index.analysis
Factory for LowerCaseFilter and some language-specific variants supported by the language parameter: greek: GreekLowerCaseFilter irish: IrishLowerCaseFilter turkish: TurkishLowerCaseFilter
LowerCaseTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LowerCaseTokenFilterFactory
 
LowerCaseTokenizerFactory - Class in org.elasticsearch.index.analysis
 
LowerCaseTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LowerCaseTokenizerFactory
 
lowFreqMinimumShouldMatch(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
Sets the minimum number of low frequent query terms that need to match in order to produce a hit.
lowFreqOperator(CommonTermsQueryBuilder.Operator) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
Sets the operator to use for terms with a low document frequency (less than CommonTermsQueryBuilder.cutoffFrequency(float).
lt(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
lt(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lt(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lt(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lt(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lt(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lt(Object) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lt(int) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lt(long) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lt(float) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lt(double) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lt(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lt(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lt(int) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lt(long) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lt(float) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lt(double) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lte(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
lte(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lte(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lte(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lte(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lte(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
lte(int) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lte(long) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lte(float) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lte(double) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lte(Object) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
lte(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lte(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lte(int) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lte(long) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lte(float) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
lte(double) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
The to part of the range query.
Lucene - Class in org.elasticsearch.common.lucene
 
Lucene.EarlyTerminatingCollector - Class in org.elasticsearch.common.lucene
A collector that terminates early by throwing Lucene.EarlyTerminationException when count of matched documents has reached maxCountHits
Lucene.EarlyTerminationException - Exception in org.elasticsearch.common.lucene
This exception is thrown when Lucene.EarlyTerminatingCollector reaches early termination
LUCENE_FREQUENCY - Static variable in class org.elasticsearch.search.suggest.SuggestUtils
 
luceneBloomFilter - Static variable in class org.elasticsearch.index.codec.postingsformat.PostingFormats
 
luceneVersion - Variable in class org.elasticsearch.Version
 
LZFCompressedIndexInput - Class in org.elasticsearch.common.compress.lzf
Deprecated.
LZFCompressedIndexInput(IndexInput, ChunkDecoder) - Constructor for class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
Deprecated.
 
LZFCompressedStreamInput - Class in org.elasticsearch.common.compress.lzf
 
LZFCompressedStreamInput(StreamInput, ChunkDecoder) - Constructor for class org.elasticsearch.common.compress.lzf.LZFCompressedStreamInput
 
LZFCompressedStreamOutput - Class in org.elasticsearch.common.compress.lzf
 
LZFCompressedStreamOutput(StreamOutput) - Constructor for class org.elasticsearch.common.compress.lzf.LZFCompressedStreamOutput
 
LZFCompressor - Class in org.elasticsearch.common.compress.lzf
 
LZFCompressor() - Constructor for class org.elasticsearch.common.compress.lzf.LZFCompressor
 
LZFCompressorContext - Class in org.elasticsearch.common.compress.lzf
 
LZFCompressorContext() - Constructor for class org.elasticsearch.common.compress.lzf.LZFCompressorContext
 

M

MAC - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on Mac.
macAddress() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
MacAddressProvider - Class in org.elasticsearch.common
 
MacAddressProvider() - Constructor for class org.elasticsearch.common.MacAddressProvider
 
main(String[]) - Static method in class org.elasticsearch.bootstrap.Bootstrap
 
main(String[]) - Static method in class org.elasticsearch.bootstrap.Elasticsearch
 
main(String[]) - Static method in class org.elasticsearch.bootstrap.ElasticsearchF
 
main(String[]) - Static method in class org.elasticsearch.bootstrap.JVMCheck
Command line driver for convenience
main(String[]) - Static method in class org.elasticsearch.node.internal.InternalNode
 
main(String[]) - Static method in class org.elasticsearch.plugins.PluginManager
 
main(String[]) - Static method in class org.elasticsearch.Version
 
mainDocIdSetCollector() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
major - Variable in class org.elasticsearch.Version
 
makeFragment(StringBuilder, int[], Field[], FieldFragList.WeightedFragInfo, String[], String[], Encoder) - Method in class org.elasticsearch.search.highlight.vectorhighlight.SimpleFragmentsBuilder
 
makeFragment(StringBuilder, int[], Field[], FieldFragList.WeightedFragInfo, String[], String[], Encoder) - Method in class org.elasticsearch.search.highlight.vectorhighlight.SourceScoreOrderFragmentsBuilder
 
makeKeySafe(TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
Returns an equivalent type that's safe for use in a key.
makeSafe() - Method in interface org.elasticsearch.search.facet.terms.strings.HashedAggregator.BytesRefCountIterator
 
makeTransientCurrent() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
makeTransientCurrent() - Method in interface org.elasticsearch.index.translog.Translog
Swaps the transient translog to be the current one.
MANAGEMENT - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
map() - Method in class org.elasticsearch.common.collect.MapBuilder
 
map() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
map(Map<String, ?>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
map() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
MAP_SCRIPT - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
 
MAP_UNMAPPED_FIELDS_AS_STRING - Variable in class org.elasticsearch.index.percolator.PercolatorQueriesRegistry
 
mapAndClose() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
mapAndClose() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
MapBinder<K,V> - Class in org.elasticsearch.common.inject.multibindings
An API to bind multiple map entries separately, only to later inject them as a complete map.
MapBuilder<K,V> - Class in org.elasticsearch.common.collect
 
MapBuilder() - Constructor for class org.elasticsearch.common.collect.MapBuilder
 
MapBuilder(Map<K, V>) - Constructor for class org.elasticsearch.common.collect.MapBuilder
 
mapOf(Type, Type) - Static method in class org.elasticsearch.common.inject.util.Types
Returns a type modelling a Map whose keys are of type keyType and whose values are of type valueType.
mapOrdered() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
mapOrdered() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
mapOrderedAndClose() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
mapOrderedAndClose() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
MapParams(Map<String, String>) - Constructor for class org.elasticsearch.common.xcontent.ToXContent.MapParams
 
mapper - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
 
mapper() - Method in class org.elasticsearch.index.mapper.FieldMappers
 
Mapper - Interface in org.elasticsearch.index.mapper
 
mapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
The first mapper for the smart named field.
mapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameObjectMapper
 
mapper() - Method in class org.elasticsearch.index.mapper.ObjectMappers
 
mapper() - Method in class org.elasticsearch.search.aggregations.support.FieldContext
 
mapper(DateFieldMapper) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueFormat.DateTime
 
mapper(DateFieldMapper) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
 
mapper(DateFieldMapper) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueParser.DateMath
 
mapper - Variable in class org.elasticsearch.search.highlight.HighlighterContext
 
mapper - Variable in class org.elasticsearch.search.highlight.vectorhighlight.SimpleFragmentsBuilder
 
mapper() - Method in class org.elasticsearch.search.lookup.FieldLookup
 
mapper() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
 
mapper(CompletionFieldMapper) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
 
Mapper.Builder<T extends Mapper.Builder,Y extends Mapper> - Class in org.elasticsearch.index.mapper
 
Mapper.BuilderContext - Class in org.elasticsearch.index.mapper
 
Mapper.TypeParser - Interface in org.elasticsearch.index.mapper
 
Mapper.TypeParser.ParserContext - Class in org.elasticsearch.index.mapper
 
MapperBuilders - Class in org.elasticsearch.index.mapper
 
MapperCompressionException - Exception in org.elasticsearch.index.mapper
 
MapperCompressionException(String) - Constructor for exception org.elasticsearch.index.mapper.MapperCompressionException
 
MapperCompressionException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.MapperCompressionException
 
MapperException - Exception in org.elasticsearch.index.mapper
 
MapperException(String) - Constructor for exception org.elasticsearch.index.mapper.MapperException
 
MapperException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.MapperException
 
MapperParsingException - Exception in org.elasticsearch.index.mapper
 
MapperParsingException(String) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
 
MapperParsingException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
 
MapperQueryParser - Class in org.apache.lucene.queryparser.classic
A query parser that uses the MapperService in order to build smarter queries based on the mapping information.
MapperQueryParser(QueryParseContext) - Constructor for class org.apache.lucene.queryparser.classic.MapperQueryParser
 
MapperQueryParser(QueryParserSettings, QueryParseContext) - Constructor for class org.apache.lucene.queryparser.classic.MapperQueryParser
 
mappers() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
mappers - Variable in class org.elasticsearch.index.mapper.FieldMapperListener.Aggregator
 
mappers() - Method in class org.elasticsearch.index.mapper.FieldMappers
 
mappers - Variable in class org.elasticsearch.index.mapper.ObjectMapperListener.Aggregator
 
mappers() - Method in class org.elasticsearch.index.mapper.ObjectMappers
 
mappersBuilders - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
mapperService() - Method in class org.elasticsearch.index.codec.CodecService
 
mapperService() - Method in class org.elasticsearch.index.IndexService
 
MapperService - Class in org.elasticsearch.index.mapper
 
MapperService(Index, Settings, Environment, AnalysisService, IndexFieldDataService, PostingsFormatService, DocValuesFormatService, SimilarityLookupService, ScriptService) - Constructor for class org.elasticsearch.index.mapper.MapperService
 
mapperService() - Method in class org.elasticsearch.index.query.QueryParseContext
 
mapperService() - Method in class org.elasticsearch.index.shard.IndexShard
 
mapperService() - Method in class org.elasticsearch.index.similarity.SimilarityService
 
mapperService() - Method in class org.elasticsearch.percolator.PercolateContext
 
mapperService() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
mapperService() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
mapperService() - Method in class org.elasticsearch.search.internal.SearchContext
 
mapperService() - Method in class org.elasticsearch.search.lookup.DocLookup
 
MapperService.SmartNameFieldMappers - Class in org.elasticsearch.index.mapper
 
MapperService.SmartNameObjectMapper - Class in org.elasticsearch.index.mapper
 
MapperServiceModule - Class in org.elasticsearch.index.mapper
 
MapperServiceModule() - Constructor for class org.elasticsearch.index.mapper.MapperServiceModule
 
mapping(String, String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
Adds mapping that will be added when the index gets created.
mapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
Adds mapping that will be added when the index gets created.
mapping(String, Map) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
Adds mapping that will be added when the index gets created.
mapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
mapping(String, String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
Adds mapping that will be added when the index gets created.
mapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
Adds mapping that will be added when the index gets created.
mapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
Adds mapping that will be added when the index gets created.
mapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
mapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
mapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
MappingCharFilterFactory - Class in org.elasticsearch.index.analysis
 
MappingCharFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.MappingCharFilterFactory
 
mappingForName(String, String) - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
MappingMetaData - Class in org.elasticsearch.cluster.metadata
Mapping configuration for a type.
MappingMetaData(DocumentMapper) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
 
MappingMetaData(CompressedString) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
 
MappingMetaData(Map<String, Object>) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
 
MappingMetaData(String, Map<String, Object>) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
 
MappingMetaData(String, CompressedString, MappingMetaData.Id, MappingMetaData.Routing, MappingMetaData.Timestamp, boolean) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
 
MappingMetaData.Id - Class in org.elasticsearch.cluster.metadata
 
MappingMetaData.ParseContext - Class in org.elasticsearch.cluster.metadata
 
MappingMetaData.Routing - Class in org.elasticsearch.cluster.metadata
 
MappingMetaData.Timestamp - Class in org.elasticsearch.cluster.metadata
 
mappingOrDefault(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
Sometimes, the default mapping exists and an actual mapping is not created yet (introduced), in this case, we want to return the default mapping in case it has some default mapping definitions.
mappings(Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
 
mappings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
 
mappings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
 
mappings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
 
mappings() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
returns the retrieved field mapping.
mappings() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
 
mappings() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
 
mappings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
mappings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
mappings(Map<String, String>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
 
mappingsAreEqual(SortedMap<String, ? extends ContextMapping>, SortedMap<String, ? extends ContextMapping>) - Static method in class org.elasticsearch.search.suggest.context.ContextMapping
Test equality of two mapping
mappingsModified() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
mappingsModified() - Method in class org.elasticsearch.index.mapper.ParseContext
 
mappingsModified() - Method in class org.elasticsearch.index.mapper.ParsedDocument
Has the parsed document caused mappings to be modified?
mappingSource() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
mappingSource() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
mappingType(String) - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
MappingUpdatedAction - Class in org.elasticsearch.cluster.action.index
Called by shards in the cluster when their mapping was dynamically updated and it needs to be updated in the cluster state meta data (and broadcast to all members).
MappingUpdatedAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataMappingService, NodeSettingsService, ActionFilters) - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
MappingUpdatedAction.MappingUpdatedRequest - Class in org.elasticsearch.cluster.action.index
 
MappingUpdatedAction.MappingUpdatedResponse - Class in org.elasticsearch.cluster.action.index
 
MappingUpdatedAction.MappingUpdateListener - Interface in org.elasticsearch.cluster.action.index
A listener to be notified when the mappings were updated
MappingUpdatedRequest(String, String, String, CompressedString, long, String) - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
MappingUpdatedResponse() - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedResponse
 
mapScript(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the map script.
mapScriptFile(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the map script file.
mapScriptId(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the indexed map script id.
mark(int) - Method in class org.elasticsearch.common.io.FastCharArrayReader
Marks the present position in the stream.
mark(int) - Method in class org.elasticsearch.common.io.FastStringReader
Marks the present position in the stream.
mark(int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
mark(int) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
 
mark(int) - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
 
mark() - Method in class org.elasticsearch.common.metrics.MeterMetric
Mark the occurrence of an event.
mark(long) - Method in class org.elasticsearch.common.metrics.MeterMetric
Mark the occurrence of a given number of events.
mark(int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
markAsDone() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
mark the current recovery as done
markAsInactive() - Method in class org.elasticsearch.index.shard.IndexShard
 
markAsRelocated() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
 
markAsRequired() - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
markedPos - Variable in class org.elasticsearch.common.io.FastCharArrayReader
The position of mark in buffer.
markRecoveryAsDone(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
mark the recovery with the given id as done (if found)
markStoreCorrupted(CorruptIndexException) - Method in class org.elasticsearch.index.store.Store
Marks this store as corrupted.
markSupported() - Method in class org.elasticsearch.common.io.FastCharArrayReader
Tells whether this stream supports the mark() operation, which it does.
markSupported() - Method in class org.elasticsearch.common.io.FastStringReader
Tells whether this stream supports the mark() operation, which it does.
markSupported() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
markSupported() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
 
markSupported() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
 
markSupported() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
master() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
the current master of the node
MASTER_PING_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
masterAndDataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Get a Map of the discovered master and data nodes arranged by their ids
MasterFaultDetection - Class in org.elasticsearch.discovery.zen.fd
A fault detection that pings the master periodically to see if its alive.
MasterFaultDetection(Settings, ThreadPool, TransportService, ClusterName, ClusterService) - Constructor for class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
MasterFaultDetection.Listener - Interface in org.elasticsearch.discovery.zen.fd
 
masterNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
 
masterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
Can this node become master or not.
masterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Get the master node
masterNode() - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
masterNode() - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.PingRequest
 
masterNodeChanged() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
masterNodeId(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
masterNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Get the id of the master node
MasterNodeOperationRequest<T extends MasterNodeOperationRequest> - Class in org.elasticsearch.action.support.master
A based request for master based operation.
MasterNodeOperationRequest() - Constructor for class org.elasticsearch.action.support.master.MasterNodeOperationRequest
 
MasterNodeOperationRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.master.MasterNodeOperationRequest
 
MasterNodeOperationRequestBuilder<Request extends MasterNodeOperationRequest<Request>,Response extends ActionResponse,RequestBuilder extends MasterNodeOperationRequestBuilder<Request,Response,RequestBuilder,Client>,Client extends ElasticsearchClient> - Class in org.elasticsearch.action.support.master
Base request builder for master node operations
MasterNodeOperationRequestBuilder(Client, Request) - Constructor for class org.elasticsearch.action.support.master.MasterNodeOperationRequestBuilder
 
MasterNodeReadOperationRequest<T extends MasterNodeReadOperationRequest> - Class in org.elasticsearch.action.support.master
Base request for master based read operations that allows to read the cluster state from the local node if needed
MasterNodeReadOperationRequest() - Constructor for class org.elasticsearch.action.support.master.MasterNodeReadOperationRequest
 
MasterNodeReadOperationRequestBuilder<Request extends MasterNodeReadOperationRequest<Request>,Response extends ActionResponse,RequestBuilder extends MasterNodeReadOperationRequestBuilder<Request,Response,RequestBuilder,Client>,Client extends ElasticsearchClient> - Class in org.elasticsearch.action.support.master
Base request builder for master node read operations that can be executed on the local node as well
MasterNodeReadOperationRequestBuilder(Client, Request) - Constructor for class org.elasticsearch.action.support.master.MasterNodeReadOperationRequestBuilder
 
masterNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Get a Map of the discovered master nodes arranged by their ids
masterNodeTimeout - Variable in class org.elasticsearch.action.support.master.MasterNodeOperationRequest
 
masterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequest
A timeout value in case the master has not been discovered yet or disconnected.
masterNodeTimeout(String) - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequest
A timeout value in case the master has not been discovered yet or disconnected.
masterNodeTimeout() - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequest
 
masterNodeTimeout() - Method in interface org.elasticsearch.cluster.ack.AckedRequest
Returns the timeout for the request to be completed on the master node
masterNodeTimeout() - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
Returns the maximum time interval to wait for the request to be completed on the master node
masterNodeTimeout(TimeValue) - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
Sets the master node timeout
masterNodeTimeout() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
Return master node timeout
masterNodeTimeout(TimeValue) - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
Sets master node timeout
masterNodeTimeout() - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
Returns master node timeout
MasterNotDiscoveredException - Exception in org.elasticsearch.discovery
 
MasterNotDiscoveredException() - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
 
MasterNotDiscoveredException(String) - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
 
masterOperation(ClusterHealthRequest, ClusterState, ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
masterOperation(NodesShutdownRequest, ClusterState, ActionListener<NodesShutdownResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
masterOperation(DeleteRepositoryRequest, ClusterState, ActionListener<DeleteRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
 
masterOperation(GetRepositoriesRequest, ClusterState, ActionListener<GetRepositoriesResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
 
masterOperation(PutRepositoryRequest, ClusterState, ActionListener<PutRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
 
masterOperation(VerifyRepositoryRequest, ClusterState, ActionListener<VerifyRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
 
masterOperation(ClusterRerouteRequest, ClusterState, ActionListener<ClusterRerouteResponse>) - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
 
masterOperation(ClusterUpdateSettingsRequest, ClusterState, ActionListener<ClusterUpdateSettingsResponse>) - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
masterOperation(ClusterSearchShardsRequest, ClusterState, ActionListener<ClusterSearchShardsResponse>) - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
 
masterOperation(CreateSnapshotRequest, ClusterState, ActionListener<CreateSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
 
masterOperation(DeleteSnapshotRequest, ClusterState, ActionListener<DeleteSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
 
masterOperation(GetSnapshotsRequest, ClusterState, ActionListener<GetSnapshotsResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
 
masterOperation(RestoreSnapshotRequest, ClusterState, ActionListener<RestoreSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
 
masterOperation(SnapshotsStatusRequest, ClusterState, ActionListener<SnapshotsStatusResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
 
masterOperation(ClusterStateRequest, ClusterState, ActionListener<ClusterStateResponse>) - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
masterOperation(PendingClusterTasksRequest, ClusterState, ActionListener<PendingClusterTasksResponse>) - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
 
masterOperation(GetAliasesRequest, ClusterState, ActionListener<AliasesExistResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
 
masterOperation(GetAliasesRequest, ClusterState, ActionListener<GetAliasesResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
 
masterOperation(IndicesAliasesRequest, ClusterState, ActionListener<IndicesAliasesResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
masterOperation(CloseIndexRequest, ClusterState, ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
 
masterOperation(CreateIndexRequest, ClusterState, ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
masterOperation(DeleteIndexRequest, ClusterState, ActionListener<DeleteIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
masterOperation(IndicesExistsRequest, ClusterState, ActionListener<IndicesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
 
masterOperation(TypesExistsRequest, ClusterState, ActionListener<TypesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
 
masterOperation(DeleteMappingRequest, ClusterState, ActionListener<DeleteMappingResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
masterOperation(PutMappingRequest, ClusterState, ActionListener<PutMappingResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
masterOperation(OpenIndexRequest, ClusterState, ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
 
masterOperation(GetSettingsRequest, ClusterState, ActionListener<GetSettingsResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
 
masterOperation(UpdateSettingsRequest, ClusterState, ActionListener<UpdateSettingsResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
 
masterOperation(DeleteIndexTemplateRequest, ClusterState, ActionListener<DeleteIndexTemplateResponse>) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
masterOperation(GetIndexTemplatesRequest, ClusterState, ActionListener<GetIndexTemplatesResponse>) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
 
masterOperation(PutIndexTemplateRequest, ClusterState, ActionListener<PutIndexTemplateResponse>) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
 
masterOperation(DeleteWarmerRequest, ClusterState, ActionListener<DeleteWarmerResponse>) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
 
masterOperation(PutWarmerRequest, ClusterState, ActionListener<PutWarmerResponse>) - Method in class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
 
masterOperation(Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
 
masterOperation(Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
masterOperation(MappingUpdatedAction.MappingUpdatedRequest, ClusterState, ActionListener<MappingUpdatedAction.MappingUpdatedResponse>) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
masterTimeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Request
 
masterTimeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
 
masterTimeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveRequest
 
Match(Text, Text, float, Map<String, HighlightField>) - Constructor for class org.elasticsearch.action.percolate.PercolateResponse.Match
Constructor only for internal usage.
Match(Text, Text, float) - Constructor for class org.elasticsearch.action.percolate.PercolateResponse.Match
Constructor only for internal usage.
match(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
 
match(int) - Method in class org.elasticsearch.common.lucene.docset.BitsDocIdSetIterator.FilteredIterator
 
match(String) - Method in class org.elasticsearch.common.ParseField
 
match(String, EnumSet<ParseField.Flag>) - Method in class org.elasticsearch.common.ParseField
 
match(ContentPath, String, String) - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
match(String) - Method in enum org.elasticsearch.index.store.IndexStoreModule.Type
Returns true iff this settings matches the type.
MATCH_ALL_CHANGES_PREDICATE - Variable in class org.elasticsearch.cluster.ClusterStateObserver
 
MATCH_ALL_FILTER - Static variable in class org.elasticsearch.common.lucene.search.Queries
A match all docs filter.
MATCH_ANY - Static variable in class org.elasticsearch.common.lucene.uid.Versions
 
MATCH_ANY_PRE_1_2_0 - Static variable in class org.elasticsearch.common.lucene.uid.Versions
 
MATCH_NAME - Static variable in class org.elasticsearch.index.query.SpanMultiTermQueryParser
 
MATCH_NO_FILTER - Static variable in class org.elasticsearch.common.lucene.search.Queries
 
MatchAllDocsFilter - Class in org.elasticsearch.common.lucene.search
A filter that matches on all docs.
MatchAllDocsFilter() - Constructor for class org.elasticsearch.common.lucene.search.MatchAllDocsFilter
 
matchAllFilter() - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter that matches all documents.
MatchAllFilterBuilder - Class in org.elasticsearch.index.query
A filter that simply wraps a query.
MatchAllFilterBuilder() - Constructor for class org.elasticsearch.index.query.MatchAllFilterBuilder
A filter that simply matches all docs.
MatchAllFilterParser - Class in org.elasticsearch.index.query
 
MatchAllFilterParser() - Constructor for class org.elasticsearch.index.query.MatchAllFilterParser
 
matchAllQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that match on all documents.
MatchAllQueryBuilder - Class in org.elasticsearch.index.query
A query that matches on all documents.
MatchAllQueryBuilder() - Constructor for class org.elasticsearch.index.query.MatchAllQueryBuilder
 
MatchAllQueryParser - Class in org.elasticsearch.index.query
 
MatchAllQueryParser() - Constructor for class org.elasticsearch.index.query.MatchAllQueryParser
 
matchDoc(int) - Method in class org.elasticsearch.common.lucene.docset.BitsDocIdSetIterator
 
matchDoc(int) - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSet
Does this document match?
matchDoc(int) - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSetIterator
 
matchDoc(int) - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.BitsBasedIterator
 
matchDoc(int) - Method in class org.elasticsearch.common.lucene.search.LimitFilter.LimitDocIdSet
 
matchDoc(int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter.GeoDistanceDocSet
 
matchDoc(int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter.GeoDistanceRangeDocSet
 
matchDoc(int) - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter.GeoPolygonDocIdSet
 
matchDoc(int) - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.GeoBoundingBoxDocSet
 
matchDoc(int) - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.Meridian180GeoBoundingBoxDocSet
 
MatchDocIdSet - Class in org.elasticsearch.common.lucene.docset
A DocIdSet that works on a "doc" level by checking if it matches or not.
MatchDocIdSet(int, Bits) - Constructor for class org.elasticsearch.common.lucene.docset.MatchDocIdSet
 
MatchDocIdSetIterator - Class in org.elasticsearch.common.lucene.docset
 
MatchDocIdSetIterator(int) - Constructor for class org.elasticsearch.common.lucene.docset.MatchDocIdSetIterator
 
matchedFields(String...) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
Set the matched fields to highlight against this field data.
matchedFields() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
matchedQueries(String[]) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
matchedQueries() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
matchedQueries() - Method in interface org.elasticsearch.search.SearchHit
The set of query and filter names the query matched with.
MatchedQueriesFetchSubPhase - Class in org.elasticsearch.search.fetch.matchedqueries
 
MatchedQueriesFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.matchedqueries.MatchedQueriesFetchSubPhase
 
Matcher<T> - Interface in org.elasticsearch.common.inject.matcher
Returns true or false for a given input.
MatcherAndConverter - Class in org.elasticsearch.common.inject.internal
 
MatcherAndConverter(Matcher<? super TypeLiteral<?>>, TypeConverter, Object) - Constructor for class org.elasticsearch.common.inject.internal.MatcherAndConverter
 
Matchers - Class in org.elasticsearch.common.inject.matcher
Matcher implementations.
matches() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
 
matches(T) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
Returns true if this matches t, false otherwise.
matches() - Method in class org.elasticsearch.percolator.PercolatorService.ReduceResult
 
matchesIndices(String, String...) - Method in class org.elasticsearch.index.query.IndicesFilterParser
 
matchesIndices(String, String...) - Method in class org.elasticsearch.index.query.IndicesQueryParser
 
MatchNoDocsFilter - Class in org.elasticsearch.common.lucene.search
A filter that matches no docs.
MatchNoDocsFilter() - Constructor for class org.elasticsearch.common.lucene.search.MatchNoDocsFilter
 
MatchNoDocsQuery - Class in org.elasticsearch.common.lucene.search
Query that matches no documents.
MatchNoDocsQuery() - Constructor for class org.elasticsearch.common.lucene.search.MatchNoDocsQuery
 
matchPhrasePrefixQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Creates a match query with type "PHRASE_PREFIX" for the provided field name and text.
matchPhraseQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Creates a text query with type "PHRASE" for the provided field name and text.
matchQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Creates a match query with type "BOOLEAN" for the provided field name and text.
MatchQuery - Class in org.elasticsearch.index.search
 
MatchQuery(QueryParseContext) - Constructor for class org.elasticsearch.index.search.MatchQuery
 
MatchQuery.Type - Enum in org.elasticsearch.index.search
 
MatchQuery.ZeroTermsQuery - Enum in org.elasticsearch.index.search
 
MatchQueryBuilder - Class in org.elasticsearch.index.query
Match query is a query that analyzes the text and constructs a query as the result of the analysis.
MatchQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.MatchQueryBuilder
Constructs a new text query.
MatchQueryBuilder.Operator - Enum in org.elasticsearch.index.query
 
MatchQueryBuilder.Type - Enum in org.elasticsearch.index.query
 
MatchQueryBuilder.ZeroTermsQuery - Enum in org.elasticsearch.index.query
 
MatchQueryParser - Class in org.elasticsearch.index.query
 
MatchQueryParser() - Constructor for class org.elasticsearch.index.query.MatchQueryParser
 
matchQueryType() - Method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
 
MathUtils - Enum in org.elasticsearch.common.math
 
max() - Method in class jsr166e.DoubleMaxUpdater
Returns the current maximum.
max() - Method in class jsr166e.LongMaxUpdater
Returns the current maximum.
max(Integer, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
max(Long, Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
max(Float, Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
max(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
max() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
max() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
max(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new Max aggregation with the given name.
Max - Interface in org.elasticsearch.search.aggregations.metrics.max
An aggregation that computes the maximum of the values in the current bucket.
max - Variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
max() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor.StatsProc
 
MAX_BYTES_VLONG - Static variable in enum org.elasticsearch.common.util.ByteUtils
 
MAX_COORDINATE - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
 
MAX_DOC_FREQ - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
MAX_EDITS - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
 
MAX_INDEX_NAME_BYTES - Static variable in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
 
MAX_INPUT_LENGTH - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
 
MAX_INSPECTIONS - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
 
MAX_IP - Static variable in class org.elasticsearch.search.aggregations.bucket.range.ipv4.InternalIPv4Range
 
MAX_MERGE_COUNT - Static variable in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
MAX_MERGE_DOCS_KEY - Static variable in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
MAX_NUM_SEGMENTS - Static variable in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
MAX_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
MAX_QUERY_TERMS - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
MAX_TERM - Static variable in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
UTF-8 term containing a single code point: Character.MAX_CODE_POINT which will compare greater than all other index terms since Character.MAX_CODE_POINT is a noncharacter and thus shouldn't appear in an index term.
MAX_TERM_FREQ - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
 
MAX_THREAD_COUNT - Static variable in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
MAX_WORD_LENGTH - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
MaxAggregator - Class in org.elasticsearch.search.aggregations.metrics.max
 
MaxAggregator(String, long, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
 
MaxAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.max
 
maxAtomicUniqueValuesCount(long) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData.Builder
 
maxAtomicUniqueValuesCount() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData
 
maxBlockSize() - Method in class org.elasticsearch.index.codec.postingsformat.DefaultPostingsFormatProvider
 
maxBoost(float) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
Tha maximum boost that will be applied by function score.
maxBucket() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
maxBucketOrd() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
Return an upper bound of the maximum bucket ordinal seen so far.
MaxBuilder - Class in org.elasticsearch.search.aggregations.metrics.max
Builder for the Max aggregation.
MaxBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.max.MaxBuilder
Sole constructor.
maxChildren(int) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
Defines the maximum number of children that are required to match for the parent to be considered a match.
maxChildren(int) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
Defines the maximum number of children that are required to match for the parent to be considered a match.
maxChildren - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
maxChildren - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
maxChunkSize - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
maxCompositeBufferComponents - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
maxCompositeBufferComponents - Variable in class org.elasticsearch.transport.netty.NettyTransport
 
maxContentLength() - Method in class org.elasticsearch.http.HttpInfo
 
maxContentLength - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
maxCumulationBufferCapacity - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
maxCumulationBufferCapacity - Variable in class org.elasticsearch.transport.netty.NettyTransport
 
maxDeterminizedStates() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
maxDeterminizedStates(int) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
maxDeterminizedStates(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Protects against too-difficult regular expression queries.
maxDeterminizedStates(int) - Method in class org.elasticsearch.index.query.RegexpFilterBuilder
Sets the regexp maxDeterminizedStates.
maxDeterminizedStates(int) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
Sets the regexp maxDeterminizedStates.
maxDoc() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
Returns the maximum document ID this builder can associate with an ordinal
maxDoc() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
 
maxDoc() - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
maxDoc(int) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
maxDoc() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
maxDoc() - Method in class org.elasticsearch.search.lookup.IndexLookup
 
maxDocFreq(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The maximum frequency in which words may still appear.
maxDocFreq() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The maximum frequency in which words may still appear.
maxDocFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Set the maximum frequency in which words may still appear.
maxDocFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Set the maximum frequency in which words may still appear.
maxEdits() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
maxEdits(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
maxEdits(Integer) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
Sets the maximum edit distance candidate suggestions can have in order to be considered as a suggestion.
maxEdits(Integer) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
Sets the maximum edit distance candidate suggestions can have in order to be considered as a suggestion.
maxErrors(Float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
Sets the maximum percentage of the terms that at most considered to be misspellings in order to form a correction.
maxExpansions(int) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
 
maxExpansions(int) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
When using fuzzy or prefix type query, the number of term expansions to use.
maxExpansions(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
When using fuzzy or prefix type query, the number of term expansions to use.
maxExpansions - Variable in class org.elasticsearch.index.search.MatchQuery
 
maxFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessInfo
 
maxHeaderSize - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
maxInitialLineLength - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
maxInputLength(int) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Builder
 
maxInspections() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
maxInspections(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
maxInspections(Integer) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
A factor that is used to multiply with the size in order to inspect more candidate suggestions.
maxInspections(Integer) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
A factor that is used to multiply with the size in order to inspect more candidate suggestions.
maxNumSegments() - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Will optimize the index down to <= maxNumSegments.
maxNumSegments(int) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Will optimize the index down to <= maxNumSegments.
MaxParser - Class in org.elasticsearch.search.aggregations.metrics.max
 
MaxParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.max.MaxParser
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
maxQueryTerms(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The maximum number of query terms that will be included in any generated query.
maxQueryTerms() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The maximum number of query terms that will be included in any generated query.
maxQueryTerms(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The maximum number of query terms that will be included in any generated query.
maxQueryTerms(int) - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
 
maxQueryTerms(int) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
 
maxQueryTerms(int) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Sets the maximum number of query terms that will be included in any generated query.
maxQueryTerms(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the maximum number of query terms that will be included in any generated query.
maxScore() - Method in class org.elasticsearch.search.internal.InternalSearchHits
 
maxScore() - Method in interface org.elasticsearch.search.SearchHits
The maximum score of this query.
maxSubwordSize - Variable in class org.elasticsearch.index.analysis.compound.AbstractCompoundWordTokenFilterFactory
 
maxSurfaceFormsPerAnalyzedForm() - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
 
maxTermFreq() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
Sets a maximum threshold in number of documents a suggest text token can exist in order to be corrected.
maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
Sets a maximum threshold in number of documents a suggest text token can exist in order to be corrected.
maxThenReset() - Method in class jsr166e.DoubleMaxUpdater
Equivalent in effect to DoubleMaxUpdater.max() followed by DoubleMaxUpdater.reset().
maxThenReset() - Method in class jsr166e.LongMaxUpdater
Equivalent in effect to LongMaxUpdater.max() followed by LongMaxUpdater.reset().
maxValue() - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
 
maxWordLen(int) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Sets the maximum word length above which words will be ignored.
maxWordLength(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The maximum word length above which words will be ignored.
maxWordLength() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The maximum word length above which words will be ignored.
maxWordLength(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the maximum word length above which words will be ignored.
maybeFailEngine(String, Throwable) - Method in class org.elasticsearch.index.engine.Engine
Check whether the engine should be failed
maybeFailEngine(String, Throwable) - Method in class org.elasticsearch.index.engine.InternalEngine
 
maybeMerge() - Method in class org.elasticsearch.index.engine.Engine
 
maybeMerge() - Method in class org.elasticsearch.index.engine.InternalEngine
 
maybeMerge() - Method in class org.elasticsearch.index.engine.ShadowEngine
 
maybeSlowRandomAccessOrds(SortedSetDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
If dv is an instance of RandomAccessOrds, then return it, otherwise wrap it into a slow wrapper that implements random access.
maybeThrowRuntimeAndSuppress(List<T>) - Static method in class org.elasticsearch.ExceptionsHelper
Throws a runtime exception with all given exceptions added as suppressed.
mb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
mbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
MCL_CURRENT - Static variable in class org.elasticsearch.common.jna.CLibrary
 
MCL_FUTURE - Static variable in class org.elasticsearch.common.jna.CLibrary
 
mean() - Method in class org.elasticsearch.common.metrics.MeanMetric
 
MeanMetric - Class in org.elasticsearch.common.metrics
 
MeanMetric() - Constructor for class org.elasticsearch.common.metrics.MeanMetric
 
meanRate() - Method in class org.elasticsearch.common.metrics.MeterMetric
 
mega() - Method in class org.elasticsearch.common.unit.SizeValue
 
megaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
 
mem() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
mem() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
mem() - Method in class org.elasticsearch.monitor.os.OsInfo
 
mem() - Method in class org.elasticsearch.monitor.os.OsStats
 
Mem() - Constructor for class org.elasticsearch.monitor.os.OsStats.Mem
 
mem() - Method in class org.elasticsearch.monitor.process.ProcessStats
 
memberKey(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
 
members() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
MembershipAction - Class in org.elasticsearch.discovery.zen.membership
 
MembershipAction(Settings, ClusterService, TransportService, DiscoveryNodesProvider, MembershipAction.MembershipListener) - Constructor for class org.elasticsearch.discovery.zen.membership.MembershipAction
 
MembershipAction.JoinCallback - Interface in org.elasticsearch.discovery.zen.membership
 
MembershipAction.MembershipListener - Interface in org.elasticsearch.discovery.zen.membership
 
MembersInjector<T> - Interface in org.elasticsearch.common.inject
Injects dependencies into the fields and methods on instances of type T.
MembersInjectorLookup<T> - Class in org.elasticsearch.common.inject.spi
A lookup of the members injector for a type.
MembersInjectorLookup(Object, TypeLiteral<T>) - Constructor for class org.elasticsearch.common.inject.spi.MembersInjectorLookup
 
memberType(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
Returns Field.class, Method.class or Constructor.class.
MEMORY_MANAGER_TYPE - Static variable in class org.elasticsearch.monitor.MonitorModule.MonitorSettings
 
MEMORY_SIZE - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
MemoryCircuitBreaker - Class in org.elasticsearch.common.breaker
MemoryCircuitBreaker is a circuit breaker that breaks once a configurable memory limit has been reached.
MemoryCircuitBreaker(ByteSizeValue, double, ESLogger) - Constructor for class org.elasticsearch.common.breaker.MemoryCircuitBreaker
Create a circuit breaker that will break if the number of estimated bytes grows above the limit.
MemoryCircuitBreaker(ByteSizeValue, double, MemoryCircuitBreaker, ESLogger) - Constructor for class org.elasticsearch.common.breaker.MemoryCircuitBreaker
Create a circuit breaker that will break if the number of estimated bytes grows above the limit.
memoryInBytes - Variable in class org.elasticsearch.index.engine.Segment
 
MemoryPool(String, long, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
MemorySizeValue - Enum in org.elasticsearch.common.unit
Utility methods to get memory sizes.
memoryUsage(int) - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
Return the expected per-bucket memory usage for the given precision.
merge - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
merge(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
merge() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
merge(T, T) - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom.Factory
Merges from first to second, with first being more important, i.e., if something exists in first and second, first will prevail.
merge(Collection<Message>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
merge(Errors) - Method in class org.elasticsearch.common.inject.internal.Errors
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper
 
merge(DocumentMapper, DocumentMapper.MergeFlags) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
merge(Mapper, MergeContext) - Method in interface org.elasticsearch.index.mapper.Mapper
 
merge(String, CompressedString, boolean) - Method in class org.elasticsearch.index.mapper.MapperService
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
merge(IndexWriter, MergeTrigger, boolean) - Method in class org.elasticsearch.index.merge.EnableMergeScheduler
 
merge(long, HyperLogLogPlusPlus, long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
merge(InternalCardinality) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
 
merge(ScoreDoc[], AtomicArray<? extends QuerySearchResultProvider>, AtomicArray<? extends FetchSearchResultProvider>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
merge(Suggest.Suggestion.Entry<Suggest.Suggestion.Entry.Option>) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
 
merge(Suggest.Suggestion.Entry<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
Merge any extra fields for this subtype.
merge(IndexWarmersMetaData, IndexWarmersMetaData) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
MERGE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
MERGE_FACTORY_KEY - Static variable in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
MERGE_POLICY_TYPE_KEY - Static variable in class org.elasticsearch.index.merge.policy.MergePolicyModule
 
MERGE_SCHEDULER_TYPE_KEY - Static variable in class org.elasticsearch.index.merge.scheduler.MergeSchedulerModule
 
MergeContext - Class in org.elasticsearch.index.mapper
 
MergeContext(DocumentMapper, DocumentMapper.MergeFlags) - Constructor for class org.elasticsearch.index.mapper.MergeContext
 
mergeDefaults(Map<String, Object>, Map<String, Object>) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
Merges the defaults provided as the second parameter into the content of the first.
MergeFlags() - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.MergeFlags
 
mergeFlags() - Static method in class org.elasticsearch.index.mapper.DocumentMapper.MergeFlags
 
mergeFlags() - Method in class org.elasticsearch.index.mapper.MergeContext
 
mergeId - Variable in class org.elasticsearch.index.engine.Segment
 
mergeInto(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
 
mergeInto(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
 
MergeMappingException - Exception in org.elasticsearch.index.mapper
 
MergeMappingException(String[]) - Constructor for exception org.elasticsearch.index.mapper.MergeMappingException
 
MergePolicyModule - Class in org.elasticsearch.index.merge.policy
 
MergePolicyModule(Settings) - Constructor for class org.elasticsearch.index.merge.policy.MergePolicyModule
 
MergePolicyProvider<T extends org.apache.lucene.index.MergePolicy> - Interface in org.elasticsearch.index.merge.policy
 
MergeResult(String[]) - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.MergeResult
 
mergeScheduler() - Method in class org.elasticsearch.index.shard.IndexShard
 
MergeSchedulerModule - Class in org.elasticsearch.index.merge.scheduler
 
MergeSchedulerModule(Settings) - Constructor for class org.elasticsearch.index.merge.scheduler.MergeSchedulerModule
 
MergeSchedulerProvider - Class in org.elasticsearch.index.merge.scheduler
 
MergeSchedulerProvider(ShardId, Settings, ThreadPool) - Constructor for class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
MergeSchedulerProvider.FailureListener - Interface in org.elasticsearch.index.merge.scheduler
 
MergeSchedulerProvider.Listener - Interface in org.elasticsearch.index.merge.scheduler
Listener for events before/after single merges.
mergeSorted(Iterable<Iterator<? extends T>>, Comparator<? super T>, boolean) - Static method in enum org.elasticsearch.common.collect.Iterators2
Return a merged view over several iterators, optionally deduplicating equivalent entries.
MergeStats - Class in org.elasticsearch.index.merge
 
MergeStats() - Constructor for class org.elasticsearch.index.merge.MergeStats
 
mergeStats() - Method in class org.elasticsearch.index.shard.IndexShard
 
Meridian180DistanceBoundingCheck(GeoPoint, GeoPoint) - Constructor for class org.elasticsearch.common.geo.GeoDistance.Meridian180DistanceBoundingCheck
 
Meridian180GeoBoundingBoxDocSet(int, Bits, MultiGeoPointValues, GeoPoint, GeoPoint) - Constructor for class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.Meridian180GeoBoundingBoxDocSet
 
Message - Class in org.elasticsearch.common.inject.spi
An error message and the context in which it occured.
Message(List<Object>, String, Throwable) - Constructor for class org.elasticsearch.common.inject.spi.Message
 
Message(Object, String) - Constructor for class org.elasticsearch.common.inject.spi.Message
 
Message(String) - Constructor for class org.elasticsearch.common.inject.spi.Message
 
message(String, String) - Method in class org.elasticsearch.common.lucene.LoggerInfoStream
 
MessageChannelHandler - Class in org.elasticsearch.transport.netty
A handler (must be the last one!) that does size based frame decoding and forwards the actual message to the relevant action.
MessageChannelHandler(NettyTransport, ESLogger, String) - Constructor for class org.elasticsearch.transport.netty.MessageChannelHandler
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.elasticsearch.http.netty.HttpRequestHandler
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.elasticsearch.http.netty.pipelining.HttpPipeliningHandler
 
messageReceived(byte[], String, LocalTransport, Version, Long) - Method in class org.elasticsearch.transport.local.LocalTransport
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.elasticsearch.transport.netty.MessageChannelHandler
 
messageReceived(T, TransportChannel) - Method in interface org.elasticsearch.transport.TransportRequestHandler
 
meta(ImmutableMap<String, Object>) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
meta() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
metaData() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
metaData(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
metaData(MetaData.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
metaData(MetaData) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
metaData() - Method in class org.elasticsearch.cluster.ClusterState
 
MetaData - Class in org.elasticsearch.cluster.metadata
 
metaData() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
Get metadata of routing nodes
metaData() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
metaData() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState
 
metadata() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
Returns the StoreFileMetaData for this file info.
metadata() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
metaData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
 
metaData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
 
metaData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
 
metaData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
 
metaData() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.WithScript
 
MetaData.Builder - Class in org.elasticsearch.cluster.metadata
 
MetaData.Custom - Interface in org.elasticsearch.cluster.metadata
 
MetaData.Custom.Factory<T extends MetaData.Custom> - Class in org.elasticsearch.cluster.metadata
 
MetaData.XContentContext - Enum in org.elasticsearch.cluster.metadata
 
metaDataChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
MetaDataCreateIndexService - Class in org.elasticsearch.cluster.metadata
Service responsible for submitting create index requests
MetaDataCreateIndexService(Settings, Environment, ThreadPool, ClusterService, IndicesService, AllocationService, MetaDataService, Version, String, AliasValidator, Set<IndexTemplateFilter>, NodeEnvironment) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
 
MetaDataDeleteIndexService - Class in org.elasticsearch.cluster.metadata
 
MetaDataDeleteIndexService(Settings, ThreadPool, ClusterService, AllocationService, NodeIndexDeletedAction, MetaDataService) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService
 
MetaDataDeleteIndexService.Listener - Interface in org.elasticsearch.cluster.metadata
 
MetaDataDeleteIndexService.Request - Class in org.elasticsearch.cluster.metadata
 
MetaDataDeleteIndexService.Response - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexAliasesService - Class in org.elasticsearch.cluster.metadata
Service responsible for submitting add and remove aliases requests
MetaDataIndexAliasesService(Settings, ClusterService, IndicesService, AliasValidator) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService
 
MetaDataIndexStateService - Class in org.elasticsearch.cluster.metadata
Service responsible for submitting open/close index requests
MetaDataIndexStateService(Settings, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexStateService
 
MetaDataIndexTemplateService - Class in org.elasticsearch.cluster.metadata
Service responsible for submitting index templates updates
MetaDataIndexTemplateService(Settings, ClusterService, AliasValidator) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService
 
MetaDataIndexTemplateService.PutListener - Interface in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.PutRequest - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.PutResponse - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.RemoveListener - Interface in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.RemoveRequest - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.RemoveResponse - Class in org.elasticsearch.cluster.metadata
 
MetaDataMappingService - Class in org.elasticsearch.cluster.metadata
Service responsible for submitting mapping changes
MetaDataMappingService(Settings, ThreadPool, ClusterService, IndicesService) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataMappingService
 
MetaDataService - Class in org.elasticsearch.cluster.metadata
 
MetaDataService(Settings) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataService
 
MetadataSnapshot(Map<String, StoreFileMetaData>) - Constructor for class org.elasticsearch.index.store.Store.MetadataSnapshot
 
MetaDataStateFormat<T> - Class in org.elasticsearch.gateway.local.state.meta
MetaDataStateFormat is a base class to write checksummed XContent based files to one or more directories in a standardized directory structure.
MetaDataStateFormat(XContentType, String) - Constructor for class org.elasticsearch.gateway.local.state.meta.MetaDataStateFormat
Creates a new MetaDataStateFormat instance
MetaDataUpdateSettingsService - Class in org.elasticsearch.cluster.metadata
Service responsible for submitting update index settings requests
MetaDataUpdateSettingsService(Settings, ClusterService, AllocationService, DynamicSettings) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService
 
MeterMetric - Class in org.elasticsearch.common.metrics
A meter metric which measures mean throughput and one-, five-, and fifteen-minute exponentially-weighted moving average throughputs.
MeterMetric(ScheduledExecutorService, TimeUnit) - Constructor for class org.elasticsearch.common.metrics.MeterMetric
 
method() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
method() - Method in class org.elasticsearch.rest.RestRequest
 
Metric - Interface in org.elasticsearch.common.metrics
 
metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
 
metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
 
metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
 
metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
 
metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.SingleValue
 
metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregator
 
metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregator
 
metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
 
metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
 
MetricsAggregationBuilder<B extends MetricsAggregationBuilder<B>> - Class in org.elasticsearch.search.aggregations.metrics
Base builder for metrics aggregations.
MetricsAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.metrics.MetricsAggregationBuilder
 
MetricsAggregator - Class in org.elasticsearch.search.aggregations.metrics
 
MetricsAggregator(String, long, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.MetricsAggregator
 
MetricsAggregator(String, long, Aggregator.BucketAggregationMode, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.MetricsAggregator
 
mhz() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
micros() - Method in class org.elasticsearch.common.unit.TimeValue
 
microsFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
mightContain(BytesRef) - Method in class org.elasticsearch.common.util.BloomFilter
 
millis() - Method in class org.elasticsearch.common.unit.TimeValue
 
millisFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
min(Integer, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
min(Long, Long) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
min(Float, Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
min(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
min(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new Min aggregation with the given name.
Min - Interface in org.elasticsearch.search.aggregations.metrics.min
An aggregation that computes the minimum of the values in the current bucket.
min - Variable in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
min() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor.StatsProc
 
MIN_DOC_COUNT_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractTermsParametersParser
 
MIN_DOC_FREQ - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
MIN_DOC_FREQ - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
 
MIN_MERGE_DOCS_KEY - Static variable in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
MIN_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
MIN_TERM_FREQ - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
MIN_WORD_LENGTH - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
MIN_WORD_LENGTH - Static variable in class org.elasticsearch.search.suggest.SuggestUtils.Fields
 
MinAggregator - Class in org.elasticsearch.search.aggregations.metrics.min
 
MinAggregator(String, long, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
 
MinAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.min
 
minBlockSize() - Method in class org.elasticsearch.index.codec.postingsformat.DefaultPostingsFormatProvider
 
MinBuilder - Class in org.elasticsearch.search.aggregations.metrics.min
Builder for the Min aggregation.
MinBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.min.MinBuilder
Sole constructor.
minChildren(int) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
Defines the minimum number of children that are required to match for the parent to be considered a match.
minChildren(int) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
Defines the minimum number of children that are required to match for the parent to be considered a match.
minChildren - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
minChildren - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Set the minimum document count per bucket.
minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramBuilder
Sets the minimum document count per bucket.
minDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
 
minDocCount(int) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsBuilder
Only return significant terms that belong to at least minDocCount documents.
minDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
Set the minimum document count terms should have in order to appear in the response.
minDocFreq(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The frequency at which words will be ignored which do not occur in at least this many docs.
minDocFreq() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The frequency at which words will be ignored which do not occur in at least this many docs.
minDocFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Sets the frequency at which words will be ignored which do not occur in at least this many docs.
minDocFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the frequency at which words will be ignored which do not occur in at least this many docs.
minDocFreq() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
minDocFreq(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
minDocFreq(float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
Sets a minimal threshold in number of documents a suggested term should appear in.
minDocFreq(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
Sets a minimal threshold in number of documents a suggested term should appear in.
MinimalMap<K,V> - Class in org.elasticsearch.common.util
 
MinimalMap() - Constructor for class org.elasticsearch.common.util.MinimalMap
 
MINIMUM_DISCOVERY_NODE_VERSION - Static variable in class org.elasticsearch.cluster.node.DiscoveryNode
Minimum version of a node to communicate with.
MINIMUM_SHOULD_MATCH - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
minimumCompatibilityVersion() - Method in class org.elasticsearch.Version
Returns the minimum compatible version based on the current version.
minimumMasterNodes(int) - Method in class org.elasticsearch.discovery.zen.elect.ElectMasterService
 
minimumMasterNodes() - Method in class org.elasticsearch.discovery.zen.elect.ElectMasterService
 
minimumMatch(int) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
Sets the minimum number of matches across the provided terms.
minimumNumberShouldMatch(int) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Specifies a minimum number of the optional (should) boolean clauses which must be satisfied.
minimumScore(float) - Method in class org.elasticsearch.percolator.PercolateContext
 
minimumScore() - Method in class org.elasticsearch.percolator.PercolateContext
 
minimumScore(float) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
minimumScore() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
minimumScore(float) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
minimumScore() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
minimumScore(float) - Method in class org.elasticsearch.search.internal.SearchContext
 
minimumScore() - Method in class org.elasticsearch.search.internal.SearchContext
 
minimumScore(float) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
MinimumScoreCollector - Class in org.elasticsearch.common.lucene
 
MinimumScoreCollector(Collector, float) - Constructor for class org.elasticsearch.common.lucene.MinimumScoreCollector
 
minimumShouldMatch() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
minimumShouldMatch(String) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
minimumShouldMatch(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
minimumShouldMatch() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Sets the minimum should match using the special syntax (for example, supporting percentage).
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
 
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
 
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
 
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
 
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
 
minor - Variable in class org.elasticsearch.Version
 
MinParser - Class in org.elasticsearch.search.aggregations.metrics.min
 
MinParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.min.MinParser
 
minQueryLength(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
minScore() - Method in class org.elasticsearch.action.count.CountRequest
The minimum score of the documents to include in the count.
minScore(float) - Method in class org.elasticsearch.action.count.CountRequest
The minimum score of the documents to include in the count.
minScore() - Method in class org.elasticsearch.action.exists.ExistsRequest
The minimum score of the documents to include in the count.
minScore(float) - Method in class org.elasticsearch.action.exists.ExistsRequest
The minimum score of the documents to include in the count.
minScore(float) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Sets the minimum score below which docs will be filtered out.
MinScoreParseElement - Class in org.elasticsearch.search.query
 
MinScoreParseElement() - Constructor for class org.elasticsearch.search.query.MinScoreParseElement
 
minSubwordSize - Variable in class org.elasticsearch.index.analysis.compound.AbstractCompoundWordTokenFilterFactory
 
minTermFreq(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The frequency below which terms will be ignored in the source doc.
minTermFreq() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The frequency below which terms will be ignored in the source doc.
minTermFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
The frequency below which terms will be ignored in the source doc.
minTermFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
The frequency below which terms will be ignored in the source doc.
MINUTE - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
minutes() - Method in class org.elasticsearch.common.unit.TimeValue
 
minutes(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
minutesFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
minValue() - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
 
minWordLength(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The minimum word length below which words will be ignored.
minWordLength() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The minimum word length below which words will be ignored.
minWordLength(int) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Sets the minimum word length below which words will be ignored.
minWordLength(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the minimum word length below which words will be ignored.
minWordLength() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
 
minWordLength(int) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.DirectCandidateGenerator
The minimum length a suggest text term must have in order to be corrected.
minWordLength(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
The minimum length a suggest text term must have in order to be corrected.
minWordSize - Variable in class org.elasticsearch.index.analysis.compound.AbstractCompoundWordTokenFilterFactory
 
misplacedBindingAnnotation(Member, Annotation) - Method in class org.elasticsearch.common.inject.internal.Errors
 
missing - Variable in class org.elasticsearch.index.store.Store.RecoveryDiff
Files that exist in the source but not in the target
missing(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new Missing aggregation with the given name.
Missing - Interface in org.elasticsearch.search.aggregations.bucket.missing
A missing aggregation.
missing() - Method in class org.elasticsearch.search.facet.DoubleFacetAggregatorBase
 
missing() - Method in class org.elasticsearch.search.facet.LongFacetAggregatorBase
 
missing() - Method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
missing(Object) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
Sets the value when a field is missing in a doc.
missing(Object) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
Not relevant.
missing(Object) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
 
missing(Object) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
Not really relevant.
missing(Object) - Method in class org.elasticsearch.search.sort.SortBuilder
Sets the value when a field is missing in a doc.
MissingAggregator - Class in org.elasticsearch.search.aggregations.bucket.missing
 
MissingAggregator(String, AggregatorFactories, ValuesSource, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
 
MissingAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.missing
 
MissingBuilder - Class in org.elasticsearch.search.aggregations.bucket.missing
Builder for the Missing aggregation.
MissingBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingBuilder
Sole constructor.
missingConstantValues() - Method in class org.elasticsearch.common.inject.internal.Errors
 
missingConstructor(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
MissingFieldQueryExtension - Class in org.apache.lucene.queryparser.classic
 
MissingFieldQueryExtension() - Constructor for class org.apache.lucene.queryparser.classic.MissingFieldQueryExtension
 
missingFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter only documents where a field does not exists in them.
MissingFilterBuilder - Class in org.elasticsearch.index.query
Constructs a filter that only match on documents that the field has a value in them.
MissingFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.MissingFilterBuilder
 
MissingFilterParser - Class in org.elasticsearch.index.query
 
MissingFilterParser() - Constructor for class org.elasticsearch.index.query.MissingFilterParser
 
missingImplementation(Key) - Method in class org.elasticsearch.common.inject.internal.Errors
We use a fairly generic error message here.
missingObject(Object, boolean) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
Return the missing object value according to the reduced type of the comparator.
MissingParser - Class in org.elasticsearch.search.aggregations.bucket.missing
 
MissingParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingParser
 
missingRuntimeRetention(Object) - Method in class org.elasticsearch.common.inject.internal.Errors
 
missingScopeAnnotation() - Method in class org.elasticsearch.common.inject.internal.Errors
 
mkdirs(File) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
mlockall(int) - Static method in class org.elasticsearch.common.jna.CLibrary
 
mlockAll() - Method in class org.elasticsearch.monitor.process.ProcessInfo
 
MmapFsDirectoryService - Class in org.elasticsearch.index.store.fs
 
MmapFsDirectoryService(ShardId, Settings, IndexStore) - Constructor for class org.elasticsearch.index.store.fs.MmapFsDirectoryService
 
MmapFsIndexStore - Class in org.elasticsearch.index.store.fs
 
MmapFsIndexStore(Index, Settings, IndexService, IndicesStore, NodeEnvironment) - Constructor for class org.elasticsearch.index.store.fs.MmapFsIndexStore
 
MmapFsIndexStoreModule - Class in org.elasticsearch.index.store.fs
 
MmapFsIndexStoreModule() - Constructor for class org.elasticsearch.index.store.fs.MmapFsIndexStoreModule
 
mod(int, int) - Static method in enum org.elasticsearch.common.math.MathUtils
Return the (positive) remainder of the division of v by mod.
mode - Variable in class org.elasticsearch.index.query.functionscore.DecayFunctionParser.AbstractDistanceScoreFunction
 
mode - Variable in class org.elasticsearch.search.facet.FacetBuilder
 
mode(FacetBuilder.Mode) - Method in class org.elasticsearch.search.facet.FacetBuilder
 
model() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
modifier(FieldValueFactorFunction.Modifier) - Method in class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionBuilder
 
Module - Interface in org.elasticsearch.common.inject
A module contributes configuration information, typically interface bindings, which will be used to create an Injector.
Module(Version) - Constructor for class org.elasticsearch.Version.Module
 
Modules - Class in org.elasticsearch.common.inject
 
Modules() - Constructor for class org.elasticsearch.common.inject.Modules
 
Modules - Class in org.elasticsearch.common.inject.util
Static utility methods for creating and working with instances of Module.
modules() - Method in class org.elasticsearch.plugins.AbstractPlugin
Defaults to return an empty list.
modules(Settings) - Method in class org.elasticsearch.plugins.AbstractPlugin
Defaults to return an empty list.
modules() - Method in interface org.elasticsearch.plugins.Plugin
Node level modules (classes, will automatically be created).
modules(Settings) - Method in interface org.elasticsearch.plugins.Plugin
Node level modules (instances)
modules() - Method in class org.elasticsearch.plugins.PluginsService
 
modules(Settings) - Method in class org.elasticsearch.plugins.PluginsService
 
Modules.OverriddenModuleBuilder - Interface in org.elasticsearch.common.inject.util
See the EDSL example at override().
ModulesBuilder - Class in org.elasticsearch.common.inject
 
ModulesBuilder() - Constructor for class org.elasticsearch.common.inject.ModulesBuilder
 
MonitorModule - Class in org.elasticsearch.monitor
 
MonitorModule(Settings) - Constructor for class org.elasticsearch.monitor.MonitorModule
 
MonitorModule.MonitorSettings - Class in org.elasticsearch.monitor
 
MonitorService - Class in org.elasticsearch.monitor
 
MonitorService(Settings, JvmMonitorService, OsService, ProcessService, JvmService, NetworkService, FsService) - Constructor for class org.elasticsearch.monitor.MonitorService
 
MonitorSettings() - Constructor for class org.elasticsearch.monitor.MonitorModule.MonitorSettings
 
MONTH - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
moreLikeThis(MoreLikeThisRequest) - Method in interface org.elasticsearch.client.Client
A more like this action to search for documents that are "like" a specific document.
moreLikeThis(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in interface org.elasticsearch.client.Client
A more like this action to search for documents that are "like" a specific document.
moreLikeThis(MoreLikeThisRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
moreLikeThis(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
moreLikeThis(MoreLikeThisRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
moreLikeThis(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
MoreLikeThisAction - Class in org.elasticsearch.action.mlt
 
MoreLikeThisFetchService - Class in org.elasticsearch.index.search.morelikethis
 
MoreLikeThisFetchService(Client, Settings) - Constructor for class org.elasticsearch.index.search.morelikethis.MoreLikeThisFetchService
 
moreLikeThisFieldQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
A more like this query that runs against a specific field.
MoreLikeThisFieldQueryBuilder - Class in org.elasticsearch.index.query
Deprecated.
MoreLikeThisFieldQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
A more like this query that runs against a specific field.
MoreLikeThisFieldQueryParser - Class in org.elasticsearch.index.query
Deprecated.
MoreLikeThisFieldQueryParser() - Constructor for class org.elasticsearch.index.query.MoreLikeThisFieldQueryParser
Deprecated.
 
MoreLikeThisQuery - Class in org.elasticsearch.common.lucene.search
 
MoreLikeThisQuery() - Constructor for class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
MoreLikeThisQuery(String, String[], Analyzer) - Constructor for class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
moreLikeThisQuery(String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
A more like this query that finds documents that are "like" the provided MoreLikeThisQueryBuilder.likeText(String) which is checked against the fields the query is constructed with.
moreLikeThisQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
A more like this query that finds documents that are "like" the provided MoreLikeThisQueryBuilder.likeText(String) which is checked against the "_all" field.
MoreLikeThisQueryBuilder - Class in org.elasticsearch.index.query
A more like this query that finds documents that are "like" the provided MoreLikeThisQueryBuilder.likeText(String) which is checked against the fields the query is constructed with.
MoreLikeThisQueryBuilder() - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Constructs a new more like this query which uses the "_all" field.
MoreLikeThisQueryBuilder(String...) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the field names that will be used when generating the 'More Like This' query.
MoreLikeThisQueryBuilder.Item - Class in org.elasticsearch.index.query
A single get item.
MoreLikeThisQueryParser - Class in org.elasticsearch.index.query
 
MoreLikeThisQueryParser() - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryParser
 
MoreLikeThisQueryParser.Fields - Class in org.elasticsearch.index.query
 
MoreLikeThisRequest - Class in org.elasticsearch.action.mlt
A more like this request allowing to search for documents that a "like" the provided document.
MoreLikeThisRequest(String) - Constructor for class org.elasticsearch.action.mlt.MoreLikeThisRequest
Constructs a new more like this request for a document that will be fetch from the provided index.
moreLikeThisRequest(String) - Static method in class org.elasticsearch.client.Requests
More like this request represents a request to search for documents that are "like" the provided (fetched) document.
MoreLikeThisRequestBuilder - Class in org.elasticsearch.action.mlt
 
MoreLikeThisRequestBuilder(Client) - Constructor for class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
 
MoreLikeThisRequestBuilder(Client, String, String, String) - Constructor for class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
 
MoreTypes - Class in org.elasticsearch.common.inject.internal
Static methods for working with types that we aren't publishing in the public Types API.
MoreTypes.GenericArrayTypeImpl - Class in org.elasticsearch.common.inject.internal
 
MoreTypes.MemberImpl - Class in org.elasticsearch.common.inject.internal
We cannot serialize the built-in Java member classes, which prevents us from using Members in our exception types.
MoreTypes.ParameterizedTypeImpl - Class in org.elasticsearch.common.inject.internal
 
MoreTypes.WildcardTypeImpl - Class in org.elasticsearch.common.inject.internal
The WildcardType interface supports multiple upper bounds and multiple lower bounds.
move(MutableShardRouting, RoutingNode) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
This function executes a move operation moving the given shard from the given node to the minimal eligible node with respect to the weight function.
move(MutableShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
 
move(MutableShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
move(MutableShardRouting, RoutingNode, RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
Moves a shard from the given node to other node.
move(MutableShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
 
move(Path, Path) - Static method in class org.elasticsearch.common.io.FileSystemUtils
Move or rename a file to a target file.
MoveAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
A command that moves a shard from a specific node to another node.
Note: The shard needs to be in the state ShardRoutingState.STARTED in order to be moved.
MoveAllocationCommand(ShardId, String, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
 
MoveAllocationCommand.Factory - Class in org.elasticsearch.cluster.routing.allocation.command
 
moveFilesWithoutOverwriting(File, File, String) - Static method in class org.elasticsearch.common.io.FileSystemUtils
This utility copy a full directory content (excluded) under a new directory but without overwriting existing files.
moveToClosed() - Method in class org.elasticsearch.common.component.Lifecycle
 
moveToSecondPhase() - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
moveToStarted() - Method in class org.elasticsearch.common.component.Lifecycle
 
moveToStopped() - Method in class org.elasticsearch.common.component.Lifecycle
 
moveToUnassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodeIterator
 
Multi() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
 
MULTI_FIELD_CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.TypeParsers
 
MULTI_VALUE_MODE - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionParser
 
Multibinder<T> - Class in org.elasticsearch.common.inject.multibindings
An API to bind multiple values separately, only to later inject them as a complete collection.
MultiBucketsAggregation - Interface in org.elasticsearch.search.aggregations.bucket
An aggregation that returns multiple buckets
MultiBucketsAggregation.Bucket - Interface in org.elasticsearch.search.aggregations.bucket
A bucket represents a criteria to which all documents that fall in it adhere to.
MultiBucketsAggregation.Bucket.SubAggregationComparator<B extends MultiBucketsAggregation.Bucket> - Class in org.elasticsearch.search.aggregations.bucket
 
MultiCandidateGeneratorWrapper - Class in org.elasticsearch.search.suggest.phrase
 
MultiCandidateGeneratorWrapper(int, CandidateGenerator...) - Constructor for class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
 
MulticastChannel - Class in org.elasticsearch.common.network
A multicast channel that supports registering for receive events, and sending datagram packets.
MulticastChannel(MulticastChannel.Listener) - Constructor for class org.elasticsearch.common.network.MulticastChannel
 
MulticastChannel.Config - Class in org.elasticsearch.common.network
Config of multicast channel.
MulticastChannel.Listener - Interface in org.elasticsearch.common.network
Listener that gets called when data is received on the multicast channel.
MulticastChannel.MultiListener - Class in org.elasticsearch.common.network
Simple listener that wraps multiple listeners into one.
multicastInterface - Variable in class org.elasticsearch.common.network.MulticastChannel.Config
 
MulticastZenPing - Class in org.elasticsearch.discovery.zen.ping.multicast
 
MulticastZenPing(ThreadPool, TransportService, ClusterName, Version) - Constructor for class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
MulticastZenPing(Settings, ThreadPool, TransportService, ClusterName, NetworkService, Version) - Constructor for class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
MultiCollector - Class in org.elasticsearch.common.lucene
 
MultiCollector(Collector, Collector[]) - Constructor for class org.elasticsearch.common.lucene.MultiCollector
 
multiFieldConverterTypeParser - Static variable in class org.elasticsearch.index.mapper.core.TypeParsers
 
multiFieldPathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
multiFieldPathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
multiFields - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
MultiFields(ContentPath.Type, ImmutableOpenMap<String, Mapper>) - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields
 
multiFieldsBuilder - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
MultiGeoPointValues - Class in org.elasticsearch.index.fielddata
A stateful lightweight per document set of GeoPoint values.
MultiGeoPointValues() - Constructor for class org.elasticsearch.index.fielddata.MultiGeoPointValues
Creates a new MultiGeoPointValues instance
multiGet(MultiGetRequest) - Method in interface org.elasticsearch.client.Client
Multi get documents.
multiGet(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in interface org.elasticsearch.client.Client
Multi get documents.
multiGet(MultiGetRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
multiGet(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
multiGet(MultiGetRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
multiGet(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
MultiGetAction - Class in org.elasticsearch.action.get
 
MultiGetItemResponse - Class in org.elasticsearch.action.get
A single multi get response.
MultiGetItemResponse(GetResponse, MultiGetResponse.Failure) - Constructor for class org.elasticsearch.action.get.MultiGetItemResponse
 
MultiGetRequest - Class in org.elasticsearch.action.get
 
MultiGetRequest() - Constructor for class org.elasticsearch.action.get.MultiGetRequest
 
MultiGetRequest(ActionRequest) - Constructor for class org.elasticsearch.action.get.MultiGetRequest
Creates a multi get 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
MultiGetRequest.Item - Class in org.elasticsearch.action.get
A single get item.
MultiGetRequestBuilder - Class in org.elasticsearch.action.get
A multi get document action request builder.
MultiGetRequestBuilder(Client) - Constructor for class org.elasticsearch.action.get.MultiGetRequestBuilder
 
MultiGetResponse - Class in org.elasticsearch.action.get
 
MultiGetResponse(MultiGetItemResponse[]) - Constructor for class org.elasticsearch.action.get.MultiGetResponse
 
MultiGetResponse.Failure - Class in org.elasticsearch.action.get
Represents a failure.
MultiGetShardRequest - Class in org.elasticsearch.action.get
 
MultiGetShardResponse - Class in org.elasticsearch.action.get
 
multiLine(MultiLineStringBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
 
MultiLineStringBuilder - Class in org.elasticsearch.common.geo.builders
 
MultiLineStringBuilder() - Constructor for class org.elasticsearch.common.geo.builders.MultiLineStringBuilder
 
MultiLineStringBuilder.InternalLineStringBuilder - Class in org.elasticsearch.common.geo.builders
 
MultiListener() - Constructor for class org.elasticsearch.common.network.MulticastChannel.MultiListener
 
multiMatchQuery(Object, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
Creates a match query with type "BOOLEAN" for the provided field name and text.
MultiMatchQuery - Class in org.elasticsearch.index.search
 
MultiMatchQuery(QueryParseContext) - Constructor for class org.elasticsearch.index.search.MultiMatchQuery
 
MultiMatchQuery.CrossFieldsQueryBuilder - Class in org.elasticsearch.index.search
 
MultiMatchQuery.QueryBuilder - Class in org.elasticsearch.index.search
 
MultiMatchQueryBuilder - Class in org.elasticsearch.index.query
Same as MatchQueryBuilder but supports multiple fields.
MultiMatchQueryBuilder(Object, String...) - Constructor for class org.elasticsearch.index.query.MultiMatchQueryBuilder
Constructs a new text query.
MultiMatchQueryBuilder.Type - Enum in org.elasticsearch.index.query
 
MultiMatchQueryParser - Class in org.elasticsearch.index.query
Same as MatchQueryParser but has support for multiple fields.
MultiMatchQueryParser() - Constructor for class org.elasticsearch.index.query.MultiMatchQueryParser
 
MultiOrdinals - Class in org.elasticsearch.index.fielddata.ordinals
Ordinals implementation which is efficient at storing field data ordinals for multi-valued or sparse fields.
MultiOrdinals(OrdinalsBuilder, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
 
multiPercolate(MultiPercolateRequest) - Method in interface org.elasticsearch.client.Client
Performs multiple percolate requests.
multiPercolate(MultiPercolateRequest, ActionListener<MultiPercolateResponse>) - Method in interface org.elasticsearch.client.Client
Performs multiple percolate requests.
multiPercolate(MultiPercolateRequest, ActionListener<MultiPercolateResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
multiPercolate(MultiPercolateRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
MultiPercolateAction - Class in org.elasticsearch.action.percolate
 
MultiPercolateRequest - Class in org.elasticsearch.action.percolate
A multi percolate request that encapsulates multiple PercolateRequest instances in a single api call.
MultiPercolateRequest() - Constructor for class org.elasticsearch.action.percolate.MultiPercolateRequest
 
MultiPercolateRequestBuilder - Class in org.elasticsearch.action.percolate
A builder for to ease the use of defining a MultiPercolateRequest instance.
MultiPercolateRequestBuilder(Client) - Constructor for class org.elasticsearch.action.percolate.MultiPercolateRequestBuilder
 
MultiPercolateResponse - Class in org.elasticsearch.action.percolate
Represents the response of a multi percolate request.
MultiPercolateResponse.Item - Class in org.elasticsearch.action.percolate
Encapsulates a single percolator response which may contain an error or the actual percolator response itself.
MultiPhrasePrefixQuery - Class in org.elasticsearch.common.lucene.search
 
MultiPhrasePrefixQuery() - Constructor for class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
 
multiPoint(MultiPointBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
 
MultiPointBuilder - Class in org.elasticsearch.common.geo.builders
 
MultiPointBuilder() - Constructor for class org.elasticsearch.common.geo.builders.MultiPointBuilder
 
multipolygon(GeometryFactory, Coordinate[][][]) - Static method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
Create a Multipolygon from a set of coordinates.
multiPolygon(MultiPolygonBuilder) - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
 
MultiPolygonBuilder - Class in org.elasticsearch.common.geo.builders
 
MultiPolygonBuilder() - Constructor for class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
 
MultiPolygonBuilder(ShapeBuilder.Orientation) - Constructor for class org.elasticsearch.common.geo.builders.MultiPolygonBuilder
 
MultiPolygonBuilder.InternalPolygonBuilder - Class in org.elasticsearch.common.geo.builders
 
multiPolygonMayOverlap - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
It's possible that some geometries in a MULTI* shape might overlap.
multiSearch(MultiSearchRequest) - Method in interface org.elasticsearch.client.Client
Performs multiple search requests.
multiSearch(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in interface org.elasticsearch.client.Client
Performs multiple search requests.
multiSearch(MultiSearchRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
multiSearch(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
multiSearch(MultiSearchRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
multiSearch(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
MultiSearchAction - Class in org.elasticsearch.action.search
 
MultiSearchRequest - Class in org.elasticsearch.action.search
A multi search API request.
MultiSearchRequest() - Constructor for class org.elasticsearch.action.search.MultiSearchRequest
 
MultiSearchRequestBuilder - Class in org.elasticsearch.action.search
A request builder for multiple search requests.
MultiSearchRequestBuilder(Client) - Constructor for class org.elasticsearch.action.search.MultiSearchRequestBuilder
 
MultiSearchResponse - Class in org.elasticsearch.action.search
A multi search response.
MultiSearchResponse(MultiSearchResponse.Item[]) - Constructor for class org.elasticsearch.action.search.MultiSearchResponse
 
MultiSearchResponse.Item - Class in org.elasticsearch.action.search
A search response item, holding the actual search response, or an error message if it failed.
MultiTermQueryBuilder - Interface in org.elasticsearch.index.query
 
multiTermVectors(MultiTermVectorsRequest) - Method in interface org.elasticsearch.client.Client
Multi get term vectors.
multiTermVectors(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in interface org.elasticsearch.client.Client
Multi get term vectors.
multiTermVectors(MultiTermVectorsRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
multiTermVectors(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
multiTermVectors(MultiTermVectorsRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
multiTermVectors(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
MultiTermVectorsAction - Class in org.elasticsearch.action.termvector
 
MultiTermVectorsItemResponse - Class in org.elasticsearch.action.termvector
A single multi get response.
MultiTermVectorsItemResponse(TermVectorResponse, MultiTermVectorsResponse.Failure) - Constructor for class org.elasticsearch.action.termvector.MultiTermVectorsItemResponse
 
MultiTermVectorsRequest - Class in org.elasticsearch.action.termvector
 
MultiTermVectorsRequest() - Constructor for class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
MultiTermVectorsRequestBuilder - Class in org.elasticsearch.action.termvector
 
MultiTermVectorsRequestBuilder(Client) - Constructor for class org.elasticsearch.action.termvector.MultiTermVectorsRequestBuilder
 
MultiTermVectorsResponse - Class in org.elasticsearch.action.termvector
 
MultiTermVectorsResponse(MultiTermVectorsItemResponse[]) - Constructor for class org.elasticsearch.action.termvector.MultiTermVectorsResponse
 
MultiTermVectorsResponse.Failure - Class in org.elasticsearch.action.termvector
Represents a failure.
MultiTermVectorsShardRequest - Class in org.elasticsearch.action.termvector
 
MultiTermVectorsShardResponse - Class in org.elasticsearch.action.termvector
 
MultiValue() - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
 
MultiValue(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
 
MultiValue(String, long, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
 
multiValued(boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData.Builder
 
multiValued() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData
 
MultiValueMode - Enum in org.elasticsearch.search
Defines what values to pick in the case a document contains multiple values for a particular field.
munlockall() - Static method in class org.elasticsearch.common.jna.CLibrary
 
murmur3Field(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
Murmur3FieldMapper - Class in org.elasticsearch.index.mapper.core
 
Murmur3FieldMapper(FieldMapper.Names, int, float, FieldType, Boolean, Long, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.Murmur3FieldMapper
 
Murmur3FieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
Murmur3FieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
Murmur3FieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
MurmurHash3 - Enum in org.elasticsearch.common.hash
MurmurHash3 hashing functions.
MurmurHash3.Hash128 - Class in org.elasticsearch.common.hash
A 128-bits hash.
must(FilterBuilder) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds a filter that must appear in the matching documents.
must(FilterBuilder...) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds multiple must filters.
must(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Adds a query that must appear in the matching documents.
MustacheScriptEngineService - Class in org.elasticsearch.script.mustache
Main entry point handling template registration, compilation and execution.
MustacheScriptEngineService(Settings) - Constructor for class org.elasticsearch.script.mustache.MustacheScriptEngineService
 
mustAck(DiscoveryNode) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
Called to determine which nodes the acknowledgement is expected from
mustNot(FilterBuilder) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds a filter that must not appear in the matching documents.
mustNot(FilterBuilder...) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds multiple must not filters.
mustNot(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Adds a query that must not appear in the matching documents.
MutableShardRouting - Class in org.elasticsearch.cluster.routing
Similar to ImmutableShardRouting this class keeps metadata of the current shard.
MutableShardRouting(ShardRouting) - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 
MutableShardRouting(ShardRouting, long) - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 
MutableShardRouting(String, int, String, boolean, ShardRoutingState, long) - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 
MutableShardRouting(String, int, String, String, boolean, ShardRoutingState, long) - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 
MutableShardRouting(String, int, String, String, RestoreSource, boolean, ShardRoutingState, long) - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 
MutualInformation - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
MutualInformation(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
 
MutualInformation.MutualInformationBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
MutualInformation.MutualInformationParser - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
MutualInformationBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation.MutualInformationBuilder
 
MutualInformationParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation.MutualInformationParser
 

N

NA_INTERFACE - Static variable in class org.elasticsearch.monitor.network.NetworkInfo
 
NAME - Static variable in class org.apache.lucene.queryparser.classic.ExistsFieldQueryExtension
 
NAME - Static variable in class org.apache.lucene.queryparser.classic.MissingFieldQueryExtension
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
 
name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
Sets the name of the repository to unregister.
name() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
The name of the repository.
NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
 
name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
Sets the name of the repository.
name() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
The name of the repository.
NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
 
name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
Sets the name of the repository to unregister.
name() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
The name of the repository.
NAME - Static variable in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
 
name() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
Returns the alias name
NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.flush.FlushAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.get.GetIndexAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.optimize.OptimizeAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.status.IndicesStatusAction
Deprecated.
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
 
name() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
The index template name to delete.
NAME - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
 
name(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
Sets the name of the index template.
name() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
The name of the index template.
NAME - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerAction
 
name(String) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
Sets the name of the warmer.
name() - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
 
NAME - Static variable in class org.elasticsearch.action.bulk.BulkAction
 
NAME - Static variable in class org.elasticsearch.action.count.CountAction
 
NAME - Static variable in class org.elasticsearch.action.delete.DeleteAction
 
NAME - Static variable in class org.elasticsearch.action.deletebyquery.DeleteByQueryAction
 
NAME - Static variable in class org.elasticsearch.action.exists.ExistsAction
 
NAME - Static variable in class org.elasticsearch.action.explain.ExplainAction
 
name() - Method in class org.elasticsearch.action.GenericAction
The name of the action.
NAME - Static variable in class org.elasticsearch.action.get.GetAction
 
NAME - Static variable in class org.elasticsearch.action.get.MultiGetAction
 
NAME - Static variable in class org.elasticsearch.action.index.IndexAction
 
NAME - Static variable in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptAction
 
NAME - Static variable in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptAction
 
NAME - Static variable in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptAction
 
NAME - Static variable in class org.elasticsearch.action.mlt.MoreLikeThisAction
 
NAME - Static variable in class org.elasticsearch.action.percolate.MultiPercolateAction
 
NAME - Static variable in class org.elasticsearch.action.percolate.PercolateAction
 
NAME - Static variable in class org.elasticsearch.action.search.ClearScrollAction
 
NAME - Static variable in class org.elasticsearch.action.search.MultiSearchAction
 
NAME - Static variable in class org.elasticsearch.action.search.SearchAction
 
NAME - Static variable in class org.elasticsearch.action.search.SearchScrollAction
 
NAME - Static variable in class org.elasticsearch.action.suggest.SuggestAction
 
NAME - Static variable in class org.elasticsearch.action.termvector.MultiTermVectorsAction
 
NAME - Static variable in class org.elasticsearch.action.termvector.TermVectorAction
 
NAME - Static variable in class org.elasticsearch.action.update.UpdateAction
 
name() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
name() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
Returns repository name
name() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The name of the node.
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand
 
name() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand
 
name() - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
Get the name of the command
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
 
name() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
 
name() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
Deprecated.
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.NodeVersionAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.RebalanceOnlyWhenActiveAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
 
NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
 
name() - Method in interface org.elasticsearch.common.blobstore.BlobMetaData
 
name() - Method in class org.elasticsearch.common.blobstore.support.PlainBlobMetaData
 
name() - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd
 
name() - Method in class org.elasticsearch.common.cli.CliToolConfig
 
name() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
 
name() - Method in class org.elasticsearch.index.analysis.AbstractCharFilterFactory
 
name() - Method in class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
Returns the injected name of the analyzer.
name() - Method in class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
 
name() - Method in class org.elasticsearch.index.analysis.AbstractTokenizerFactory
 
name() - Method in interface org.elasticsearch.index.analysis.AnalyzerProvider
 
name() - Method in interface org.elasticsearch.index.analysis.CharFilterFactory
 
name() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
The name of the analyzer.
name() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
 
name() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
 
name() - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
 
name() - Method in interface org.elasticsearch.index.analysis.TokenizerFactory
 
name() - Method in class org.elasticsearch.index.codec.docvaluesformat.AbstractDocValuesFormatProvider
 
name() - Method in interface org.elasticsearch.index.codec.docvaluesformat.DocValuesFormatProvider
Returns the name of this providers DocValuesFormat
name() - Method in class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider.Factory
 
name() - Method in class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider
 
name() - Method in class org.elasticsearch.index.codec.postingsformat.AbstractPostingsFormatProvider
 
name() - Method in interface org.elasticsearch.index.codec.postingsformat.PostingsFormatProvider
Returns the name of this providers PostingsFormat
name() - Method in class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider.Factory
 
name() - Method in class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider
 
name() - Method in class org.elasticsearch.index.gateway.CommitPoint.FileInfo
 
name() - Method in class org.elasticsearch.index.gateway.CommitPoint
 
name() - Method in class org.elasticsearch.index.Index
 
name() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
name() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
 
name(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
name() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The logical name of the field.
name(String) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
Returns the field mappers based on the mapper name.
NAME - Static variable in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
name() - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.VersionFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
name - Variable in class org.elasticsearch.index.mapper.Mapper.Builder
 
name() - Method in class org.elasticsearch.index.mapper.Mapper.Builder
 
name() - Method in interface org.elasticsearch.index.mapper.Mapper
 
name(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns FieldMappers for all the FieldMappers that are registered under the given name across all the different DocumentMapper types.
name() - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
name() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
NAME - Static variable in class org.elasticsearch.index.query.AndFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.BoolFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.BoolQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.BoostingQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.CommonTermsQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.ConstantScoreQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.DisMaxQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.ExistsFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.FieldMaskingSpanQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.FilteredQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.FQueryFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.FuzzyLikeThisQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.FuzzyQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.GeoDistanceFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.GeoDistanceRangeFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.GeohashCellFilter
 
NAME - Static variable in class org.elasticsearch.index.query.GeoPolygonFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.GeoShapeFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.GeoShapeQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.HasChildFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.HasChildQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.HasParentFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.HasParentQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.IdsFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.IdsQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.IndicesFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.IndicesQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.LimitFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.MatchAllFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.MatchAllQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.MatchQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.MissingFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.MoreLikeThisFieldQueryParser
Deprecated.
 
NAME - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.MultiMatchQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.NestedFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.NestedQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.NotFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.NumericRangeFilterParser
Deprecated.
 
NAME - Static variable in class org.elasticsearch.index.query.OrFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.PrefixFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.PrefixQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.QueryFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.QueryStringQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.RangeFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.RangeQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.RegexpFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.RegexpQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.ScriptFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.SimpleQueryStringParser
 
NAME - Static variable in class org.elasticsearch.index.query.SpanFirstQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.SpanMultiTermQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.SpanNearQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.SpanNotQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.SpanOrQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.SpanTermQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.TemplateQueryParser
Name to reference this type of query.
NAME - Static variable in class org.elasticsearch.index.query.TermFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.TermQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.TermsFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.TermsQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.TopChildrenQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.TypeFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.WildcardQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.WrapperFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.WrapperQueryParser
 
name() - Method in class org.elasticsearch.index.similarity.AbstractSimilarityProvider
Returns the name associated with the Provider
name() - Method in class org.elasticsearch.index.similarity.PreBuiltSimilarityProvider.Factory
 
name() - Method in interface org.elasticsearch.index.similarity.SimilarityProvider
Returns the name associated with the Provider
name() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
Returns the base file name
name() - Method in class org.elasticsearch.index.store.distributor.AbstractDistributor
 
name() - Method in class org.elasticsearch.index.store.distributor.LeastUsedDistributor
 
name() - Method in class org.elasticsearch.index.store.distributor.RandomWeightedDistributor
 
name() - Method in class org.elasticsearch.index.store.StoreFileMetaData
Returns the name of this file
name() - Method in exception org.elasticsearch.indices.IndexTemplateAlreadyExistsException
 
name() - Method in exception org.elasticsearch.indices.IndexTemplateMissingException
 
name() - Method in exception org.elasticsearch.indices.InvalidIndexTemplateException
 
name() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
name() - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
file name *
name() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
name() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
name() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
name() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
name() - Method in interface org.elasticsearch.plugins.Plugin
The name of the plugin.
name(String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets snapshot name
name() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns snapshot name
name() - Method in class org.elasticsearch.repositories.RepositoryName
 
name() - Method in class org.elasticsearch.river.RiverName
 
NAME - Static variable in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
NAME - Static variable in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
NAME - Static variable in class org.elasticsearch.script.mustache.MustacheScriptEngineService
 
NAME - Static variable in class org.elasticsearch.script.NativeScriptEngineService
 
name - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
name() - Method in class org.elasticsearch.search.aggregations.Aggregator
 
name - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
 
name - Variable in class org.elasticsearch.search.aggregations.InternalAggregation
 
name() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.Type
 
name - Variable in class org.elasticsearch.search.aggregations.support.OrderPath.Token
 
name - Variable in class org.elasticsearch.search.facet.FacetBuilder
 
name() - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsContext.FieldDataField
 
name() - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsContext.PartialField
 
name() - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsContext.ScriptField
 
name() - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 
name() - Method in class org.elasticsearch.search.highlight.HighlightField
The name of the field highlighted.
name() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
 
NAME - Static variable in class org.elasticsearch.search.rescore.QueryRescorer
 
name() - Method in class org.elasticsearch.search.rescore.QueryRescorer
 
name() - Method in interface org.elasticsearch.search.rescore.Rescorer
Returns the name of this rescorer
name() - Method in interface org.elasticsearch.search.SearchHitField
The name of the field.
name - Variable in class org.elasticsearch.search.suggest.context.ContextBuilder
 
name - Variable in class org.elasticsearch.search.suggest.context.ContextMapping.ContextQuery
 
name() - Method in class org.elasticsearch.search.suggest.context.ContextMapping.ContextQuery
 
name - Variable in class org.elasticsearch.search.suggest.context.ContextMapping
 
name() - Method in class org.elasticsearch.search.suggest.context.ContextMapping
 
name - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
 
name() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
 
name() - Method in class org.elasticsearch.snapshots.RestoreInfo
Snapshot name
name() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreRequest
Returns snapshot name
name() - Method in interface org.elasticsearch.snapshots.Snapshot
Returns snapshot name
name() - Method in class org.elasticsearch.snapshots.SnapshotInfo
Returns snapshot name
name() - Method in class org.elasticsearch.snapshots.SnapshotsService.SnapshotRequest
Returns snapshot name
name - Variable in class org.elasticsearch.transport.netty.NettyTransport.ServerChannelPipelineFactory
 
Named - Annotation Type in org.elasticsearch.common.inject.name
Annotates named things.
named(String) - Static method in class org.elasticsearch.common.inject.name.Names
Creates a Named annotation with name as the value.
NamedAnalyzer - Class in org.elasticsearch.index.analysis
Named analyzer is an analyzer wrapper around an actual analyzer (NamedAnalyzer.analyzer that is associated with a name (NamedAnalyzer.name().
NamedAnalyzer(NamedAnalyzer, int) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
 
NamedAnalyzer(String, Analyzer) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
 
NamedAnalyzer(String, AnalyzerScope, Analyzer) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
 
NamedAnalyzer(String, AnalyzerScope, Analyzer, int) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
 
namedFilters() - Method in class org.elasticsearch.index.query.ParsedFilter
 
namedFilters() - Method in class org.elasticsearch.index.query.ParsedQuery
 
namedStopWords - Static variable in class org.elasticsearch.index.analysis.Analysis
 
names() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
 
names(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
 
names(String...) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
Sets the names of the index templates.
names() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
The names of the index templates.
names() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequest
The name to delete.
names(String...) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequest
The name (or wildcard expression) of the index warmer to delete, or null to delete all warmers.
Names - Class in org.elasticsearch.common.inject.name
Utility methods for use with @Named.
Names - Class in org.elasticsearch.common
 
names() - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
names() - Method in interface org.elasticsearch.common.settings.Settings
 
names - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
names() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
names() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
Names(String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Names
 
Names(String, String, String, String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Names
 
Names(String, String, String, String, String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Names
 
Names() - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
Names() - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
 
names() - Method in class org.elasticsearch.index.query.AndFilterParser
 
names() - Method in class org.elasticsearch.index.query.BoolFilterParser
 
names() - Method in class org.elasticsearch.index.query.BoolQueryParser
 
names() - Method in class org.elasticsearch.index.query.BoostingQueryParser
 
names() - Method in class org.elasticsearch.index.query.CommonTermsQueryParser
 
names() - Method in class org.elasticsearch.index.query.ConstantScoreQueryParser
 
names() - Method in class org.elasticsearch.index.query.DisMaxQueryParser
 
names() - Method in class org.elasticsearch.index.query.ExistsFilterParser
 
names() - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryParser
 
names() - Method in class org.elasticsearch.index.query.FilteredQueryParser
 
names() - Method in interface org.elasticsearch.index.query.FilterParser
The names this filter is registered under.
names() - Method in class org.elasticsearch.index.query.FQueryFilterParser
 
NAMES - Static variable in class org.elasticsearch.index.query.functionscore.exp.ExponentialDecayFunctionParser
 
NAMES - Static variable in class org.elasticsearch.index.query.functionscore.factor.FactorParser
Deprecated.
 
NAMES - Static variable in class org.elasticsearch.index.query.functionscore.fieldvaluefactor.FieldValueFactorFunctionParser
 
names() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryParser
 
NAMES - Static variable in class org.elasticsearch.index.query.functionscore.gauss.GaussDecayFunctionParser
 
NAMES - Static variable in class org.elasticsearch.index.query.functionscore.lin.LinearDecayFunctionParser
 
NAMES - Static variable in class org.elasticsearch.index.query.functionscore.random.RandomScoreFunctionParser
 
NAMES - Static variable in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionParser
 
names() - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryParser
 
names() - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryParser
 
names() - Method in class org.elasticsearch.index.query.FuzzyQueryParser
 
names() - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
names() - Method in class org.elasticsearch.index.query.GeoDistanceFilterParser
 
names() - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterParser
 
names() - Method in class org.elasticsearch.index.query.GeohashCellFilter.Parser
 
names() - Method in class org.elasticsearch.index.query.GeoPolygonFilterParser
 
names() - Method in class org.elasticsearch.index.query.GeoShapeFilterParser
 
names() - Method in class org.elasticsearch.index.query.GeoShapeQueryParser
 
names() - Method in class org.elasticsearch.index.query.HasChildFilterParser
 
names() - Method in class org.elasticsearch.index.query.HasChildQueryParser
 
names() - Method in class org.elasticsearch.index.query.HasParentFilterParser
 
names() - Method in class org.elasticsearch.index.query.HasParentQueryParser
 
names() - Method in class org.elasticsearch.index.query.IdsFilterParser
 
names() - Method in class org.elasticsearch.index.query.IdsQueryParser
 
names() - Method in class org.elasticsearch.index.query.IndicesFilterParser
 
names() - Method in class org.elasticsearch.index.query.IndicesQueryParser
 
names() - Method in class org.elasticsearch.index.query.LimitFilterParser
 
names() - Method in class org.elasticsearch.index.query.MatchAllFilterParser
 
names() - Method in class org.elasticsearch.index.query.MatchAllQueryParser
 
names() - Method in class org.elasticsearch.index.query.MatchQueryParser
 
names() - Method in class org.elasticsearch.index.query.MissingFilterParser
 
names() - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryParser
Deprecated.
 
names() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryParser
 
names() - Method in class org.elasticsearch.index.query.MultiMatchQueryParser
 
names() - Method in class org.elasticsearch.index.query.NestedFilterParser
 
names() - Method in class org.elasticsearch.index.query.NestedQueryParser
 
names() - Method in class org.elasticsearch.index.query.NotFilterParser
 
names() - Method in class org.elasticsearch.index.query.NumericRangeFilterParser
Deprecated.
 
names() - Method in class org.elasticsearch.index.query.OrFilterParser
 
names() - Method in class org.elasticsearch.index.query.PrefixFilterParser
 
names() - Method in class org.elasticsearch.index.query.PrefixQueryParser
 
names() - Method in class org.elasticsearch.index.query.QueryFilterParser
 
names() - Method in interface org.elasticsearch.index.query.QueryParser
The names this query parser is registered under.
names() - Method in class org.elasticsearch.index.query.QueryStringQueryParser
 
names() - Method in class org.elasticsearch.index.query.RangeFilterParser
 
names() - Method in class org.elasticsearch.index.query.RangeQueryParser
 
names() - Method in class org.elasticsearch.index.query.RegexpFilterParser
 
names() - Method in class org.elasticsearch.index.query.RegexpQueryParser
 
names() - Method in class org.elasticsearch.index.query.ScriptFilterParser
 
names() - Method in class org.elasticsearch.index.query.SimpleQueryStringParser
 
names() - Method in class org.elasticsearch.index.query.SpanFirstQueryParser
 
names() - Method in class org.elasticsearch.index.query.SpanMultiTermQueryParser
 
names() - Method in class org.elasticsearch.index.query.SpanNearQueryParser
 
names() - Method in class org.elasticsearch.index.query.SpanNotQueryParser
 
names() - Method in class org.elasticsearch.index.query.SpanOrQueryParser
 
names() - Method in class org.elasticsearch.index.query.SpanTermQueryParser
 
names() - Method in class org.elasticsearch.index.query.TemplateQueryParser
 
names() - Method in class org.elasticsearch.index.query.TermFilterParser
 
names() - Method in class org.elasticsearch.index.query.TermQueryParser
 
names() - Method in class org.elasticsearch.index.query.TermsFilterParser
 
names() - Method in class org.elasticsearch.index.query.TermsQueryParser
 
names() - Method in class org.elasticsearch.index.query.TopChildrenQueryParser
 
names() - Method in class org.elasticsearch.index.query.TypeFilterParser
 
names() - Method in class org.elasticsearch.index.query.WildcardQueryParser
 
names() - Method in class org.elasticsearch.index.query.WrapperFilterParser
 
names() - Method in class org.elasticsearch.index.query.WrapperQueryParser
 
names() - Method in exception org.elasticsearch.rest.action.admin.indices.alias.delete.AliasesMissingException
 
NAMES - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
 
NAMES - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
 
names() - Method in class org.elasticsearch.search.highlight.FastVectorHighlighter
 
names() - Method in interface org.elasticsearch.search.highlight.Highlighter
 
names() - Method in class org.elasticsearch.search.highlight.PlainHighlighter
 
names() - Method in class org.elasticsearch.search.highlight.PostingsHighlighter
 
names() - Method in class org.elasticsearch.search.sort.GeoDistanceSortParser
 
names() - Method in class org.elasticsearch.search.sort.ScriptSortParser
 
names() - Method in interface org.elasticsearch.search.sort.SortParser
 
names() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggester
 
names() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
 
names() - Method in class org.elasticsearch.search.suggest.Suggester
 
names() - Method in class org.elasticsearch.search.suggest.term.TermSuggester
 
names() - Method in exception org.elasticsearch.search.warmer.IndexWarmerMissingException
 
Names() - Constructor for class org.elasticsearch.threadpool.ThreadPool.Names
 
NAMES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
 
NAMES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
 
NAMES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
 
NAMES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
 
nanos() - Method in class org.elasticsearch.common.unit.TimeValue
 
Natives - Class in org.elasticsearch.common.jna
 
Natives() - Constructor for class org.elasticsearch.common.jna.Natives
 
NativeScriptEngineService - Class in org.elasticsearch.script
A native script engine service.
NativeScriptEngineService(Settings, Map<String, NativeScriptFactory>) - Constructor for class org.elasticsearch.script.NativeScriptEngineService
 
NativeScriptFactory - Interface in org.elasticsearch.script
A factory to create instances of either ExecutableScript or SearchScript.
needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.AllFieldsVisitor
 
needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.CustomFieldsVisitor
 
needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.JustSourceFieldsVisitor
 
needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.JustUidFieldsVisitor
 
needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
 
needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.UidAndRoutingFieldsVisitor
 
needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.UidAndSourceFieldsVisitor
 
needsHashes - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
 
needsRefresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
Returns true iff the cache needs to be refreshed.
needToCheck() - Method in class org.elasticsearch.action.support.AutoCreateIndex
Do we really need to check if an index should be auto created?
negative(QueryBuilder) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
 
negativeBoost(float) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
 
neighbors(String) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Calculate all neighbors of a given geohash cell.
neighbors(boolean) - Method in class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
NEIGHBORS - Static variable in class org.elasticsearch.index.query.GeohashCellFilter
 
neighbors(boolean) - Method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping.Builder
Set neighborhood usage
nested() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
Nested(FixedBitSetFilter, FixedBitSetFilter) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
 
nested - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
nested(ObjectMapper.Nested) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
NESTED - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Defaults
 
nested() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
nested(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new Nested aggregation with the given name.
Nested - Interface in org.elasticsearch.search.aggregations.bucket.nested
A nested aggregation.
nested(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Sets the nested path the facet will execute on.
nested - Variable in class org.elasticsearch.search.facet.FacetBuilder
 
nested(String) - Method in class org.elasticsearch.search.facet.FacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.filter.FilterFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.query.QueryFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
Sets the nested path the facet will execute on.
NESTED_CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper
 
NESTED_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
 
NestedAggregator - Class in org.elasticsearch.search.aggregations.bucket.nested
 
NestedAggregator(String, AggregatorFactories, ObjectMapper, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
 
NestedAggregator.Factory - Class in org.elasticsearch.search.aggregations.bucket.nested
 
NestedBuilder - Class in org.elasticsearch.search.aggregations.bucket.nested
Builder for the Nested aggregation.
NestedBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedBuilder
Sole constructor.
NestedFacetExecutor - Class in org.elasticsearch.search.facet.nested
 
NestedFacetExecutor(FacetExecutor, SearchContext, String) - Constructor for class org.elasticsearch.search.facet.nested.NestedFacetExecutor
 
NestedFacetExecutor.Collector - Class in org.elasticsearch.search.facet.nested
 
NestedFacetExecutor.Post - Class in org.elasticsearch.search.facet.nested
 
nestedFilter(String, QueryBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
nestedFilter(String, FilterBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
NestedFilterBuilder - Class in org.elasticsearch.index.query
 
NestedFilterBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.index.query.NestedFilterBuilder
 
NestedFilterBuilder(String, FilterBuilder) - Constructor for class org.elasticsearch.index.query.NestedFilterBuilder
 
NestedFilterParser - Class in org.elasticsearch.index.query
 
NestedFilterParser(InnerHitsQueryParserHelper) - Constructor for class org.elasticsearch.index.query.NestedFilterParser
 
NestedInnerHits(SearchContext, Query, Map<String, InnerHitsContext.BaseInnerHits>, ObjectMapper, ObjectMapper) - Constructor for class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.NestedInnerHits
 
NestedInnerQueryParseSupport - Class in org.elasticsearch.index.query.support
A helper that helps with parsing inner queries of the nested query.
NestedInnerQueryParseSupport(XContentParser, SearchContext) - Constructor for class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
NestedInnerQueryParseSupport(QueryParseContext) - Constructor for class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
nestedObjectMapper - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
NestedParser - Class in org.elasticsearch.search.aggregations.bucket.nested
 
NestedParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedParser
 
nestedQuery(String, QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
 
nestedQuery(String, FilterBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
 
NestedQueryBuilder - Class in org.elasticsearch.index.query
 
NestedQueryBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.index.query.NestedQueryBuilder
 
NestedQueryBuilder(String, FilterBuilder) - Constructor for class org.elasticsearch.index.query.NestedQueryBuilder
 
NestedQueryParser - Class in org.elasticsearch.index.query
 
NestedQueryParser(InnerHitsQueryParserHelper) - Constructor for class org.elasticsearch.index.query.NestedQueryParser
 
NestedQueryParser.ToBlockJoinQueryBuilder - Class in org.elasticsearch.index.query
 
nestedScope() - Method in class org.elasticsearch.index.query.QueryParseContext
 
NestedScope - Class in org.elasticsearch.index.query.support
During query parsing this keeps track of the current nested level.
NestedScope() - Constructor for class org.elasticsearch.index.query.support.NestedScope
 
nestedTypeFilter() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
nestedTypePathAsString() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
NettyHeader - Class in org.elasticsearch.transport.netty
 
NettyHeader() - Constructor for class org.elasticsearch.transport.netty.NettyHeader
 
NettyHttpChannel - Class in org.elasticsearch.http.netty
 
NettyHttpChannel(NettyHttpServerTransport, NettyHttpRequest, Pattern, boolean) - Constructor for class org.elasticsearch.http.netty.NettyHttpChannel
 
NettyHttpChannel(NettyHttpServerTransport, NettyHttpRequest, Pattern, OrderedUpstreamMessageEvent, boolean) - Constructor for class org.elasticsearch.http.netty.NettyHttpChannel
 
NettyHttpRequest - Class in org.elasticsearch.http.netty
 
NettyHttpRequest(HttpRequest, Channel) - Constructor for class org.elasticsearch.http.netty.NettyHttpRequest
 
NettyHttpServerTransport - Class in org.elasticsearch.http.netty
 
NettyHttpServerTransport(Settings, NetworkService, BigArrays) - Constructor for class org.elasticsearch.http.netty.NettyHttpServerTransport
 
NettyHttpServerTransport.HttpChannelPipelineFactory - Class in org.elasticsearch.http.netty
 
NettyInternalESLogger - Class in org.elasticsearch.transport.netty
 
NettyInternalESLogger(ESLogger) - Constructor for class org.elasticsearch.transport.netty.NettyInternalESLogger
 
NettyInternalESLoggerFactory - Class in org.elasticsearch.transport.netty
 
NettyInternalESLoggerFactory() - Constructor for class org.elasticsearch.transport.netty.NettyInternalESLoggerFactory
 
NettyTransport - Class in org.elasticsearch.transport.netty
There are 4 types of connections per node, low/med/high/ping.
NettyTransport(Settings, ThreadPool, NetworkService, BigArrays, Version) - Constructor for class org.elasticsearch.transport.netty.NettyTransport
 
nettyTransport - Variable in class org.elasticsearch.transport.netty.NettyTransport.ClientChannelPipelineFactory
 
nettyTransport - Variable in class org.elasticsearch.transport.netty.NettyTransport.ServerChannelPipelineFactory
 
NettyTransport.ChannelCloseListener - Class in org.elasticsearch.transport.netty
 
NettyTransport.ClientChannelPipelineFactory - Class in org.elasticsearch.transport.netty
 
NettyTransport.NodeChannels - Class in org.elasticsearch.transport.netty
 
NettyTransport.ServerChannelPipelineFactory - Class in org.elasticsearch.transport.netty
 
NettyTransportChannel - Class in org.elasticsearch.transport.netty
 
NettyTransportChannel(NettyTransport, TransportServiceAdapter, String, Channel, long, Version, String) - Constructor for class org.elasticsearch.transport.netty.NettyTransportChannel
 
NettyUtils - Class in org.elasticsearch.common.netty
 
NettyUtils() - Constructor for class org.elasticsearch.common.netty.NettyUtils
 
NettyUtils.EsThreadNameDeterminer - Class in org.elasticsearch.common.netty
 
network() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Should the node Network be returned.
network(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Should the node Network be returned.
network() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node Network be returned.
network(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node Network be returned.
NetworkExceptionHelper - Class in org.elasticsearch.common.transport
 
NetworkExceptionHelper() - Constructor for class org.elasticsearch.common.transport.NetworkExceptionHelper
 
networkInfo() - Method in class org.elasticsearch.monitor.network.JmxNetworkProbe
 
NetworkInfo - Class in org.elasticsearch.monitor.network
 
NetworkInfo() - Constructor for class org.elasticsearch.monitor.network.NetworkInfo
 
networkInfo() - Method in interface org.elasticsearch.monitor.network.NetworkProbe
 
NetworkInfo.Interface - Class in org.elasticsearch.monitor.network
 
NetworkModule - Class in org.elasticsearch.common.network
 
NetworkModule() - Constructor for class org.elasticsearch.common.network.NetworkModule
 
NetworkProbe - Interface in org.elasticsearch.monitor.network
 
NetworkService - Class in org.elasticsearch.common.network
 
NetworkService(Settings) - Constructor for class org.elasticsearch.common.network.NetworkService
 
networkService - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
networkService() - Method in class org.elasticsearch.monitor.MonitorService
 
NetworkService - Class in org.elasticsearch.monitor.network
 
NetworkService(Settings, NetworkProbe) - Constructor for class org.elasticsearch.monitor.network.NetworkService
 
networkService - Variable in class org.elasticsearch.transport.netty.NettyTransport
 
NetworkService.CustomNameResolver - Interface in org.elasticsearch.common.network
A custom name resolver can support custom lookup keys (my_net_key:ipv4) and also change the default inet address used in case no settings is provided.
NetworkService.TcpSettings - Class in org.elasticsearch.common.network
 
networkStats() - Method in class org.elasticsearch.monitor.network.JmxNetworkProbe
 
networkStats() - Method in interface org.elasticsearch.monitor.network.NetworkProbe
 
NetworkStats - Class in org.elasticsearch.monitor.network
 
NetworkStats.Tcp - Class in org.elasticsearch.monitor.network
 
NetworkUtils - Class in org.elasticsearch.common.network
 
NetworkUtils.StackType - Enum in org.elasticsearch.common.network
 
newAddAliasAction(String, String) - Static method in class org.elasticsearch.cluster.metadata.AliasAction
 
newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.children.InternalChildren
 
newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
 
newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
 
newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
Create a new empty sub aggregation.
newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
 
newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
 
newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
 
newAggregation(String, List<InternalTerms.Bucket>, boolean, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
 
newAggregation(String, List<InternalTerms.Bucket>, boolean, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
newAggregation(String, List<InternalTerms.Bucket>, boolean, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
 
newAggregation(String, List<InternalTerms.Bucket>, boolean, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
 
newAggregation(String, List<InternalTerms.Bucket>, boolean, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
 
newAliasMetaData(AliasMetaData, String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData
Creates a new AliasMetaData instance with same content as the given one, but with a different alias name
newAliasMetaDataBuilder(String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
newBlockingQueue() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newBuilder() - Method in class org.elasticsearch.rest.RestChannel
 
newBuilder(BytesReference) - Method in class org.elasticsearch.rest.RestChannel
 
newByteArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new ByteArray.
newByteArray(long) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new ByteArray initialized with zeros.
newByteRange(IndexNumericFieldData, Byte, Byte, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newBytes(IndexFieldData, ObjectOpenHashSet<BytesRef>) - Static method in class org.elasticsearch.index.search.FieldDataTermsFilter
Get a FieldDataTermsFilter that filters on non-numeric terms found in a hppc ObjectOpenHashSet of BytesRef.
newBytesOutput() - Method in class org.elasticsearch.http.netty.NettyHttpChannel
 
newBytesOutput() - Method in class org.elasticsearch.rest.RestChannel
 
newCached(long, TimeUnit, ThreadFactory) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
newCircleBuilder() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
create a new Circle
newCollector(RandomAccessOrds) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.LowCardinality
 
newCollector(RandomAccessOrds) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
 
newCollector(RandomAccessOrds) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.WithHash
 
newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
 
newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
 
newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.FloatValuesComparatorSource
 
newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
 
newConcurrentMap() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newConcurrentMapLong() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newConcurrentMapLongWithAggressiveConcurrency() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
Creates a new CHM with an aggressive concurrency level, aimed at highly updateable long living maps.
newConcurrentMapWithAggressiveConcurrency() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
Creates a new CHM with an aggressive concurrency level, aimed at high concurrent update rate long living maps.
newConcurrentSet() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newCondition() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
 
newContentDecoder(String) - Method in class org.elasticsearch.http.netty.ESHttpContentDecompressor
 
newDefaultQuery(String) - Method in class org.elasticsearch.index.query.SimpleQueryParser
 
newDeque() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newDirectory(File) - Method in class org.elasticsearch.gateway.local.state.meta.MetaDataStateFormat
 
newDoubleArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new DoubleArray.
newDoubleArray(long) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new DoubleArray of the given capacity.
newDoubleRange(IndexNumericFieldData, Double, Double, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newDoubles(IndexNumericFieldData, DoubleOpenHashSet) - Static method in class org.elasticsearch.index.search.FieldDataTermsFilter
Get a FieldDataTermsFilter that filters on floating point numeric terms found in a hppc DoubleOpenHashSet.
newEngine() - Method in class org.elasticsearch.index.shard.IndexShard
 
newEngine() - Method in class org.elasticsearch.index.shard.ShadowIndexShard
 
newEntry() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
 
newEntry() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
 
newEntry() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
 
newEntry() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
 
newEnvelope() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
create a new rectangle
newEnvelope(ShapeBuilder.Orientation) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
create a new rectangle
newFactory(Class<F>, Class<?>) - Static method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider
 
newFactory(TypeLiteral<F>, TypeLiteral<?>) - Static method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider
 
newFilter(QueryParseContext, String, String) - Static method in class org.elasticsearch.index.query.ExistsFilterParser
 
newFilter(QueryParseContext, String, boolean, boolean, String) - Static method in class org.elasticsearch.index.query.MissingFilterParser
 
newFixed(int, int, ThreadFactory) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
newFloatArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new FloatArray.
newFloatArray(long) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new FloatArray of the given capacity.
newFloatRange(IndexNumericFieldData, Float, Float, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newFromDistributor(Distributor) - Method in class org.elasticsearch.index.store.DirectoryService
Creates a new Directory from the given distributor.
newFSDirectory(File, LockFactory) - Method in class org.elasticsearch.index.store.fs.DefaultFsDirectoryService
 
newFSDirectory(File, LockFactory) - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
newFSDirectory(File, LockFactory) - Method in class org.elasticsearch.index.store.fs.MmapFsDirectoryService
 
newFSDirectory(File, LockFactory) - Method in class org.elasticsearch.index.store.fs.NioFsDirectoryService
 
newFSDirectory(File, LockFactory) - Method in class org.elasticsearch.index.store.fs.SimpleFsDirectoryService
 
newFuture() - Static method in class org.elasticsearch.action.support.PlainActionFuture
 
newFuzzyQuery(Term, float, int) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
 
newFuzzyQuery(String, int) - Method in class org.elasticsearch.index.query.SimpleQueryParser
Dispatches to Lucene's SimpleQueryParser's newFuzzyQuery, optionally lowercasing the term first
newGeometryCollection() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new GeometryCollection
newGeometryCollection(ShapeBuilder.Orientation) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new GeometryCollection
newHeuristic(boolean, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare.ChiSquareParser
 
newHeuristic(boolean, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDParser
 
newHeuristic(boolean, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation.MutualInformationParser
 
newHeuristic(boolean, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYParser
 
newIndexRequestInstance(DeleteByQueryRequest, String, Set<String>, long) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
newIndexRequestInstance(Request, String, Set<String>, long) - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
newInstance(String) - Method in class org.elasticsearch.common.logging.ESLoggerFactory
 
newInstance(String, String) - Method in class org.elasticsearch.common.logging.ESLoggerFactory
 
newInstance(String, String) - Method in class org.elasticsearch.common.logging.jdk.JdkESLoggerFactory
 
newInstance(String, String) - Method in class org.elasticsearch.common.logging.log4j.Log4jESLoggerFactory
 
newInstance(String, String) - Method in class org.elasticsearch.common.logging.slf4j.Slf4jESLoggerFactory
 
newInstance(int) - Method in class org.elasticsearch.common.recycler.AbstractRecyclerC
 
newInstance(int) - Method in interface org.elasticsearch.common.recycler.Recycler.C
Create a new empty instance of the given size.
newInstance() - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
 
newInstance(String) - Method in class org.elasticsearch.transport.netty.NettyInternalESLoggerFactory
 
newInstance() - Method in class org.elasticsearch.transport.PlainTransportFuture
 
newInstance() - Method in interface org.elasticsearch.transport.TransportRequestHandler
 
newInstance() - Method in interface org.elasticsearch.transport.TransportResponseHandler
creates a new instance of the return type from the remote call.
newIntArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new IntArray.
newIntArray(long) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new IntArray.
newIntRange(IndexNumericFieldData, Integer, Integer, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newLineString() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new lineString
newLongArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new LongArray.
newLongArray(long) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new LongArray.
newLongRange(IndexNumericFieldData, Long, Long, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newLongs(IndexNumericFieldData, LongOpenHashSet) - Static method in class org.elasticsearch.index.search.FieldDataTermsFilter
Get a FieldDataTermsFilter that filters on non-floating point numeric terms found in a hppc LongOpenHashSet.
newMap(int) - Static method in class org.elasticsearch.common.collect.HppcMaps
Returns a new map with the given initial capacity
newMap() - Static method in class org.elasticsearch.common.collect.HppcMaps
Returns a new map with a default initial capacity of
newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
Returns a new mapbinder that collects entries of keyType/valueType in a Map that is itself bound with no binding annotation.
newMapBinder(Binder, Class<K>, Class<V>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
Returns a new mapbinder that collects entries of keyType/valueType in a Map that is itself bound with no binding annotation.
newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
Returns a new mapbinder that collects entries of keyType/valueType in a Map that is itself bound with annotation.
newMapBinder(Binder, Class<K>, Class<V>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
Returns a new mapbinder that collects entries of keyType/valueType in a Map that is itself bound with annotation.
newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
Returns a new mapbinder that collects entries of keyType/valueType in a Map that is itself bound with annotationType.
newMapBinder(Binder, Class<K>, Class<V>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
Returns a new mapbinder that collects entries of keyType/valueType in a Map that is itself bound with annotationType.
newMapBuilder() - Static method in class org.elasticsearch.common.collect.MapBuilder
 
newMapBuilder(Map<K, V>) - Static method in class org.elasticsearch.common.collect.MapBuilder
 
newMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
newMatchAllDocsQuery() - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
 
newMatchAllQuery() - Static method in class org.elasticsearch.common.lucene.search.Queries
 
newMatchNoDocsQuery() - Static method in class org.elasticsearch.common.lucene.search.Queries
Return a query that matches no document.
newMergeScheduler() - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
newMultiLinestring() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new Collection of lineStrings
newMultiPoint() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new set of points
newMultiPolygon() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new Collection of polygons
newMultiPolygon(ShapeBuilder.Orientation) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new Collection of polygons
newNested(boolean, boolean) - Static method in class org.elasticsearch.index.mapper.object.ObjectMapper.Nested
 
newNode(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
newNodeRequest() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
newNodeRequest(String, NodesHotThreadsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
newNodeRequest() - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
newNodeRequest(String, NodesInfoRequest) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
newNodeRequest() - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
newNodeRequest(String, NodesRestartRequest) - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
newNodeRequest() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
newNodeRequest(String, NodesStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
newNodeRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
 
newNodeRequest(String, TransportNodesSnapshotsStatus.Request) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
 
newNodeRequest() - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
 
newNodeRequest(String, ClusterStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
 
newNodeRequest() - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
newNodeRequest(String, Request) - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
newNodeRequest() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
newNodeRequest(String, TransportNodesListGatewayMetaState.Request) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
newNodeRequest() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
newNodeRequest(String, TransportNodesListGatewayStartedShards.Request) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
newNodeRequest() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
newNodeRequest(String, TransportNodesListShardStoreMetaData.Request) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
 
newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
 
newNodeResponse() - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
newNodeResponse() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
newNodeResponse() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
newNodeResponse() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
newNoNullKeysMap() - Static method in class org.elasticsearch.common.collect.HppcMaps
Returns a map like HppcMaps.newMap() that does not accept null keys
newNoNullKeysMap(int) - Static method in class org.elasticsearch.common.collect.HppcMaps
Returns a map like HppcMaps.newMap(int) that does not accept null keys
newObjectArray(long) - Method in class org.elasticsearch.common.util.BigArrays
Allocate a new ObjectArray.
newOption() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry
 
newOption() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
newOption() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry
 
newParameterizedType(Type, Type...) - Static method in class org.elasticsearch.common.inject.util.Types
Returns a new parameterized type, applying typeArguments to rawType.
newParameterizedTypeWithOwner(Type, Type, Type...) - Static method in class org.elasticsearch.common.inject.util.Types
Returns a new parameterized type, applying typeArguments to rawType and enclosed by ownerType.
newParent(long) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
newParent(long) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCollector
 
newParent(long) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCountCollector
 
newPhraseQuery(String, int) - Method in class org.elasticsearch.index.query.SimpleQueryParser
 
newPoint(double, double) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new point
newPoint(Coordinate) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new PointBuilder from a Coordinate
newPolygon() - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new Polygon
newPolygon(ShapeBuilder.Orientation) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new Polygon
newPrefixQuery(String) - Method in class org.elasticsearch.index.query.SimpleQueryParser
Dispatches to Lucene's SimpleQueryParser's newPrefixQuery, optionally lowercasing the term first or trying to analyze terms
newPrivateBinder() - Method in interface org.elasticsearch.common.inject.Binder
Creates a new private child environment for bindings and other configuration.
newQueue() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newReadOnlyEngine(EngineConfig) - Method in interface org.elasticsearch.index.engine.EngineFactory
 
newReadOnlyEngine(EngineConfig) - Method in class org.elasticsearch.index.engine.InternalEngineFactory
 
newReadWriteEngine(EngineConfig) - Method in interface org.elasticsearch.index.engine.EngineFactory
 
newReadWriteEngine(EngineConfig) - Method in class org.elasticsearch.index.engine.InternalEngineFactory
 
newRemoveAliasAction(String, String) - Static method in class org.elasticsearch.cluster.metadata.AliasAction
 
newReplicaRequestInstance() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
newReplicaRequestInstance() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
newReplicaRequestInstance() - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
newReplicaRequestInstance() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
newReplicaRequestInstance() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
newReplicaRequestInstance() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.warmer.get.TransportGetWarmersAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
 
newRequest() - Method in class org.elasticsearch.action.count.TransportCountAction
 
newRequest() - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
newRequest() - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
newRequest() - Method in class org.elasticsearch.action.get.TransportGetAction
 
newRequest() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
newRequest() - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
newRequest() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
 
newRequest() - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
 
newRequest() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
newRequest() - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
newRequest() - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
newRequest() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
newRequest() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
newRequest() - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
newRequest() - Method in class org.elasticsearch.action.termvector.TransportSingleShardMultiTermsVectorAction
 
newRequest() - Method in class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
newRequest() - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
newRequest() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
newRequest() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
newRequest() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
newRequest() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.Action
Creates a new request builder given the client provided as argument
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.flush.FlushAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusAction
Deprecated.
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.bulk.BulkAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.count.CountAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.delete.DeleteAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.exists.ExistsAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.explain.ExplainAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.get.GetAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.get.MultiGetAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.index.IndexAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.mlt.MoreLikeThisAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.percolate.MultiPercolateAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.percolate.PercolateAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.search.ClearScrollAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.search.MultiSearchAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.search.SearchAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.search.SearchScrollAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.suggest.SuggestAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.termvector.TermVectorAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.update.UpdateAction
 
newRequestInstance() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsAction
 
newRequestInstance() - Method in class org.elasticsearch.action.bulk.TransportBulkAction
 
newRequestInstance() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
newRequestInstance() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
newRequestInstance() - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
newRequestInstance() - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
newRequestInstance() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
newRequestInstance() - Method in class org.elasticsearch.action.get.TransportMultiGetAction
 
newRequestInstance() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
newRequestInstance() - Method in class org.elasticsearch.action.indexedscripts.delete.TransportDeleteIndexedScriptAction
 
newRequestInstance() - Method in class org.elasticsearch.action.indexedscripts.get.TransportGetIndexedScriptAction
 
newRequestInstance() - Method in class org.elasticsearch.action.indexedscripts.put.TransportPutIndexedScriptAction
 
newRequestInstance() - Method in class org.elasticsearch.action.mlt.TransportMoreLikeThisAction
 
newRequestInstance() - Method in class org.elasticsearch.action.percolate.TransportMultiPercolateAction
 
newRequestInstance() - Method in class org.elasticsearch.action.search.TransportClearScrollAction
 
newRequestInstance() - Method in class org.elasticsearch.action.search.TransportMultiSearchAction
 
newRequestInstance() - Method in class org.elasticsearch.action.search.TransportSearchAction
 
newRequestInstance() - Method in class org.elasticsearch.action.search.TransportSearchScrollAction
 
newRequestInstance() - Method in class org.elasticsearch.action.support.HandledTransportAction
Sub classes implement this call to get new instance of a Request object
newRequestInstance() - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
newRequestInstance() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
newRequestInstance() - Method in class org.elasticsearch.action.termvector.TransportMultiTermVectorsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
 
newResponse(NodesHotThreadsRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
 
newResponse(NodesInfoRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartAction
 
newResponse(NodesRestartRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
 
newResponse(NodesStatsRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
 
newResponse(TransportNodesSnapshotsStatus.Request, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
 
newResponse(ClusterStatsRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
 
newResponse(ClearIndicesCacheRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.flush.FlushAction
 
newResponse(FlushRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeAction
 
newResponse(OptimizeRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
 
newResponse(RecoveryRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
 
newResponse(RefreshRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
 
newResponse(IndicesSegmentsRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
 
newResponse(IndicesStatsRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusAction
Deprecated.
 
newResponse(IndicesStatusRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
 
newResponse(ValidateQueryRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.warmer.get.TransportGetWarmersAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
 
newResponse() - Method in class org.elasticsearch.action.bulk.BulkAction
 
newResponse() - Method in class org.elasticsearch.action.count.CountAction
 
newResponse(CountRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.count.TransportCountAction
 
newResponse() - Method in class org.elasticsearch.action.delete.DeleteAction
 
newResponse() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryAction
 
newResponse() - Method in class org.elasticsearch.action.exists.ExistsAction
 
newResponse(ExistsRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
newResponse() - Method in class org.elasticsearch.action.explain.ExplainAction
 
newResponse() - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
newResponse() - Method in class org.elasticsearch.action.GenericAction
Creates a new response instance.
newResponse() - Method in class org.elasticsearch.action.get.GetAction
 
newResponse() - Method in class org.elasticsearch.action.get.MultiGetAction
 
newResponse() - Method in class org.elasticsearch.action.get.TransportGetAction
 
newResponse() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
newResponse() - Method in class org.elasticsearch.action.index.IndexAction
 
newResponse() - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptAction
 
newResponse() - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptAction
 
newResponse() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptAction
 
newResponse() - Method in class org.elasticsearch.action.mlt.MoreLikeThisAction
 
newResponse() - Method in class org.elasticsearch.action.percolate.MultiPercolateAction
 
newResponse() - Method in class org.elasticsearch.action.percolate.PercolateAction
 
newResponse(PercolateRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
newResponse() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
 
newResponse() - Method in class org.elasticsearch.action.search.ClearScrollAction
 
newResponse() - Method in class org.elasticsearch.action.search.MultiSearchAction
 
newResponse() - Method in class org.elasticsearch.action.search.SearchAction
 
newResponse() - Method in class org.elasticsearch.action.search.SearchScrollAction
 
newResponse() - Method in class org.elasticsearch.action.suggest.SuggestAction
 
newResponse(SuggestRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
 
newResponse(Request, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
newResponse() - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
newResponse(Request, AtomicReferenceArray) - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
newResponse() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
newResponse() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
newResponse() - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
newResponse() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsAction
 
newResponse() - Method in class org.elasticsearch.action.termvector.TermVectorAction
 
newResponse() - Method in class org.elasticsearch.action.termvector.TransportSingleShardMultiTermsVectorAction
 
newResponse() - Method in class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
newResponse() - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
newResponse() - Method in class org.elasticsearch.action.update.UpdateAction
 
newResponse(boolean) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
 
newResponse() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
newResponse(TransportNodesListGatewayMetaState.Request, AtomicReferenceArray) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
newResponse(TransportNodesListGatewayStartedShards.Request, AtomicReferenceArray) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
newResponse(TransportNodesListShardStoreMetaData.Request, AtomicReferenceArray) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
newResponseInstance() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
newResponseInstance() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
newResponseInstance(IndexDeleteRequest, List<ShardDeleteResponse>, int, List<ShardOperationFailedException>) - Method in class org.elasticsearch.action.delete.TransportIndexDeleteAction
 
newResponseInstance() - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
newResponseInstance(DeleteByQueryRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
newResponseInstance(IndexDeleteByQueryRequest, List<ShardDeleteByQueryResponse>, int, List<ShardOperationFailedException>) - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
newResponseInstance() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
newResponseInstance() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
newResponseInstance(Request, List<ShardResponse>, int, List<ShardOperationFailedException>) - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
newResponseInstance(Request, AtomicReferenceArray) - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
newResponseInstance() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
newScaling(int, int, long, TimeUnit, ThreadFactory) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
newScorer(IndexReader, Terms, String, double, BytesRef) - Method in interface org.elasticsearch.search.suggest.phrase.WordScorer.WordScorerFactory
 
newScript(Map<String, Object>) - Method in interface org.elasticsearch.script.NativeScriptFactory
Creates a new instance of either a ExecutableScript or a SearchScript.
newSearcher(String, IndexSearcher, SearcherManager) - Method in class org.elasticsearch.index.engine.Engine
 
newSearcher(IndexReader) - Method in class org.elasticsearch.index.engine.EngineSearcherFactory
 
newSetBinder(Binder, TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
Returns a new multibinder that collects instances of type in a Set that is itself bound with no binding annotation.
newSetBinder(Binder, Class<T>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
Returns a new multibinder that collects instances of type in a Set that is itself bound with no binding annotation.
newSetBinder(Binder, TypeLiteral<T>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
Returns a new multibinder that collects instances of type in a Set that is itself bound with annotation.
newSetBinder(Binder, Class<T>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
Returns a new multibinder that collects instances of type in a Set that is itself bound with annotation.
newSetBinder(Binder, TypeLiteral<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
Returns a new multibinder that collects instances of type in a Set that is itself bound with annotationType.
newSetBinder(Binder, Class<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
Returns a new multibinder that collects instances of type in a Set that is itself bound with annotationType.
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
newShardRequest(int, ShardRouting, ClearIndicesCacheRequest) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newShardRequest(int, ShardRouting, FlushRequest) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newShardRequest(int, ShardRouting, OptimizeRequest) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
newShardRequest(int, ShardRouting, RecoveryRequest) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newShardRequest(int, ShardRouting, RefreshRequest) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
newShardRequest(int, ShardRouting, IndicesSegmentsRequest) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
newShardRequest(int, ShardRouting, IndicesStatsRequest) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
newShardRequest(int, ShardRouting, IndicesStatusRequest) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
newShardRequest(int, ShardRouting, ValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
newShardRequest() - Method in class org.elasticsearch.action.count.TransportCountAction
 
newShardRequest(int, ShardRouting, CountRequest) - Method in class org.elasticsearch.action.count.TransportCountAction
 
newShardRequest() - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
newShardRequest(int, ShardRouting, ExistsRequest) - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
newShardRequest() - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
newShardRequest(int, ShardRouting, PercolateRequest) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
newShardRequest() - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
 
newShardRequest(int, ShardRouting, SuggestRequest) - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
 
newShardRequest() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
newShardRequest(int, ShardRouting, Request) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
newShardRequestInstance(IndexDeleteRequest, int) - Method in class org.elasticsearch.action.delete.TransportIndexDeleteAction
 
newShardRequestInstance(IndexDeleteByQueryRequest, int) - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
newShardRequestInstance(Request, int) - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
newShardResponse() - Method in class org.elasticsearch.action.count.TransportCountAction
 
newShardResponse() - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
newShardResponse() - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
newShardResponse() - Method in class org.elasticsearch.action.suggest.TransportSuggestAction
 
newShardResponse() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
newShortRange(IndexNumericFieldData, Short, Short, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newSinglePrioritizing(ThreadFactory) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
newTaskFor(Runnable, T) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
 
newTaskFor(Callable<T>) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
 
newTermExtractor(String) - Method in class org.elasticsearch.search.highlight.CustomQueryScorer
 
newTermQuery(Term, TermContext) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
 
newTermQuery(Term) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
 
newTransientTranslog(long) - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
newTransientTranslog(long) - Method in interface org.elasticsearch.index.translog.Translog
Creates a new transient translog, where added ops will be added to the current one, and to it.
newTranslog(long) - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
newTranslog(long) - Method in interface org.elasticsearch.index.translog.Translog
Creates a new transaction log internally.
newXContentBuilder(XContentType, OutputStream) - Method in class org.elasticsearch.gateway.local.state.meta.MetaDataStateFormat
 
next() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodeIterator
 
next() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodesIterator
 
next() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
next() - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
Proxy to the original next() call, but estimates the overhead of loading the next term.
next() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
next() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
Returns the next operation, or null when no more operations are found
next() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentileRanks.Iter
 
next() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles.Iter
 
next() - Method in interface org.elasticsearch.search.facet.terms.strings.HashedAggregator.BytesRefCountIterator
 
next() - Method in class org.elasticsearch.search.lookup.CachedPositionIterator
 
next() - Method in class org.elasticsearch.search.lookup.PositionIterator
 
nextAfter(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
nextAfter(Float, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
nextDoc() - Method in class org.elasticsearch.common.lucene.docset.AllDocIdSet.Iterator
 
nextDoc() - Method in class org.elasticsearch.common.lucene.docset.MatchDocIdSetIterator
 
nextDoc() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.IteratorBasedIterator
 
nextDoc() - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
nextDoc() - Method in class org.elasticsearch.index.search.child.ConstantScorer
 
nextDoc() - Method in class org.elasticsearch.search.lookup.CachedPositionIterator
 
nextDoc() - Method in class org.elasticsearch.search.lookup.PositionIterator
 
nextLevel(ObjectMapper) - Method in class org.elasticsearch.index.query.support.NestedScope
Sets the new current nested level and pushes old current nested level down the stack returns that level.
nextOrd() - Method in class org.elasticsearch.index.fielddata.AbstractRandomAccessOrds
 
nextOrdinal() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
Advances the OrdinalsBuilder to the next ordinal and return the current ordinal.
nextOrNull() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
nextOrNull() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
Returns the next shard, or null if none available.
nextPosition() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor.ReaderAggregator
 
nextPossibleMasters(ObjectContainer<DiscoveryNode>, int) - Method in class org.elasticsearch.discovery.zen.elect.ElectMasterService
Returns a list of the next possible masters.
nextRoundingValue(long) - Method in class org.elasticsearch.common.rounding.Rounding.FactorRounding
 
nextRoundingValue(long) - Method in class org.elasticsearch.common.rounding.Rounding.Interval
 
nextRoundingValue(long) - Method in class org.elasticsearch.common.rounding.Rounding
Given the rounded value (which was potentially generated by Rounding.round(long), returns the next rounding value.
nextRoundingValue(long) - Method in class org.elasticsearch.common.rounding.Rounding.PrePostRounding
 
nextSeed() - Method in class org.elasticsearch.cluster.routing.RotationShardShuffler
 
nextSeed() - Method in class org.elasticsearch.cluster.routing.ShardShuffler
Return a new seed.
nextToken() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
nextToken() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
nextToken() - Method in class org.elasticsearch.search.suggest.SuggestUtils.TokenConsumer
 
nextUp(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
nextUp(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
NGramTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
NGramTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.NGramTokenFilterFactory
 
NGramTokenizerFactory - Class in org.elasticsearch.index.analysis
 
NGramTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.NGramTokenizerFactory
 
NioFsDirectoryService - Class in org.elasticsearch.index.store.fs
 
NioFsDirectoryService(ShardId, Settings, IndexStore) - Constructor for class org.elasticsearch.index.store.fs.NioFsDirectoryService
 
NioFsIndexStore - Class in org.elasticsearch.index.store.fs
 
NioFsIndexStore(Index, Settings, IndexService, IndicesStore, NodeEnvironment) - Constructor for class org.elasticsearch.index.store.fs.NioFsIndexStore
 
NioFsIndexStoreModule - Class in org.elasticsearch.index.store.fs
 
NioFsIndexStoreModule() - Constructor for class org.elasticsearch.index.store.fs.NioFsIndexStoreModule
 
NO - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
 
NO - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Nested
 
NO_DECODER - Static variable in class org.elasticsearch.common.path.PathTrie
 
NO_MASTER_BLOCK - Static variable in class org.elasticsearch.discovery.DiscoverySettings
 
NO_MASTER_BLOCK_ALL - Static variable in class org.elasticsearch.discovery.DiscoverySettings
 
NO_MASTER_BLOCK_ID - Static variable in class org.elasticsearch.discovery.DiscoverySettings
 
NO_MASTER_BLOCK_WRITES - Static variable in class org.elasticsearch.discovery.DiscoverySettings
 
NO_NORMALIZATION - Static variable in class org.elasticsearch.index.similarity.AbstractSimilarityProvider
 
NO_OP_COLLECTOR - Static variable in class org.elasticsearch.search.aggregations.BucketCollector
 
NO_SCOPE - Static variable in class org.elasticsearch.common.inject.Scopes
No scope; the same as not applying any scope at all.
NO_SCORE - Static variable in class org.elasticsearch.percolator.PercolatorService
 
NO_VALUES - Static variable in class org.elasticsearch.index.fielddata.ordinals.Ordinals
 
NO_WAIT - Static variable in interface org.elasticsearch.indices.IndicesWarmer.TerminationHandle
 
NoCacheFilter - Class in org.elasticsearch.common.lucene.search
A marker interface for Filter denoting the filter as one that should not be cached, ever.
NoCacheFilter() - Constructor for class org.elasticsearch.common.lucene.search.NoCacheFilter
 
NoCacheQuery - Class in org.elasticsearch.common.lucene.search
Queries are never cached directly, but a query can be wrapped in a filter that may end being cached.
NoCacheQuery() - Constructor for class org.elasticsearch.common.lucene.search.NoCacheQuery
 
noCFSRatio - Variable in class org.elasticsearch.index.merge.policy.AbstractMergePolicyProvider
 
NoClassSettingsException - Exception in org.elasticsearch.common.settings
A specific type of SettingsException indicating failure to load a class based on a settings value.
NoClassSettingsException(String) - Constructor for exception org.elasticsearch.common.settings.NoClassSettingsException
 
NoClassSettingsException(String, Throwable) - Constructor for exception org.elasticsearch.common.settings.NoClassSettingsException
 
node() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation.NodeExplanation
The node referenced by the explanation
node() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand
Get the id of the Node
node() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
Get the id of the node that manages the shard which allocation should be canceled
node() - Method in class org.elasticsearch.cluster.routing.RoutingNode
Returns the nodes DiscoveryNode.
node(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
node() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
the node which this ping describes
Node - Interface in org.elasticsearch.node
A node represent a node within a cluster (cluster.name).
node() - Method in class org.elasticsearch.node.NodeBuilder
NodeBuilder.build()s and starts the node.
node() - Method in class org.elasticsearch.river.routing.RiverRouting
The node the river is allocated to, null if its not allocated.
node() - Method in exception org.elasticsearch.transport.ConnectTransportException
 
NODE_LOCK_FILENAME - Static variable in class org.elasticsearch.env.NodeEnvironment
 
NodeAdminClient - Class in org.elasticsearch.client.node
 
NodeAdminClient(Settings, NodeClusterAdminClient, NodeIndicesAdminClient) - Constructor for class org.elasticsearch.client.node.NodeAdminClient
 
nodeBooleanValue(Object, boolean) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeBooleanValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
NodeBuilder - Class in org.elasticsearch.node
A node builder is used to construct a Node instance.
NodeBuilder() - Constructor for class org.elasticsearch.node.NodeBuilder
 
nodeBuilder() - Static method in class org.elasticsearch.node.NodeBuilder
A convenient factory method to create a NodeBuilder.
nodeByteValue(Object, byte) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeByteValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeChannel(DiscoveryNode, TransportRequestOptions) - Method in class org.elasticsearch.transport.netty.NettyTransport
 
NodeChannels(Channel[], Channel[], Channel[], Channel[], Channel[]) - Constructor for class org.elasticsearch.transport.netty.NettyTransport.NodeChannels
 
NodeClient - Class in org.elasticsearch.client.node
 
NodeClient(Settings, ThreadPool, NodeAdminClient, Map<GenericAction, TransportAction>, Headers) - Constructor for class org.elasticsearch.client.node.NodeClient
 
NodeClientModule - Class in org.elasticsearch.client.node
 
NodeClientModule() - Constructor for class org.elasticsearch.client.node.NodeClientModule
 
NodeClosedException - Exception in org.elasticsearch.node
An exception indicating that node is closed.
NodeClosedException(DiscoveryNode) - Constructor for exception org.elasticsearch.node.NodeClosedException
 
NodeClusterAdminClient - Class in org.elasticsearch.client.node
 
NodeClusterAdminClient(ThreadPool, Map<GenericAction, TransportAction>, Headers) - Constructor for class org.elasticsearch.client.node.NodeClusterAdminClient
 
nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.local.LocalTransport
 
nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.netty.NettyTransport
 
nodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.Transport
Returns true if the node is connected.
nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
 
nodeDataLocations() - Method in class org.elasticsearch.env.NodeEnvironment
Deprecated.
nodeDataPaths() - Method in class org.elasticsearch.env.NodeEnvironment
Returns an array of all of the nodes data locations.
nodeDescription() - Method in interface org.elasticsearch.discovery.Discovery
 
nodeDescription() - Method in class org.elasticsearch.discovery.DiscoveryService
 
nodeDescription() - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
nodeDescription() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
NodeDisconnectedException - Exception in org.elasticsearch.transport
 
NodeDisconnectedException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.NodeDisconnectedException
 
nodeDoubleValue(Object, double) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeDoubleValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
NodeEnvironment - Class in org.elasticsearch.env
A component that holds all data paths for a single node.
NodeEnvironment(Settings, Environment) - Constructor for class org.elasticsearch.env.NodeEnvironment
 
NodeEnvironmentModule - Class in org.elasticsearch.env
 
NodeEnvironmentModule() - Constructor for class org.elasticsearch.env.NodeEnvironmentModule
 
NodeEnvironmentModule(NodeEnvironment) - Constructor for class org.elasticsearch.env.NodeEnvironmentModule
 
nodeExists(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Determine if a given node exists
NodeExplanation(DiscoveryNode, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationExplanation.NodeExplanation
nodeFloatValue(Object, float) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeFloatValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeHasJoinedClusterOnce() - Method in interface org.elasticsearch.discovery.zen.ping.PingContextProvider
return true if this node has previously joined the cluster at least once.
nodeHasJoinedClusterOnce() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
NodeHotThreads - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
 
NodeHotThreads(DiscoveryNode, String) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
 
nodeId() - Method in exception org.elasticsearch.action.FailedNodeException
 
nodeId() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
Returns null for not set.
nodeId() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
nodeId() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
Returns node id of the node where shared is getting restored
nodeId() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
nodeId() - Method in class org.elasticsearch.cluster.routing.RoutingNode
Get the id of this node
nodeId() - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.PingRequest
 
nodeId() - Method in class org.elasticsearch.repositories.VerificationFailure
 
nodeId() - Method in class org.elasticsearch.search.SearchShardTarget
 
nodeId() - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
Returns node id where failure occurred
nodeIdText() - Method in class org.elasticsearch.search.SearchShardTarget
 
nodeIndexDeleted(ClusterState, String, Settings, String) - Method in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
 
NodeIndexDeletedAction - Class in org.elasticsearch.cluster.action.index
 
NodeIndexDeletedAction(Settings, ThreadPool, TransportService, NodeEnvironment, IndicesService) - Constructor for class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
 
NodeIndexDeletedAction.Listener - Interface in org.elasticsearch.cluster.action.index
 
NodeIndicesAdminClient - Class in org.elasticsearch.client.node
 
NodeIndicesAdminClient(ThreadPool, Map<GenericAction, TransportAction>, Headers) - Constructor for class org.elasticsearch.client.node.NodeIndicesAdminClient
 
NodeIndicesStats - Class in org.elasticsearch.indices
Global information on indices stats running on a specific node.
NodeIndicesStats(CommonStats, Map<Index, List<IndexShardStats>>) - Constructor for class org.elasticsearch.indices.NodeIndicesStats
 
NodeInfo - Class in org.elasticsearch.action.admin.cluster.node.info
Node information (static, does not change over time).
NodeInfo(Version, Build, DiscoveryNode, ImmutableMap<String, String>, Settings, OsInfo, ProcessInfo, JvmInfo, ThreadPoolInfo, NetworkInfo, TransportInfo, HttpInfo, PluginsInfo) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
 
nodeInfo() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
 
nodeIntegerValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeIntegerValue(Object, int) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
NodeLocalGatewayMetaState(DiscoveryNode, MetaData) - Constructor for class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState
 
NodeLocalGatewayStartedShards(DiscoveryNode, long) - Constructor for class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards
 
nodeLongValue(Object, long) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeLongValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeMappingRefresh(ClusterState, NodeMappingRefreshAction.NodeMappingRefreshRequest) - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
 
NodeMappingRefreshAction - Class in org.elasticsearch.cluster.action.index
 
NodeMappingRefreshAction(Settings, TransportService, MetaDataMappingService) - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
 
NodeMappingRefreshAction.NodeMappingRefreshRequest - Class in org.elasticsearch.cluster.action.index
 
NodeMappingRefreshRequest(String, String, String[], String) - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
nodeMapValue(Object, String) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
NodeModule - Class in org.elasticsearch.node.internal
 
NodeModule(Node) - Constructor for class org.elasticsearch.node.internal.NodeModule
 
nodeName() - Method in class org.elasticsearch.common.component.AbstractComponent
 
nodeName() - Method in class org.elasticsearch.index.AbstractIndexComponent
 
nodeName() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
nodeName() - Method in class org.elasticsearch.river.AbstractRiverComponent
 
NodeNotConnectedException - Exception in org.elasticsearch.transport
An exception indicating that a message is sent to a node that is not connected.
NodeNotConnectedException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.NodeNotConnectedException
 
NodeNotConnectedException(DiscoveryNode, String, Throwable) - Constructor for exception org.elasticsearch.transport.NodeNotConnectedException
 
nodeOperation(TransportNodesHotThreadsAction.NodeRequest) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
nodeOperation(TransportNodesInfoAction.NodeInfoRequest) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
nodeOperation(TransportNodesRestartAction.NodeRestartRequest) - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
nodeOperation(TransportNodesStatsAction.NodeStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
nodeOperation(TransportNodesSnapshotsStatus.NodeRequest) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
 
nodeOperation(TransportClusterStatsAction.ClusterStatsNodeRequest) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
 
nodeOperation(NodeRequest) - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
nodeOperation(TransportNodesListGatewayMetaState.NodeRequest) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
nodeOperation(TransportNodesListGatewayStartedShards.NodeRequest) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
nodeOperation(TransportNodesListShardStoreMetaData.NodeRequest) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
NodeOperationRequest - Class in org.elasticsearch.action.support.nodes
 
NodeOperationRequest() - Constructor for class org.elasticsearch.action.support.nodes.NodeOperationRequest
 
NodeOperationRequest(NodesOperationRequest, String) - Constructor for class org.elasticsearch.action.support.nodes.NodeOperationRequest
 
NodeOperationResponse - Class in org.elasticsearch.action.support.nodes
A base class for node level operations.
NodeOperationResponse() - Constructor for class org.elasticsearch.action.support.nodes.NodeOperationResponse
 
NodeOperationResponse(DiscoveryNode) - Constructor for class org.elasticsearch.action.support.nodes.NodeOperationResponse
 
nodeRequiresLocalStorage(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
 
NodeRestartResponse(DiscoveryNode) - Constructor for class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartResponse.NodeRestartResponse
 
nodes() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
nodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
nodes - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
nodes - Variable in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
nodes(DiscoveryNodes.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
nodes(DiscoveryNodes) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
nodes() - Method in class org.elasticsearch.cluster.ClusterState
 
nodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Get a Map of the discovered nodes arranged by their ids
nodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
Get discovery nodes in current routing
nodes() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
nodes() - Method in interface org.elasticsearch.discovery.zen.DiscoveryNodesProvider
 
nodes() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
start of PingContextProvider implementation
nodes() - Method in class org.elasticsearch.repositories.RepositoriesService.VerifyResponse
 
NODES_FOLDER - Static variable in class org.elasticsearch.env.NodeEnvironment
 
nodesAdded() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
nodesChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
nodesDelta() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
nodeService() - Method in interface org.elasticsearch.discovery.zen.DiscoveryNodesProvider
 
nodeService() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
NodeService - Class in org.elasticsearch.node.service
 
NodeService(Settings, ThreadPool, MonitorService, Discovery, TransportService, IndicesService, PluginsService, CircuitBreakerService, Version) - Constructor for class org.elasticsearch.node.service.NodeService
 
NodeSettingsService - Class in org.elasticsearch.node.settings
A service that allows to register for node settings change that can come from cluster events holding new settings.
NodeSettingsService(Settings) - Constructor for class org.elasticsearch.node.settings.NodeSettingsService
 
NodeSettingsService.Listener - Interface in org.elasticsearch.node.settings
 
NodesFaultDetection - Class in org.elasticsearch.discovery.zen.fd
A fault detection of multiple nodes.
NodesFaultDetection(Settings, ThreadPool, TransportService, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
 
NodesFaultDetection.Listener - Class in org.elasticsearch.discovery.zen.fd
 
NodesFaultDetection.PingRequest - Class in org.elasticsearch.discovery.zen.fd
 
nodeShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.RoutingNodesIterator
 
nodeShortValue(Object, short) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeShortValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodesHotThreads(NodesHotThreadsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Returns top N hot-threads samples per node.
nodesHotThreads(NodesHotThreadsRequest, ActionListener<NodesHotThreadsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Returns top N hot-threads samples per node.
nodesHotThreads(NodesHotThreadsRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
nodesHotThreads(NodesHotThreadsRequest, ActionListener<NodesHotThreadsResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
NodesHotThreadsAction - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
 
NodesHotThreadsRequest - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
 
NodesHotThreadsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
Get hot threads from nodes based on the nodes ids specified.
NodesHotThreadsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
 
NodesHotThreadsRequestBuilder(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
 
NodesHotThreadsResponse - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
 
NodesHotThreadsResponse(ClusterName, NodeHotThreads[]) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
 
NodeShouldNotConnectException - Exception in org.elasticsearch.transport
 
NodeShouldNotConnectException(DiscoveryNode, DiscoveryNode) - Constructor for exception org.elasticsearch.transport.NodeShouldNotConnectException
 
nodesIds(String...) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
 
nodesIds() - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
nodesIds(String...) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
nodesInfo(NodesInfoRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Nodes info of the cluster.
nodesInfo(NodesInfoRequest, ActionListener<NodesInfoResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Nodes info of the cluster.
nodesInfo(NodesInfoRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
nodesInfo(NodesInfoRequest, ActionListener<NodesInfoResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
NodesInfoAction - Class in org.elasticsearch.action.admin.cluster.node.info
 
NodesInfoRequest - Class in org.elasticsearch.action.admin.cluster.node.info
A request to get node (cluster) level information.
NodesInfoRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
 
NodesInfoRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Get information from nodes based on the nodes ids specified.
nodesInfoRequest() - Static method in class org.elasticsearch.client.Requests
Creates a nodes info request against all the nodes.
nodesInfoRequest(String...) - Static method in class org.elasticsearch.client.Requests
Creates a nodes info request against one or more nodes.
NodesInfoRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.info
 
NodesInfoRequestBuilder(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
 
NodesInfoResponse - Class in org.elasticsearch.action.admin.cluster.node.info
 
NodesInfoResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
 
NodesInfoResponse(ClusterName, NodeInfo[]) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
 
NodesLocalGatewayMetaState(ClusterName, TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState[], FailedNodeException[]) - Constructor for class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState
 
NodesLocalGatewayStartedShards(ClusterName, TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards[], FailedNodeException[]) - Constructor for class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards
 
NodeSnapshotStatus(DiscoveryNode, ImmutableMap<SnapshotId, ImmutableMap<ShardId, SnapshotIndexShardStatus>>) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
 
NodesOperationRequest<T extends NodesOperationRequest> - Class in org.elasticsearch.action.support.nodes
 
NodesOperationRequest() - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
NodesOperationRequest(ActionRequest, String...) - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
NodesOperationRequest(String...) - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
NodesOperationRequestBuilder<Request extends NodesOperationRequest<Request>,Response extends NodesOperationResponse,RequestBuilder extends NodesOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.nodes
 
NodesOperationRequestBuilder(ClusterAdminClient, Request) - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
 
NodesOperationResponse<NodeResponse extends NodeOperationResponse> - Class in org.elasticsearch.action.support.nodes
 
NodesOperationResponse() - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
NodesOperationResponse(ClusterName, NodeResponse[]) - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
nodesPerAttributesCounts(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
nodesRemoved() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
nodesRestart(NodesRestartRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Restarts nodes in the cluster.
nodesRestart(NodesRestartRequest, ActionListener<NodesRestartResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Restarts nodes in the cluster.
nodesRestart(NodesRestartRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
nodesRestart(NodesRestartRequest, ActionListener<NodesRestartResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
NodesRestartAction - Class in org.elasticsearch.action.admin.cluster.node.restart
 
NodesRestartRequest - Class in org.elasticsearch.action.admin.cluster.node.restart
A request to restart one ore more nodes (or the whole cluster).
NodesRestartRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequest
 
NodesRestartRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequest
Restarts down nodes based on the nodes ids specified.
nodesRestartRequest() - Static method in class org.elasticsearch.client.Requests
Restarts all nodes in the cluster.
nodesRestartRequest(String...) - Static method in class org.elasticsearch.client.Requests
Restarts specific nodes in the cluster.
NodesRestartRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.restart
 
NodesRestartRequestBuilder(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequestBuilder
 
NodesRestartResponse - Class in org.elasticsearch.action.admin.cluster.node.restart
 
NodesRestartResponse(ClusterName, NodesRestartResponse.NodeRestartResponse[]) - Constructor for class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartResponse
 
NodesRestartResponse.NodeRestartResponse - Class in org.elasticsearch.action.admin.cluster.node.restart
 
nodesShutdown(NodesShutdownRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Shutdown nodes in the cluster.
nodesShutdown(NodesShutdownRequest, ActionListener<NodesShutdownResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Shutdown nodes in the cluster.
nodesShutdown(NodesShutdownRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
nodesShutdown(NodesShutdownRequest, ActionListener<NodesShutdownResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
NodesShutdownAction - Class in org.elasticsearch.action.admin.cluster.node.shutdown
 
NodesShutdownRequest - Class in org.elasticsearch.action.admin.cluster.node.shutdown
 
NodesShutdownRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
 
nodesShutdownRequest() - Static method in class org.elasticsearch.client.Requests
Shuts down all nodes in the cluster.
nodesShutdownRequest(String...) - Static method in class org.elasticsearch.client.Requests
Shuts down the specified nodes in the cluster.
NodesShutdownRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.shutdown
 
NodesShutdownRequestBuilder(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequestBuilder
 
NodesShutdownResponse - Class in org.elasticsearch.action.admin.cluster.node.shutdown
 
NodesShutdownResponse(ClusterName, DiscoveryNode[]) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse
 
NodesSnapshotStatus(ClusterName, TransportNodesSnapshotsStatus.NodeSnapshotStatus[], FailedNodeException[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
 
nodesStats(NodesStatsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Nodes stats of the cluster.
nodesStats(NodesStatsRequest, ActionListener<NodesStatsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Nodes stats of the cluster.
nodesStats(NodesStatsRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
nodesStats(NodesStatsRequest, ActionListener<NodesStatsResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
NodesStatsAction - Class in org.elasticsearch.action.admin.cluster.node.stats
 
NodesStatsRequest - Class in org.elasticsearch.action.admin.cluster.node.stats
A request to get node (cluster) level stats.
NodesStatsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
 
NodesStatsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Get stats from nodes based on the nodes ids specified.
nodesStatsRequest(String...) - Static method in class org.elasticsearch.client.Requests
Creates a nodes stats request against one or more nodes.
NodesStatsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.stats
 
NodesStatsRequestBuilder(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
 
NodesStatsResponse - Class in org.elasticsearch.action.admin.cluster.node.stats
 
NodesStatsResponse(ClusterName, NodeStats[]) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
 
NodesStoreFilesMetaData(ClusterName, TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData[], FailedNodeException[]) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
 
NodeStats - Class in org.elasticsearch.action.admin.cluster.node.stats
Node statistics (dynamic, changes depending on when created).
NodeStats(DiscoveryNode, long, NodeIndicesStats, OsStats, ProcessStats, JvmStats, ThreadPoolStats, NetworkStats, FsStats, TransportStats, HttpStats, AllCircuitBreakerStats) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
nodeStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
 
NodeStoreFilesMetaData(DiscoveryNode, TransportNodesListShardStoreMetaData.StoreFilesMetaData) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
 
nodeStringValue(Object, String) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeTimeValue(Object, TimeValue) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
nodeTimeValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
NodeVersionAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
An allocation decider that prevents relocation or allocation from nodes that might not be version compatible.
NodeVersionAllocationDecider(Settings, RecoverySettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.NodeVersionAllocationDecider
 
noDynamicDateTimeFormatter() - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
 
noFields() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Sets no fields to be loaded, resulting in only id and type to be returned per field.
NoisyChannelSpellChecker - Class in org.elasticsearch.search.suggest.phrase
 
NoisyChannelSpellChecker() - Constructor for class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
 
NoisyChannelSpellChecker(double) - Constructor for class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
 
NoisyChannelSpellChecker(double, boolean, int) - Constructor for class org.elasticsearch.search.suggest.phrase.NoisyChannelSpellChecker
 
NoisyChannelSpellChecker.Result - Class in org.elasticsearch.search.suggest.phrase
 
noMatchFilter(String) - Method in class org.elasticsearch.index.query.IndicesFilterBuilder
Sets the no match filter, can either be all or none.
noMatchFilter(FilterBuilder) - Method in class org.elasticsearch.index.query.IndicesFilterBuilder
Sets the filter to use when it executes on an index that does not match the indices provided.
noMatchQuery(String) - Method in class org.elasticsearch.index.query.IndicesQueryBuilder
Sets the no match query, can either be all or none.
noMatchQuery(QueryBuilder) - Method in class org.elasticsearch.index.query.IndicesQueryBuilder
Sets the query to use when it executes on an index that does not match the indices provided.
noMatchSize(Integer) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
Sets the size of the fragment to return from the beginning of the field if there are no matches to highlight.
noMatchSize(Integer) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
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.
noMatchSize() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
NON_LOOPBACK_ADDRESS - Static variable in class org.elasticsearch.common.network.NetworkUtils
 
NON_NEGATIVE_DOUBLE - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
NON_NEGATIVE_FLOAT - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
NON_NEGATIVE_INTEGER - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
NON_RECYCLING_INSTANCE - Static variable in class org.elasticsearch.common.util.BigArrays
 
NonCollectingAggregator - Class in org.elasticsearch.search.aggregations
An aggregator that is not collected, this can typically be used when running an aggregation over a field that doesn't have a mapping.
NonCollectingAggregator(String, AggregationContext, Aggregator, AggregatorFactories) - Constructor for class org.elasticsearch.search.aggregations.NonCollectingAggregator
 
NonCollectingAggregator(String, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.NonCollectingAggregator
 
NONE - Static variable in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
 
none(Recycler.C<T>) - Static method in enum org.elasticsearch.common.recycler.Recyclers
Return a Recycler that never recycles entries.
None() - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
 
NONE - Static variable in class org.elasticsearch.plugins.PluginManager.ACTION
 
NoneCircuitBreakerService - Class in org.elasticsearch.indices.breaker
Class that returns a breaker that never breaks
NoneCircuitBreakerService() - Constructor for class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
 
NoneDocSetCache - Class in org.elasticsearch.index.cache.docset.none
 
NoneDocSetCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.docset.none.NoneDocSetCache
 
NoneFilterCache - Class in org.elasticsearch.index.cache.filter.none
 
NoneFilterCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
NoneGateway - Class in org.elasticsearch.gateway.none
 
NoneGateway(Settings, ClusterName) - Constructor for class org.elasticsearch.gateway.none.NoneGateway
 
NoneGatewayAllocator - Class in org.elasticsearch.gateway.none
 
NoneGatewayAllocator() - Constructor for class org.elasticsearch.gateway.none.NoneGatewayAllocator
 
NoneGatewayModule - Class in org.elasticsearch.gateway.none
 
NoneGatewayModule() - Constructor for class org.elasticsearch.gateway.none.NoneGatewayModule
 
NoneIndexGateway - Class in org.elasticsearch.index.gateway.none
 
NoneIndexGateway(Index, Settings) - Constructor for class org.elasticsearch.index.gateway.none.NoneIndexGateway
 
NoneIndexGatewayModule - Class in org.elasticsearch.index.gateway.none
 
NoneIndexGatewayModule() - Constructor for class org.elasticsearch.index.gateway.none.NoneIndexGatewayModule
 
NoneIndexShardGateway - Class in org.elasticsearch.index.gateway.none
 
NoneIndexShardGateway(ShardId, Settings, IndexShard) - Constructor for class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
NoneQueryParserCache - Class in org.elasticsearch.index.cache.query.parser.none
 
NoneQueryParserCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.query.parser.none.NoneQueryParserCache
 
NoneRecycler<T> - Class in org.elasticsearch.common.recycler
 
NoneRecycler(Recycler.C<T>) - Constructor for class org.elasticsearch.common.recycler.NoneRecycler
 
NoneRecycler.NV<T> - Class in org.elasticsearch.common.recycler
 
NonEstimatingEstimator - Class in org.elasticsearch.index.fielddata.plain
Estimator that does nothing except for adjust the breaker after the field data has been loaded.
NONEXISTENT_INDEX_RETRY_WAIT - Static variable in class org.elasticsearch.index.engine.ShadowEngine
how long to wait for an index to exist
nonHeapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
nonHeapInit() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
nonHeapMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
nonHeapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
nonNestedDocsFilter - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
NonNestedDocsFilter - Class in org.elasticsearch.index.search.nested
A filter that returns all root (non nested) documents.
NoNodeAvailableException - Exception in org.elasticsearch.client.transport
An exception indicating no node is available to perform the operation.
NoNodeAvailableException(String) - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
 
NoNodeAvailableException(String, Throwable) - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
 
NOOP_COLLECTOR - Static variable in class org.elasticsearch.common.lucene.search.NoopCollector
 
NoopCircuitBreaker - Class in org.elasticsearch.common.breaker
A CircuitBreaker that doesn't increment or adjust, and all operations are basically noops
NoopCircuitBreaker(CircuitBreaker.Name) - Constructor for class org.elasticsearch.common.breaker.NoopCircuitBreaker
 
NoopCollector - Class in org.elasticsearch.common.lucene.search
 
NoopCollector() - Constructor for class org.elasticsearch.common.lucene.search.NoopCollector
 
NoOpLock() - Constructor for class org.elasticsearch.index.engine.Engine.NoOpLock
 
NoopStreamOutput - Class in org.elasticsearch.common.io.stream
A non-threadsafe StreamOutput that doesn't actually write the bytes to any stream, it only keeps track of how many bytes have been written
NoopStreamOutput() - Constructor for class org.elasticsearch.common.io.stream.NoopStreamOutput
 
noopUpdate(String) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
NORMAL - Static variable in class org.elasticsearch.common.Priority
 
normalize(double, DistanceUnit) - Method in enum org.elasticsearch.common.geo.GeoDistance
 
normalize(float, float) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
NORMALIZE_LAT - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
NORMALIZE_LON - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
normalizeFetchSourceContent(FetchSourceContext, String[]) - Method in class org.elasticsearch.index.get.ShardGetService
decides what needs to be done based on the request input and always returns a valid non-null FetchSourceContext
normalizeLat(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
Normalize latitude to lie within the -90 to 90 (both inclusive) range.
normalizeLon(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
Normalize longitude to lie within the -180 (exclusive) to 180 (inclusive) range.
normalizePoint(GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
Normalize the geo Point for its coordinates to lie within their respective normalized ranges.
normalizePoint(GeoPoint, boolean, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
Normalize the geo Point for the given coordinates to lie within their respective normalized ranges.
normalizePrefix(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Checks that all settings in the builder start with the specified prefix.
normalizeVersions() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
creates a new IndexRoutingTable with all shard versions normalized
normalizeVersions() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Normalizes all shard routings to the same version.
NORMS_LOADING_KEY - Static variable in class org.elasticsearch.search.SearchService
 
normsField(String) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
Field used for normalization factor (document boost).
normsLoading - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
normsLoading(FieldMapper.Loading) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
normsLoading - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
normsLoading(FieldMapper.Loading) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
normsLoading(FieldMapper.Loading) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
NorwegianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
NorwegianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.NorwegianAnalyzerProvider
 
NoShardAvailableActionException - Exception in org.elasticsearch.action
 
NoShardAvailableActionException(ShardId) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
 
NoShardAvailableActionException(ShardId, String) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
 
NoShardAvailableActionException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
 
NoSuchNodeException - Exception in org.elasticsearch.action
 
NoSuchNodeException(String) - Constructor for exception org.elasticsearch.action.NoSuchNodeException
 
not(Matcher<? super T>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
Inverts the given matcher.
NOT_EXISTS - Static variable in class org.elasticsearch.index.engine.Engine.GetResult
 
NOT_FOUND - Static variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
NOT_FOUND - Static variable in class org.elasticsearch.common.lucene.uid.Versions
 
NOT_SET - Static variable in class org.elasticsearch.common.lucene.uid.Versions
 
notASubtype(Class<?>, Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
NotBits(Bits) - Constructor for class org.elasticsearch.common.lucene.docset.NotDocIdSet.NotBits
 
NotDocIdSet - Class in org.elasticsearch.common.lucene.docset
A DocIdSet that matches the "inverse" of the provided doc id set.
NotDocIdSet(DocIdSet, int) - Constructor for class org.elasticsearch.common.lucene.docset.NotDocIdSet
 
NotDocIdSet.BitsBasedIterator - Class in org.elasticsearch.common.lucene.docset
 
NotDocIdSet.IteratorBasedIterator - Class in org.elasticsearch.common.lucene.docset
 
NotDocIdSet.NotBits - Class in org.elasticsearch.common.lucene.docset
 
NotFilter - Class in org.elasticsearch.common.lucene.search
 
NotFilter(Filter) - Constructor for class org.elasticsearch.common.lucene.search.NotFilter
 
notFilter(FilterBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
NotFilterBuilder - Class in org.elasticsearch.index.query
A filter that matches documents matching boolean combinations of other filters.
NotFilterBuilder(FilterBuilder) - Constructor for class org.elasticsearch.index.query.NotFilterBuilder
 
NotFilterParser - Class in org.elasticsearch.index.query
 
NotFilterParser() - Constructor for class org.elasticsearch.index.query.NotFilterParser
 
notifyNow() - Method in class org.elasticsearch.watcher.ResourceWatcherService
 
notifyNow(ResourceWatcherService.Frequency) - Method in class org.elasticsearch.watcher.ResourceWatcherService
 
NotSerializableTransportException - Exception in org.elasticsearch.transport
 
NotSerializableTransportException(Throwable) - Constructor for exception org.elasticsearch.transport.NotSerializableTransportException
 
now() - Method in exception org.elasticsearch.index.AlreadyExpiredException
 
nowInMillis() - Method in class org.elasticsearch.index.query.QueryParseContext
 
nowInMillis() - Method in class org.elasticsearch.search.internal.SearchContext
 
nowInMillis() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
 
nowInMillis() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
 
nowInMillis() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 
nowInMillisImpl() - Method in class org.elasticsearch.percolator.PercolateContext
 
nowInMillisImpl() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
nowInMillisImpl() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
nowInMillisImpl() - Method in class org.elasticsearch.search.internal.SearchContext
 
nowInMillisUsed() - Method in class org.elasticsearch.search.internal.SearchContext
 
NULL - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetaData
 
NULL - Static variable in class org.elasticsearch.index.gateway.CommitPoint
 
NULL_KEY - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.ByteFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.FloatFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.LongFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.ShortFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.ip.IpFieldMapper.Defaults
 
Nullability - Class in org.elasticsearch.common.inject.internal
Whether a member supports null values injected.
Nullable - Annotation Type in org.elasticsearch.common.inject.internal
The presence of this annotation on a method parameter indicates that null is an acceptable value for that parameter.
Nullable - Annotation Type in org.elasticsearch.common
The presence of this annotation on a method parameter indicates that null is an acceptable value for that parameter.
nullField(String) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
nullField(XContentBuilderString) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
NullProgress() - Constructor for class org.elasticsearch.common.http.client.HttpDownloadHelper.NullProgress
 
nullValue() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
nullValue(boolean) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.core.ByteFieldMapper.Builder
 
nullValue(byte) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
nullValue(String) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Builder
 
nullValue(double) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.core.FloatFieldMapper.Builder
 
nullValue(float) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Builder
 
nullValue(int) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Builder
 
nullValue() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
nullValue - Variable in class org.elasticsearch.index.mapper.core.LongFieldMapper.Builder
 
nullValue(long) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.core.ShortFieldMapper.Builder
 
nullValue(short) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
nullValue(String) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
nullValue(int) - Method in class org.elasticsearch.index.mapper.core.TokenCountFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Builder
 
nullValue(float) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.ip.IpFieldMapper.Builder
 
nullValue(String) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper.Builder
 
nullValue(boolean) - Method in class org.elasticsearch.index.query.MissingFilterBuilder
Should the missing filter automatically include fields with null value configured in the mappings.
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
nullValueFilter() - Method in interface org.elasticsearch.index.mapper.FieldMapper
Null value filter, returns null if there is no null value associated with the field.
nullValueFilter() - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
nullValueFilter() - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
Number(String, ValueFormatter, ValueParser) - Constructor for class org.elasticsearch.search.aggregations.support.format.ValueFormat.Number
 
number() - Method in class org.elasticsearch.Version
Just the version number (without -SNAPSHOT if snapshot).
NumberFieldMapper<T extends Number> - Class in org.elasticsearch.index.mapper.core
 
NumberFieldMapper(FieldMapper.Names, int, float, FieldType, Boolean, Explicit<Boolean>, Explicit<Boolean>, NamedAnalyzer, NamedAnalyzer, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
NumberFieldMapper.Builder<T extends NumberFieldMapper.Builder,Y extends NumberFieldMapper> - Class in org.elasticsearch.index.mapper.core
 
NumberFieldMapper.CustomLongNumericDocValuesField - Class in org.elasticsearch.index.mapper.core
 
NumberFieldMapper.CustomNumericDocValuesField - Class in org.elasticsearch.index.mapper.core
 
NumberFieldMapper.CustomNumericField - Class in org.elasticsearch.index.mapper.core
 
NumberFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
numberOfActions() - Method in class org.elasticsearch.action.bulk.BulkRequest
The number of actions in the bulk request.
numberOfActions() - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
The number of actions currently in the bulk.
numberOfFiles() - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
numberOfFiles() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
Returns number of files that where snapshotted
numberOfFiles() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
Number of files
numberOfFiles() - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
 
numberOfFragments() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
numberOfNodesShardsAreAllocatedOn(String...) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
Calculates the number of nodes that hold one or more shards of this index IndexRoutingTable excluding the nodes with the node ids give as the excludedNodes parameter.
numberOfOpenChannels() - Method in class org.elasticsearch.common.netty.OpenChannelsHandler
 
numberOfOwningShards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
The number of shards on this node that will not be eventually relocated.
numberOfParts() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
Returns number of parts
numberOfPendingTasks() - Method in interface org.elasticsearch.cluster.ClusterService
Returns the number of currently pending tasks.
numberOfPendingTasks() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
numberOfReplicas(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
numberOfReplicas() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
numberOfReplicas() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
numberOfShards(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
numberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
numberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
numberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
numberOfShards() - Method in class org.elasticsearch.index.IndexService
 
numberOfShards() - Method in class org.elasticsearch.percolator.PercolateContext
 
numberOfShards() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
numberOfShards() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
numberOfShards() - Method in class org.elasticsearch.search.internal.SearchContext
 
numberOfShards() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
 
numberOfShards() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
 
numberOfShards() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 
numberOfShardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
Determine the number of shards with a specific state
Numbers - Class in org.elasticsearch.common
A set of utilities for numbers.
numberType() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
numberType() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
numberValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
numberValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
numBitsPerCoordinate() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
The number of bits required to encode a single coordinate of a geo point.
numBytes() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
The number of bytes required to encode a single geo point.
numCollectedDocs - Variable in class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator
 
numCollectedDocs - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
 
numCollectedDocs - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
 
numDeletedDocs() - Method in class org.elasticsearch.search.lookup.IndexLookup
 
numDocs - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
numDocs() - Method in class org.elasticsearch.search.lookup.IndexLookup
 
Numeric() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
 
numeric(String, InternalAggregation.Type, SearchContext) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
 
NUMERIC_DETECTION - Static variable in class org.elasticsearch.index.mapper.object.RootObjectMapper.Defaults
 
NumericAnalyzer<T extends NumericTokenizer> - Class in org.elasticsearch.index.analysis
 
NumericAnalyzer() - Constructor for class org.elasticsearch.index.analysis.NumericAnalyzer
 
numericAsString() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper.CustomByteNumericField
 
numericAsString() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericField
 
numericAsString() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericField
 
numericAsString() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.CustomIntegerNumericField
 
numericAsString() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.CustomLongNumericField
 
numericAsString() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
 
numericAsString() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper.CustomShortNumericField
 
NumericDateAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericDateAnalyzer(int, DateTimeFormatter) - Constructor for class org.elasticsearch.index.analysis.NumericDateAnalyzer
 
NumericDateTokenizer - Class in org.elasticsearch.index.analysis
 
NumericDateTokenizer(Reader, int, char[], DateTimeFormatter) - Constructor for class org.elasticsearch.index.analysis.NumericDateTokenizer
 
numericDetection - Variable in class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
 
numericDetection() - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper
 
NumericDoubleAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericDoubleAnalyzer(int) - Constructor for class org.elasticsearch.index.analysis.NumericDoubleAnalyzer
 
NumericDoubleTokenizer - Class in org.elasticsearch.index.analysis
 
NumericDoubleTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.analysis.NumericDoubleTokenizer
 
NumericDoubleValues - Class in org.elasticsearch.index.fielddata
A per-document numeric value.
NumericDoubleValues() - Constructor for class org.elasticsearch.index.fielddata.NumericDoubleValues
Sole constructor.
NumericDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
NumericDVIndexFieldData(Index, FieldMapper.Names, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.NumericDVIndexFieldData
 
NumericFloatAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericFloatAnalyzer(int) - Constructor for class org.elasticsearch.index.analysis.NumericFloatAnalyzer
 
NumericFloatTokenizer - Class in org.elasticsearch.index.analysis
 
NumericFloatTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.analysis.NumericFloatTokenizer
 
NumericIntegerAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericIntegerAnalyzer(int) - Constructor for class org.elasticsearch.index.analysis.NumericIntegerAnalyzer
 
NumericIntegerTokenizer - Class in org.elasticsearch.index.analysis
 
NumericIntegerTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.analysis.NumericIntegerTokenizer
 
NumericIpAnalyzer(int) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.NumericIpAnalyzer
 
NumericIpTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.NumericIpTokenizer
 
NumericLongAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericLongAnalyzer(int) - Constructor for class org.elasticsearch.index.analysis.NumericLongAnalyzer
 
NumericLongTokenizer - Class in org.elasticsearch.index.analysis
 
NumericLongTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.analysis.NumericLongTokenizer
 
NumericMetricsAggregation - Interface in org.elasticsearch.search.aggregations.metrics
 
NumericMetricsAggregation.MultiValue - Interface in org.elasticsearch.search.aggregations.metrics
 
NumericMetricsAggregation.SingleValue - Interface in org.elasticsearch.search.aggregations.metrics
 
NumericMetricsAggregator - Class in org.elasticsearch.search.aggregations.metrics
 
NumericMetricsAggregator.MultiValue - Class in org.elasticsearch.search.aggregations.metrics
 
NumericMetricsAggregator.SingleValue - Class in org.elasticsearch.search.aggregations.metrics
 
NumericRangeFieldDataFilter<T> - Class in org.elasticsearch.index.search
A numeric filter that can be much faster than NumericRangeFilter at the expense of loading numeric values of the field to memory using org.elasticsearch.index.cache.field.data.FieldDataCache.
NumericRangeFieldDataFilter(IndexNumericFieldData, T, T, boolean, boolean) - Constructor for class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
numericRangeFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
Deprecated.
The numeric_range filter will be removed at some point in time in favor for the range filter with the execution mode fielddata.
NumericRangeFilterBuilder - Class in org.elasticsearch.index.query
Deprecated.
This filter will be removed at some point in time in favor for the range filter with the execution mode fielddata.
NumericRangeFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
A filter that restricts search results to values that are within the given range.
NumericRangeFilterParser - Class in org.elasticsearch.index.query
Deprecated.
NumericRangeFilterParser() - Constructor for class org.elasticsearch.index.query.NumericRangeFilterParser
Deprecated.
 
NumericTokenizer - Class in org.elasticsearch.index.analysis
 
NumericTokenizer(Reader, NumericTokenStream, char[], Object) - Constructor for class org.elasticsearch.index.analysis.NumericTokenizer
 
numericType(IndexNumericFieldData.NumericType) - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData.Builder
 
numericValue() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
 
NumericValuesSourceMetricsAggregatorParser<S extends InternalNumericMetricsAggregation> - Class in org.elasticsearch.search.aggregations.metrics
 
NumericValuesSourceMetricsAggregatorParser(InternalAggregation.Type) - Constructor for class org.elasticsearch.search.aggregations.metrics.NumericValuesSourceMetricsAggregatorParser
 
numOfFragments(int) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 
numOfFragments(Integer) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
Sets the maximum number of fragments returned
numPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
 
numShapes() - Method in class org.elasticsearch.common.geo.builders.GeometryCollectionBuilder
 
NXYBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
 
NXYParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYParser
 
NXYSignificanceHeuristic - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
NXYSignificanceHeuristic(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
 
NXYSignificanceHeuristic.Frequencies - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
NXYSignificanceHeuristic.NXYBuilder - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
NXYSignificanceHeuristic.NXYParser - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 

O

Object() - Constructor for class org.elasticsearch.common.collect.HppcMaps.Object
 
object(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
OBJECT_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.BigArrays
 
ObjectArray<T> - Interface in org.elasticsearch.common.util
Abstraction of an array of object values.
objectBytes() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
objectBytes() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
objectFloatMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
objectFloatMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
objectIntMap - Variable in class org.elasticsearch.cache.recycler.CacheRecycler
 
objectIntMap(int) - Method in class org.elasticsearch.cache.recycler.CacheRecycler
 
objectMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns objects mappers based on the full path of the object.
ObjectMapper - Class in org.elasticsearch.index.mapper.object
 
objectMapper(ObjectMapper) - Method in class org.elasticsearch.index.mapper.ObjectMapperListener.Aggregator
 
objectMapper(ObjectMapper) - Method in class org.elasticsearch.index.mapper.ObjectMapperListener
 
ObjectMapper.Builder<T extends ObjectMapper.Builder,Y extends ObjectMapper> - Class in org.elasticsearch.index.mapper.object
 
ObjectMapper.Defaults - Class in org.elasticsearch.index.mapper.object
 
ObjectMapper.Dynamic - Enum in org.elasticsearch.index.mapper.object
 
ObjectMapper.Nested - Class in org.elasticsearch.index.mapper.object
 
ObjectMapper.TypeParser - Class in org.elasticsearch.index.mapper.object
 
ObjectMapperListener - Class in org.elasticsearch.index.mapper
 
ObjectMapperListener() - Constructor for class org.elasticsearch.index.mapper.ObjectMapperListener
 
ObjectMapperListener.Aggregator - Class in org.elasticsearch.index.mapper
 
objectMappers() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
objectMappers(ObjectMapper...) - Method in class org.elasticsearch.index.mapper.ObjectMapperListener
 
ObjectMappers - Class in org.elasticsearch.index.mapper
A holder for several ObjectMapper.
ObjectMappers() - Constructor for class org.elasticsearch.index.mapper.ObjectMappers
 
ObjectMappers(ObjectMapper) - Constructor for class org.elasticsearch.index.mapper.ObjectMappers
 
ObjectMappers(ObjectMapper[]) - Constructor for class org.elasticsearch.index.mapper.ObjectMappers
 
ObjectMappers(ImmutableList<ObjectMapper>) - Constructor for class org.elasticsearch.index.mapper.ObjectMappers
 
objectPage() - Method in class org.elasticsearch.cache.recycler.PageCacheRecycler
 
objectText() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
objectText() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
observedState() - Method in class org.elasticsearch.cluster.ClusterStateObserver
last cluster state observer by this observer.
obtain(int) - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
 
obtain(int) - Method in class org.elasticsearch.common.recycler.DequeRecycler
 
obtain(int) - Method in class org.elasticsearch.common.recycler.NoneRecycler
 
obtain() - Method in interface org.elasticsearch.common.recycler.Recycler
 
obtain(int) - Method in interface org.elasticsearch.common.recycler.Recycler
 
obtain(AtomicReaderContext) - Method in interface org.elasticsearch.index.cache.docset.DocSetCache
 
obtain(AtomicReaderContext) - Method in class org.elasticsearch.index.cache.docset.none.NoneDocSetCache
 
obtain(AtomicReaderContext) - Method in class org.elasticsearch.index.cache.docset.simple.SimpleDocSetCache
 
occur - Variable in class org.elasticsearch.index.search.MatchQuery
 
occurrences - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCountCollector
 
of() - Static method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
 
of() - Static method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
of() - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
 
of(T) - Static method in class org.elasticsearch.common.inject.util.Providers
Returns a provider which always provides instance.
of(byte) - Static method in class org.elasticsearch.index.analysis.CharMatcher.ByUnicodeCategory
 
of(int) - Static method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
Get an instance based on the number of bytes that has been used to encode values.
of(DistanceUnit.Distance) - Static method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
Get an instance based on the expected precision.
offer(E) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
 
offer(E, long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
 
offMaster() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
 
offMaster() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
Called when the local node used to be the master, a new master was elected and it's no longer the local node.
OFFSET - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
 
offset - Variable in class org.elasticsearch.index.query.functionscore.DecayFunctionParser.AbstractDistanceScoreFunction
 
offset(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Set the offset that is applied to computed bucket boundaries.
offset - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
offsetAttr - Variable in class org.elasticsearch.search.suggest.SuggestUtils.TokenConsumer
 
offsets(boolean) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Return the start and stop offsets for each term if they were stored or skip offsets.
offsets() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
OLD - Static variable in class org.elasticsearch.monitor.jvm.GcNames
 
OLD_CIRCUIT_BREAKER_MAX_BYTES_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
OLD_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
omitNorms(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
omitNormsSet - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
onAckTimeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
Called once the acknowledgement timeout defined by AckedClusterStateUpdateTask.ackTimeout() has expired
onAfter() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
This method is called in a finally block after successful execution or on a rejection.
onAllNodesAcked(Throwable) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
Called once all the nodes have acknowledged the cluster state update request.
onCached(long) - Method in class org.elasticsearch.index.cache.filter.ShardFilterCache
 
onCached(long) - Method in class org.elasticsearch.index.cache.fixedbitset.ShardFixedBitSetFilterCache
 
onCached(IndicesQueryCache.Key, IndicesQueryCache.Value) - Method in class org.elasticsearch.index.cache.query.ShardQueryCache
 
onCancel(String, Throwable) - Method in class org.elasticsearch.common.util.CancellableThreads
called if CancellableThreads.checkForCancel() was invoked after the operation was cancelled.
onClose() - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
 
onClose(Object) - Method in class org.elasticsearch.index.cache.docset.simple.SimpleDocSetCache
 
onClose(IndexReader) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
onClose(Object) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
onClose(Object) - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
onClose(Object) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
onClose(IndexReader) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
onClusterServiceClose() - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
called when the cluster service is closed
onCommit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.deletionpolicy.KeepLastNDeletionPolicy
 
onCommit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.deletionpolicy.KeepOnlyLastDeletionPolicy
Deletes all commits except the most recent one.
onCommit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
Called by Lucene..
onDirectoryCreated(File) - Method in class org.elasticsearch.watcher.FileChangesListener
Called for every new subdirectory found in the watched directory
onDirectoryDeleted(File) - Method in class org.elasticsearch.watcher.FileChangesListener
Called for every file that disappeared in the watched directory
onDirectoryInit(File) - Method in class org.elasticsearch.watcher.FileChangesListener
Called for every subdirectory found in the watched directory during initialization
onDoc(int, SortedNumericDoubleValues) - Method in class org.elasticsearch.search.facet.DoubleFacetAggregatorBase
 
onDoc(int, MultiGeoPointValues) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetExecutor.Aggregator
 
onDoc(int, SortedNumericDocValues) - Method in class org.elasticsearch.search.facet.LongFacetAggregatorBase
 
onDoc(int, SortedBinaryDocValues) - Method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
ONE - Static variable in class org.elasticsearch.common.unit.Fuzziness
 
oneMinuteEWMA() - Static method in class org.elasticsearch.common.metrics.EWMA
Creates a new EWMA which is equivalent to the UNIX one minute load average and which expects to be ticked every 5 seconds.
oneMinuteRate() - Method in class org.elasticsearch.common.metrics.MeterMetric
 
onFailedEngine(ShardId, String, Throwable) - Method in interface org.elasticsearch.index.engine.Engine.FailedEngineListener
 
onFailedFetchPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
onFailedMerge(MergePolicy.MergeException) - Method in interface org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider.FailureListener
 
onFailedQueryPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
onFailure(Throwable) - Method in interface org.elasticsearch.action.ActionListener
A failure handler.
onFailure(Throwable) - Method in class org.elasticsearch.action.ActionRunnable
Calls the action listeners ActionListener.onFailure(Throwable) method with the given exception.
onFailure(Throwable) - Method in class org.elasticsearch.action.LatchedActionListener
 
onFailure(Throwable) - Method in class org.elasticsearch.action.support.AdapterActionFuture
 
onFailure(Throwable) - Method in class org.elasticsearch.action.support.DelegatingActionListener
 
onFailure(Throwable) - Method in class org.elasticsearch.client.transport.TransportClientNodesService.RetryListener
 
onFailure(String, Throwable) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
 
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdateListener
 
onFailure(String, Throwable) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
A callback called when execute fails.
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Listener
 
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutListener
 
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveListener
 
onFailure(Throwable) - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
This method is invoked for all exception thrown by AbstractRunnable.doRun()
onFailure(DiscoveryNode, Throwable) - Method in class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
 
onFailure(DiscoveryNode, Throwable) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
Called for each failure obtained from non master nodes
onFailure(Throwable) - Method in interface org.elasticsearch.discovery.zen.membership.MembershipAction.JoinCallback
 
onFailure(String) - Method in interface org.elasticsearch.gateway.Gateway.GatewayStateRecoveredListener
 
onFailure(Throwable) - Method in interface org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices.Listener
 
onFailure(Throwable) - Method in class org.elasticsearch.rest.action.support.RestActionListener
 
onFailure(Throwable) - Method in interface org.elasticsearch.search.action.SearchServiceListener
 
onFailure(Throwable) - Method in interface org.elasticsearch.snapshots.SnapshotsService.CreateSnapshotListener
Called if a snapshot operation couldn't start
onFailure(Throwable) - Method in interface org.elasticsearch.snapshots.SnapshotsService.DeleteSnapshotListener
Called if delete operation failed
onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
onFileChanged(File) - Method in class org.elasticsearch.watcher.FileChangesListener
Called for every file that was changed in the watched directory
onFileCreated(File) - Method in class org.elasticsearch.watcher.FileChangesListener
Called for every new file found in the watched directory
onFileDeleted(File) - Method in class org.elasticsearch.watcher.FileChangesListener
Called for every file that disappeared in the watched directory
onFileInit(File) - Method in class org.elasticsearch.watcher.FileChangesListener
Called for every file found in the watched directory during initialization
onFreeContext(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
OnGoingMerge - Class in org.elasticsearch.index.merge
Represents a single on going merge within an index.
OnGoingMerge(MergePolicy.OneMerge) - Constructor for class org.elasticsearch.index.merge.OnGoingMerge
 
onGoingMerges() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
onGoingMerges() - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
onGoingMerges() - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
onGoingMerges() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
Deprecated.
 
onGoingRecoveries - Variable in class org.elasticsearch.index.engine.InternalEngine
 
onHit() - Method in class org.elasticsearch.index.cache.query.ShardQueryCache
 
onIgnoreRecovery(String) - Method in interface org.elasticsearch.index.gateway.IndexShardGatewayService.RecoveryListener
 
onInit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.deletionpolicy.KeepLastNDeletionPolicy
 
onInit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.deletionpolicy.KeepOnlyLastDeletionPolicy
Deletes all commits except the most recent one.
onInit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
Called by Lucene.
onJoin(DiscoveryNode, MembershipAction.JoinCallback) - Method in interface org.elasticsearch.discovery.zen.membership.MembershipAction.MembershipListener
 
onLeave(DiscoveryNode) - Method in interface org.elasticsearch.discovery.zen.membership.MembershipAction.MembershipListener
 
onLoad(FieldMapper.Names, FieldDataType, Accountable) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache.Listener
 
onLoad(FieldMapper.Names, FieldDataType, Accountable) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
 
onLoad(FieldMapper.Names, FieldDataType, Accountable) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCacheListener
 
only(Object) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
Returns a matcher which matches objects equal to the given object.
ONLY_EXPUNGE_DELETES - Static variable in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
onlyCount() - Method in class org.elasticsearch.action.percolate.PercolateRequest
onlyCount(boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequest
Sets whether this percolate request should only count the number of percolator queries that matches with the document being percolated and don't keep track of the actual queries that have matched.
onlyCount() - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
 
onlyExpungeDeletes() - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should the optimization only expunge deletes from the index, without full optimization.
onlyExpungeDeletes(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should the optimization only expunge deletes from the index, without full optimization.
onlyLongestMatch - Variable in class org.elasticsearch.index.analysis.compound.AbstractCompoundWordTokenFilterFactory
 
onlyNodeActiveInitializingShardsIt(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
onMappingUpdate() - Method in interface org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdateListener
 
onMappingUpdate() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
 
onMaster() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
 
onMaster() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
Called when local node is elected to be the master
onMasterFailure(DiscoveryNode, String) - Method in interface org.elasticsearch.discovery.zen.fd.MasterFaultDetection.Listener
called when pinging the master failed, like a timeout, transport disconnects etc
onMessage(BytesReference, SocketAddress) - Method in interface org.elasticsearch.common.network.MulticastChannel.Listener
 
onMessage(BytesReference, SocketAddress) - Method in class org.elasticsearch.common.network.MulticastChannel.MultiListener
 
onMiss() - Method in class org.elasticsearch.index.cache.query.ShardQueryCache
 
onNewClusterState(ClusterState) - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
called when a new state is observed
onNewClusterState(ClusterState, PublishClusterStateAction.NewClusterStateListener.NewStateProcessed) - Method in interface org.elasticsearch.discovery.zen.publish.PublishClusterStateAction.NewClusterStateListener
 
onNewClusterState(RiverClusterState) - Method in interface org.elasticsearch.river.cluster.PublishRiverClusterStateAction.NewClusterStateListener
 
onNewClusterStateFailed(Throwable) - Method in interface org.elasticsearch.discovery.zen.publish.PublishClusterStateAction.NewClusterStateListener.NewStateProcessed
 
onNewClusterStateProcessed() - Method in interface org.elasticsearch.discovery.zen.publish.PublishClusterStateAction.NewClusterStateListener.NewStateProcessed
 
onNewContext(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
onNewInfo(ClusterInfo) - Method in interface org.elasticsearch.cluster.ClusterInfoService.Listener
 
onNodeAck(DiscoveryNode, Throwable) - Method in interface org.elasticsearch.discovery.Discovery.AckListener
 
onNodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportConnectionListener
 
onNodeDisconnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportConnectionListener
 
onNodeFailure(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.Listener
 
onNodeIndexDeleted(String, String) - Method in interface org.elasticsearch.cluster.action.index.NodeIndexDeletedAction.Listener
 
onNodeIndexStoreDeleted(String, String) - Method in interface org.elasticsearch.cluster.action.index.NodeIndexDeletedAction.Listener
 
onNoLongerMaster(String) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
called when the task was rejected because the local node is no longer master
onOperation(ShardRouting, int, ShardResponse) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction.AsyncBroadcastAction
 
onOrAfter(Version) - Method in class org.elasticsearch.Version
 
onOrBefore(Version) - Method in class org.elasticsearch.Version
 
onPause(long) - Method in interface org.apache.lucene.store.StoreRateLimiting.Listener
 
onPause(long) - Method in interface org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream.Listener
 
onPause(long) - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
onPing(ZenPing.PingResponse[]) - Method in interface org.elasticsearch.discovery.zen.ping.ZenPing.PingListener
 
onPingReceived(NodesFaultDetection.PingRequest) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.Listener
 
onPortNumber(int) - Method in interface org.elasticsearch.common.transport.PortsRange.PortCallback
 
onPostWarm(long) - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
 
onPreFetchPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
onPreQueryPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
onPreWarm() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
 
onQueryPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
onQueryPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
onRecoveryDone() - Method in interface org.elasticsearch.index.gateway.IndexShardGatewayService.RecoveryListener
 
onRecoveryDone(RecoveryState) - Method in interface org.elasticsearch.indices.recovery.RecoveryTarget.RecoveryListener
 
onRecoveryFailed(IndexShardGatewayRecoveryException) - Method in interface org.elasticsearch.index.gateway.IndexShardGatewayService.RecoveryListener
 
onRecoveryFailure(RecoveryState, RecoveryFailedException, boolean) - Method in interface org.elasticsearch.indices.recovery.RecoveryTarget.RecoveryListener
 
onRecoveryFailure(Throwable) - Method in class org.elasticsearch.indices.recovery.SharedFSRecoverySourceHandler
 
onRefreshSettings(Settings) - Method in class org.elasticsearch.action.support.DestructiveOperations
 
onRefreshSettings(Settings) - Method in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
 
onRefreshSettings(Settings) - Method in interface org.elasticsearch.index.settings.IndexSettingsService.Listener
 
onRefreshSettings(Settings) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService.ApplySettings
 
onRefreshSettings(Settings) - Method in interface org.elasticsearch.node.settings.NodeSettingsService.Listener
 
onRejection(Throwable) - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
This should be executed if the thread-pool executing this action rejected the execution.
onRemoval(RemovalNotification<WeightedFilterCache.FilterCacheKey, DocIdSet>) - Method in class org.elasticsearch.index.cache.filter.ShardFilterCache
 
onRemoval(RemovalNotification<Object, Cache<Filter, FixedBitSetFilterCache.Value>>) - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
onRemoval(long) - Method in class org.elasticsearch.index.cache.fixedbitset.ShardFixedBitSetFilterCache
 
onRemoval(RemovalNotification<IndicesQueryCache.Key, IndicesQueryCache.Value>) - Method in class org.elasticsearch.index.cache.query.ShardQueryCache
 
onRemoval(RemovalNotification<IndexFieldDataCache.FieldBased.Key, Accountable>) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.FieldBased
 
onRemoval(RemovalNotification<WeightedFilterCache.FilterCacheKey, DocIdSet>) - Method in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
onRemoval(RemovalNotification<IndicesQueryCache.Key, IndicesQueryCache.Value>) - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache
 
onRemoval(RemovalNotification<IndicesFieldDataCache.Key, Accountable>) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
 
onRequestReceived(long, String) - Method in class org.elasticsearch.transport.TransportService.Adapter
 
onRequestReceived(long, String) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
called by the {@link Transport) implementation when an incoming request arrives but before any parsing of it has happened (with the exception of the requestId and action)
onRequestSent(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.transport.TransportService.Adapter
 
onRequestSent(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
called by the Transport implementation once a request has been sent
onResponse(Response) - Method in interface org.elasticsearch.action.ActionListener
A response handler.
onResponse(T) - Method in class org.elasticsearch.action.LatchedActionListener
 
onResponse(L) - Method in class org.elasticsearch.action.support.AdapterActionFuture
 
onResponse(Instigator) - Method in class org.elasticsearch.action.support.DelegatingActionListener
 
onResponse(Response) - Method in class org.elasticsearch.client.transport.TransportClientNodesService.RetryListener
 
onResponse(MetaDataDeleteIndexService.Response) - Method in interface org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Listener
 
onResponse(MetaDataIndexTemplateService.PutResponse) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutListener
 
onResponse(MetaDataIndexTemplateService.RemoveResponse) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveListener
 
onResponse(DiscoveryNode) - Method in class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
 
onResponse(DiscoveryNode) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
Called for each response obtained from non master nodes
onResponse(LocalAllocateDangledIndices.AllocateDangledResponse) - Method in interface org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices.Listener
 
onResponse(Response) - Method in class org.elasticsearch.rest.action.support.RestActionListener
 
onResponse() - Method in interface org.elasticsearch.snapshots.SnapshotsService.CreateSnapshotListener
Called when snapshot has successfully started
onResponse() - Method in interface org.elasticsearch.snapshots.SnapshotsService.DeleteSnapshotListener
Called if delete operation was successful
onResponseReceived(long) - Method in class org.elasticsearch.transport.TransportService.Adapter
 
onResponseReceived(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
called by the {@link Transport) implementation when a response or an exception has been recieved for a previously sent request (before any processing or deserialization was done).
onResponseSent(long, String, TransportResponse, TransportResponseOptions) - Method in class org.elasticsearch.transport.TransportService.Adapter
 
onResponseSent(long, String, Throwable) - Method in class org.elasticsearch.transport.TransportService.Adapter
 
onResponseSent(long, String, TransportResponse, TransportResponseOptions) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
called by the {@link Transport) implementation once a response was sent to calling node
onResponseSent(long, String, Throwable) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
called by the {@link Transport) implementation after an exception was sent as a response to an incoming request
onRestorePause(long) - Method in interface org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository.RateLimiterListener
 
onRestorePause(long) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
 
onResult(T) - Method in interface org.elasticsearch.search.action.SearchServiceListener
 
onSnapshotCompletion(SnapshotId, SnapshotInfo) - Method in interface org.elasticsearch.snapshots.SnapshotsService.SnapshotCompletionListener
 
onSnapshotFailure(SnapshotId, Throwable) - Method in interface org.elasticsearch.snapshots.SnapshotsService.SnapshotCompletionListener
 
onSnapshotPause(long) - Method in interface org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository.RateLimiterListener
 
onSnapshotPause(long) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
 
onSuccess() - Method in interface org.elasticsearch.discovery.zen.membership.MembershipAction.JoinCallback
 
onSuccess(ClusterState) - Method in interface org.elasticsearch.gateway.Gateway.GatewayStateRecoveredListener
 
onTerminated() - Method in interface org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor.ShutdownListener
 
onTick() - Method in interface org.elasticsearch.common.http.client.HttpDownloadHelper.DownloadProgress
tick handler
onTick() - Method in class org.elasticsearch.common.http.client.HttpDownloadHelper.NullProgress
tick handler
onTick() - Method in class org.elasticsearch.common.http.client.HttpDownloadHelper.VerboseProgress
tick handler
onTimeout(TimeValue) - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
 
onTimeout(TimeValue) - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
 
onTimeout() - Method in interface org.elasticsearch.discovery.Discovery.AckListener
 
onUnload(FieldMapper.Names, FieldDataType, boolean, long) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache.Listener
 
onUnload(FieldMapper.Names, FieldDataType, boolean, long) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
 
onUnload(FieldMapper.Names, FieldDataType, boolean, long) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCacheListener
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetExecutor.DateHistogramProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetExecutor.DateHistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetExecutor.DateHistogramProc.ValueAggregator
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetExecutor.DateHistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.DoubleFacetAggregatorBase
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.CountHistogramFacetExecutor.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.FullHistogramFacetExecutor.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.ValueHistogramFacetExecutor.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.ValueHistogramFacetExecutor.HistogramProc.ValueAggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.ValueScriptHistogramFacetExecutor.HistogramProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.LongFacetAggregatorBase
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.range.KeyValueRangeFacetExecutor.RangeProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.range.RangeFacetExecutor.RangeProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor.StatsProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetExecutor.StatsProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetExecutor.AggregatorValueProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetExecutor.StaticAggregatorValueProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetExecutor.AggregatorValueProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetExecutor.StaticAggregatorValueProc
 
onValue(int, BytesRef, int) - Method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
onValue(int, BytesRef, int) - Method in class org.elasticsearch.search.facet.terms.strings.HashedScriptAggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor.Aggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor.Aggregator.ValueAggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor.ScriptAggregator
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor.Aggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor.Aggregator.ValueAggregator
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor.ScriptAggregator
 
onValue(int, BytesRef, int) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor.Aggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor.Aggregator.ValueAggregator
 
onValue(int, BytesRef, int) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor.ScriptAggregator
 
open(OpenIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Open an index based on the index name.
open(OpenIndexRequest, ActionListener<OpenIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Open an index based on the index name.
open(OpenIndexRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
open(OpenIndexRequest, ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
openAndPutIndexOutput(String, StoreFileMetaData, Store) - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
Creates an IndexOutput for the given file name.
OpenChannelsHandler - Class in org.elasticsearch.common.netty
 
OpenChannelsHandler(ESLogger) - Constructor for class org.elasticsearch.common.netty.OpenChannelsHandler
 
openFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessStats
 
openIndex(OpenIndexClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexStateService
 
OpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
 
OpenIndexClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.open
Cluster state update request that allows to open one or more indices
OpenIndexRequest - Class in org.elasticsearch.action.admin.indices.open
A request to open an index.
OpenIndexRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
Constructs a new open index request for the specified index.
openIndexRequest(String) - Static method in class org.elasticsearch.client.Requests
Creates an open index request.
OpenIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.open
Builder for for open index request
OpenIndexRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
 
OpenIndexRequestBuilder(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
 
OpenIndexResponse - Class in org.elasticsearch.action.admin.indices.open
A response for a open index action.
openInput(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
Creates a new InputStream for the given blob name
openInput(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
 
openInput(String) - Method in class org.elasticsearch.common.blobstore.url.URLBlobContainer
 
openInput(String, IOContext) - Method in class org.elasticsearch.index.store.DistributorDirectory
 
openInput(String, IOContext) - Method in class org.elasticsearch.index.store.Store.StoreDirectory
 
openInput(File) - Method in class org.elasticsearch.index.translog.ChecksummedTranslogStream
 
openInput(File) - Method in class org.elasticsearch.index.translog.LegacyTranslogStream
 
openInput(File) - Method in interface org.elasticsearch.index.translog.TranslogStream
Seek past the header, if any header is present
openSlice(long) - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
Called for each logical slice given a zero based slice ordinal.
openVerifyingInput(String, IOContext, StoreFileMetaData) - Method in class org.elasticsearch.index.store.Store
 
operation() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
 
operationComplete(ChannelFuture) - Method in class org.elasticsearch.common.netty.ReleaseChannelFutureListener
 
operationComplete(ChannelFuture) - Method in class org.elasticsearch.transport.netty.NettyTransport.ChannelCloseListener
 
operationRouting() - Method in interface org.elasticsearch.cluster.ClusterService
The operation routing.
OperationRouting - Interface in org.elasticsearch.cluster.routing.operation
 
operationRouting() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
OperationRoutingModule - Class in org.elasticsearch.cluster.routing.operation
 
OperationRoutingModule(Settings) - Constructor for class org.elasticsearch.cluster.routing.operation.OperationRoutingModule
 
operationThreaded() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreaded(boolean) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreaded() - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreaded(boolean) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreaded() - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreaded(boolean) - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
Controls if the operation will be executed on a separate thread when executed locally.
operator(MatchQueryBuilder.Operator) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
Sets the operator to use when using a boolean query.
operator(MatchQueryBuilder.Operator) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
Sets the operator to use when using a boolean query.
optimize(OptimizeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Explicitly optimize one or more indices into a the number of segments.
optimize(OptimizeRequest, ActionListener<OptimizeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Explicitly optimize one or more indices into a the number of segments.
optimize(OptimizeRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
optimize(OptimizeRequest, ActionListener<OptimizeResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
optimize(OptimizeRequest) - Method in class org.elasticsearch.index.shard.IndexShard
 
OPTIMIZE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
OptimizeAction - Class in org.elasticsearch.action.admin.indices.optimize
 
optimizeBbox(String) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
optimizeBbox(String) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
OptimizeFailedEngineException - Exception in org.elasticsearch.index.engine
 
OptimizeFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.OptimizeFailedEngineException
 
OptimizeRequest - Class in org.elasticsearch.action.admin.indices.optimize
A request to optimize one or more indices.
OptimizeRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Constructs an optimization request over one or more indices.
OptimizeRequest() - Constructor for class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
 
optimizeRequest(String...) - Static method in class org.elasticsearch.client.Requests
Creates an optimize request.
OptimizeRequest.Defaults - Class in org.elasticsearch.action.admin.indices.optimize
 
OptimizeRequestBuilder - Class in org.elasticsearch.action.admin.indices.optimize
A request to optimize one or more indices.
OptimizeRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
 
OptimizeResponse - Class in org.elasticsearch.action.admin.indices.optimize
A response for optimize action.
optimizeSingleShard() - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
option(String, String) - Static method in class org.elasticsearch.common.cli.CliToolConfig.Builder
 
Option(Text, float, BytesReference) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
 
Option() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
 
Option(Text, Text, float, Boolean) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
 
Option(Text, Text, float) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
 
Option(Text, float) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
 
Option() - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
 
Option(Text, int, float) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
 
Option() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
 
optionalConstructor(Constructor) - Method in class org.elasticsearch.common.inject.internal.Errors
 
optionalReadFromStream(StreamInput) - Static method in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
optionalWriteToStream(FetchSourceContext, StreamOutput) - Static method in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
optionGroup(boolean) - Static method in class org.elasticsearch.common.cli.CliToolConfig.Builder
 
optionGroups(CliToolConfig.OptionGroupBuilder...) - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd.Builder
 
options(CliToolConfig.OptionBuilder...) - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd.Builder
 
options() - Method in class org.elasticsearch.common.cli.CliToolConfig.Cmd
 
options(CliToolConfig.OptionBuilder...) - Method in class org.elasticsearch.common.cli.CliToolConfig.OptionGroupBuilder
 
options(Map<String, Object>) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
Allows to set custom options for custom highlighters.
options(Map<String, Object>) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
Allows to set custom options for custom highlighters.
options() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.FieldOptions
 
options - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
options() - Static method in class org.elasticsearch.transport.TransportRequestOptions
 
options() - Static method in class org.elasticsearch.transport.TransportResponseOptions
 
opType(IndexRequest.OpType) - Method in class org.elasticsearch.action.index.IndexRequest
Sets the type of operation to perform.
opType(String) - Method in class org.elasticsearch.action.index.IndexRequest
opType() - Method in class org.elasticsearch.action.index.IndexRequest
The type of operation to perform.
opType(IndexRequest.OpType) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
Sets the type of operation to perform.
opType() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
The type of operation to perform.
opType() - Method in class org.elasticsearch.index.engine.Engine.Create
 
opType() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
opType() - Method in class org.elasticsearch.index.engine.Engine.Index
 
opType() - Method in interface org.elasticsearch.index.engine.Engine.Operation
 
opType() - Method in class org.elasticsearch.index.translog.Translog.Create
 
opType() - Method in class org.elasticsearch.index.translog.Translog.Delete
 
opType() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
opType() - Method in class org.elasticsearch.index.translog.Translog.Index
 
opType() - Method in interface org.elasticsearch.index.translog.Translog.Operation
 
or(Matcher<? super T>) - Method in class org.elasticsearch.common.inject.matcher.AbstractMatcher
 
or(Matcher<? super T>) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
Returns a new matcher which returns true if either this or the given matcher return true.
or(CharMatcher) - Method in class org.elasticsearch.index.analysis.CharMatcher.Builder
 
ord() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
 
ordAt(int) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalMapping
 
order(int) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
 
order() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
 
order() - Method in interface org.elasticsearch.action.support.ActionFilter
The position of the filter in the chain.
order() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
Returns -1 if not set...
order(int) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
order() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
order(int) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
 
order() - Method in class org.elasticsearch.rest.RestFilter
Optionally, the order of the filter.
order(Histogram.Order) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Set the order by which the buckets will be returned.
Order() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.Histogram.Order
 
order(Histogram.Order) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramBuilder
Sets the order by which the buckets will be returned.
order - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
Order() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.Terms.Order
 
order - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
 
order(Terms.Order) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsBuilder
Defines the order in which the buckets will be returned.
order(TermsFacet.ComparatorType) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
The order by which to return the facets by.
order(TermsStatsFacet.ComparatorType) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
The order by which to return the facets by.
order(String) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
The order of fragments per field.
order(String) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
The order of fragments per field.
order(SortOrder) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
The order of sorting.
order(SortOrder) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
The order of sorting.
order(SortOrder) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
The order of sort scoring.
order(SortOrder) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
Sets the sort order.
order(SortOrder) - Method in class org.elasticsearch.search.sort.SortBuilder
The order of sorting.
OrderedDownstreamChannelEvent - Class in org.elasticsearch.http.netty.pipelining
Permits downstream channel events to be ordered and signalled as to whether more are to come for a given sequence.
OrderedDownstreamChannelEvent(OrderedUpstreamMessageEvent, int, boolean, ChannelEvent) - Constructor for class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
Construct a downstream channel event for all types of events.
OrderedDownstreamChannelEvent(OrderedUpstreamMessageEvent, Object) - Constructor for class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
Convenience constructor signifying that this downstream message event is the last one for the given sequence, and that there is only one response.
OrderedDownstreamChannelEvent(OrderedUpstreamMessageEvent, int, boolean, Object) - Constructor for class org.elasticsearch.http.netty.pipelining.OrderedDownstreamChannelEvent
Convenience constructor for passing message events.
OrderedUpstreamMessageEvent - Class in org.elasticsearch.http.netty.pipelining
Permits upstream message events to be ordered.
OrderedUpstreamMessageEvent(int, Channel, Object, SocketAddress) - Constructor for class org.elasticsearch.http.netty.pipelining.OrderedUpstreamMessageEvent
 
OrderPath - 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.
OrderPath(OrderPath.Token[]) - Constructor for class org.elasticsearch.search.aggregations.support.OrderPath
 
OrderPath.Token - Class in org.elasticsearch.search.aggregations.support
 
ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
 
Ordinals - Class in org.elasticsearch.index.fielddata.ordinals
A thread safe ordinals abstraction.
Ordinals() - Constructor for class org.elasticsearch.index.fielddata.ordinals.Ordinals
 
ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.Ordinals
 
ordinals() - Method in class org.elasticsearch.index.fielddata.ordinals.Ordinals
 
ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.SinglePackedOrdinals
 
ordinals - Variable in class org.elasticsearch.index.fielddata.plain.FSTBytesAtomicFieldData
 
ordinals - Variable in class org.elasticsearch.index.fielddata.plain.PagedBytesAtomicFieldData
 
Ordinals.ValuesHolder - Interface in org.elasticsearch.index.fielddata.ordinals
 
OrdinalsBuilder - Class in org.elasticsearch.index.fielddata.ordinals
Simple class to build document ID <-> ordinal mapping.
OrdinalsBuilder(long, int, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
 
OrdinalsBuilder(int, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
 
OrdinalsBuilder(int) - Constructor for class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
 
ordinalsValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
ordinalsValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
 
OrDocIdSet - Class in org.elasticsearch.common.lucene.docset
 
OrDocIdSet(DocIdSet[]) - Constructor for class org.elasticsearch.common.lucene.docset.OrDocIdSet
 
OrFilter - Class in org.elasticsearch.common.lucene.search
 
OrFilter(List<? extends Filter>) - Constructor for class org.elasticsearch.common.lucene.search.OrFilter
 
orFilter(FilterBuilder...) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
OrFilterBuilder - Class in org.elasticsearch.index.query
A filter that matches documents matching boolean combinations of other filters.
OrFilterBuilder(FilterBuilder...) - Constructor for class org.elasticsearch.index.query.OrFilterBuilder
 
OrFilterParser - Class in org.elasticsearch.index.query
 
OrFilterParser() - Constructor for class org.elasticsearch.index.query.OrFilterParser
 
org.apache.lucene.analysis - package org.apache.lucene.analysis
 
org.apache.lucene.analysis.miscellaneous - package org.apache.lucene.analysis.miscellaneous
 
org.apache.lucene.index - package org.apache.lucene.index
 
org.apache.lucene.index.memory - package org.apache.lucene.index.memory
 
org.apache.lucene.queries - package org.apache.lucene.queries
 
org.apache.lucene.queryparser.classic - package org.apache.lucene.queryparser.classic
 
org.apache.lucene.search.postingshighlight - package org.apache.lucene.search.postingshighlight
 
org.apache.lucene.search.suggest.analyzing - package org.apache.lucene.search.suggest.analyzing
 
org.apache.lucene.search.vectorhighlight - package org.apache.lucene.search.vectorhighlight
 
org.apache.lucene.store - package org.apache.lucene.store
 
org.apache.lucene.util - package org.apache.lucene.util
 
org.elasticsearch - package org.elasticsearch
 
org.elasticsearch.action - package org.elasticsearch.action
 
org.elasticsearch.action.admin - package org.elasticsearch.action.admin
Administrative Actions.
org.elasticsearch.action.admin.cluster - package org.elasticsearch.action.admin.cluster
 
org.elasticsearch.action.admin.cluster.health - package org.elasticsearch.action.admin.cluster.health
 
org.elasticsearch.action.admin.cluster.node.hotthreads - package org.elasticsearch.action.admin.cluster.node.hotthreads
 
org.elasticsearch.action.admin.cluster.node.info - package org.elasticsearch.action.admin.cluster.node.info
 
org.elasticsearch.action.admin.cluster.node.restart - package org.elasticsearch.action.admin.cluster.node.restart
 
org.elasticsearch.action.admin.cluster.node.shutdown - package org.elasticsearch.action.admin.cluster.node.shutdown
 
org.elasticsearch.action.admin.cluster.node.stats - package org.elasticsearch.action.admin.cluster.node.stats
 
org.elasticsearch.action.admin.cluster.repositories.delete - package org.elasticsearch.action.admin.cluster.repositories.delete
 
org.elasticsearch.action.admin.cluster.repositories.get - package org.elasticsearch.action.admin.cluster.repositories.get
 
org.elasticsearch.action.admin.cluster.repositories.put - package org.elasticsearch.action.admin.cluster.repositories.put
 
org.elasticsearch.action.admin.cluster.repositories.verify - package org.elasticsearch.action.admin.cluster.repositories.verify
 
org.elasticsearch.action.admin.cluster.reroute - package org.elasticsearch.action.admin.cluster.reroute
 
org.elasticsearch.action.admin.cluster.settings - package org.elasticsearch.action.admin.cluster.settings
 
org.elasticsearch.action.admin.cluster.shards - package org.elasticsearch.action.admin.cluster.shards
 
org.elasticsearch.action.admin.cluster.snapshots.create - package org.elasticsearch.action.admin.cluster.snapshots.create
 
org.elasticsearch.action.admin.cluster.snapshots.delete - package org.elasticsearch.action.admin.cluster.snapshots.delete
 
org.elasticsearch.action.admin.cluster.snapshots.get - package org.elasticsearch.action.admin.cluster.snapshots.get
 
org.elasticsearch.action.admin.cluster.snapshots.restore - package org.elasticsearch.action.admin.cluster.snapshots.restore
 
org.elasticsearch.action.admin.cluster.snapshots.status - package org.elasticsearch.action.admin.cluster.snapshots.status
 
org.elasticsearch.action.admin.cluster.state - package org.elasticsearch.action.admin.cluster.state
 
org.elasticsearch.action.admin.cluster.stats - package org.elasticsearch.action.admin.cluster.stats
 
org.elasticsearch.action.admin.cluster.tasks - package org.elasticsearch.action.admin.cluster.tasks
 
org.elasticsearch.action.admin.indices - package org.elasticsearch.action.admin.indices
Indices Administrative Actions.
org.elasticsearch.action.admin.indices.alias - package org.elasticsearch.action.admin.indices.alias
 
org.elasticsearch.action.admin.indices.alias.exists - package org.elasticsearch.action.admin.indices.alias.exists
 
org.elasticsearch.action.admin.indices.alias.get - package org.elasticsearch.action.admin.indices.alias.get
 
org.elasticsearch.action.admin.indices.analyze - package org.elasticsearch.action.admin.indices.analyze
 
org.elasticsearch.action.admin.indices.cache.clear - package org.elasticsearch.action.admin.indices.cache.clear
 
org.elasticsearch.action.admin.indices.close - package org.elasticsearch.action.admin.indices.close
 
org.elasticsearch.action.admin.indices.create - package org.elasticsearch.action.admin.indices.create
Create index action.
org.elasticsearch.action.admin.indices.delete - package org.elasticsearch.action.admin.indices.delete
Delete index action.
org.elasticsearch.action.admin.indices.exists.indices - package org.elasticsearch.action.admin.indices.exists.indices
 
org.elasticsearch.action.admin.indices.exists.types - package org.elasticsearch.action.admin.indices.exists.types
 
org.elasticsearch.action.admin.indices.flush - package org.elasticsearch.action.admin.indices.flush
Flush index/indices action.
org.elasticsearch.action.admin.indices.get - package org.elasticsearch.action.admin.indices.get
 
org.elasticsearch.action.admin.indices.mapping - package org.elasticsearch.action.admin.indices.mapping
Indices Mapping Administrative Actions.
org.elasticsearch.action.admin.indices.mapping.delete - package org.elasticsearch.action.admin.indices.mapping.delete
 
org.elasticsearch.action.admin.indices.mapping.get - package org.elasticsearch.action.admin.indices.mapping.get
 
org.elasticsearch.action.admin.indices.mapping.put - package org.elasticsearch.action.admin.indices.mapping.put
Put Mapping Action.
org.elasticsearch.action.admin.indices.open - package org.elasticsearch.action.admin.indices.open
 
org.elasticsearch.action.admin.indices.optimize - package org.elasticsearch.action.admin.indices.optimize
Optimize index/indices action.
org.elasticsearch.action.admin.indices.recovery - package org.elasticsearch.action.admin.indices.recovery
 
org.elasticsearch.action.admin.indices.refresh - package org.elasticsearch.action.admin.indices.refresh
Refresh index/indices action.
org.elasticsearch.action.admin.indices.segments - package org.elasticsearch.action.admin.indices.segments
 
org.elasticsearch.action.admin.indices.settings.get - package org.elasticsearch.action.admin.indices.settings.get
 
org.elasticsearch.action.admin.indices.settings.put - package org.elasticsearch.action.admin.indices.settings.put
 
org.elasticsearch.action.admin.indices.stats - package org.elasticsearch.action.admin.indices.stats
 
org.elasticsearch.action.admin.indices.status - package org.elasticsearch.action.admin.indices.status
 
org.elasticsearch.action.admin.indices.template.delete - package org.elasticsearch.action.admin.indices.template.delete
 
org.elasticsearch.action.admin.indices.template.get - package org.elasticsearch.action.admin.indices.template.get
 
org.elasticsearch.action.admin.indices.template.put - package org.elasticsearch.action.admin.indices.template.put
 
org.elasticsearch.action.admin.indices.validate.query - package org.elasticsearch.action.admin.indices.validate.query
Validate action.
org.elasticsearch.action.admin.indices.warmer - package org.elasticsearch.action.admin.indices.warmer
Index / Search Warmer Administrative Actions
org.elasticsearch.action.admin.indices.warmer.delete - package org.elasticsearch.action.admin.indices.warmer.delete
 
org.elasticsearch.action.admin.indices.warmer.get - package org.elasticsearch.action.admin.indices.warmer.get
 
org.elasticsearch.action.admin.indices.warmer.put - package org.elasticsearch.action.admin.indices.warmer.put
 
org.elasticsearch.action.bulk - package org.elasticsearch.action.bulk
 
org.elasticsearch.action.count - package org.elasticsearch.action.count
Count action.
org.elasticsearch.action.delete - package org.elasticsearch.action.delete
Delete action.
org.elasticsearch.action.deletebyquery - package org.elasticsearch.action.deletebyquery
Delete by query action.
org.elasticsearch.action.exists - package org.elasticsearch.action.exists
Exists action.
org.elasticsearch.action.explain - package org.elasticsearch.action.explain
Explain action.
org.elasticsearch.action.get - package org.elasticsearch.action.get
Get action.
org.elasticsearch.action.index - package org.elasticsearch.action.index
Index action.
org.elasticsearch.action.indexedscripts.delete - package org.elasticsearch.action.indexedscripts.delete
Delete action.
org.elasticsearch.action.indexedscripts.get - package org.elasticsearch.action.indexedscripts.get
 
org.elasticsearch.action.indexedscripts.put - package org.elasticsearch.action.indexedscripts.put
Index action.
org.elasticsearch.action.mlt - package org.elasticsearch.action.mlt
More Like This action.
org.elasticsearch.action.percolate - package org.elasticsearch.action.percolate
 
org.elasticsearch.action.search - package org.elasticsearch.action.search
Search action.
org.elasticsearch.action.search.type - package org.elasticsearch.action.search.type
 
org.elasticsearch.action.suggest - package org.elasticsearch.action.suggest
Suggest action.
org.elasticsearch.action.support - package org.elasticsearch.action.support
 
org.elasticsearch.action.support.broadcast - package org.elasticsearch.action.support.broadcast
 
org.elasticsearch.action.support.master - package org.elasticsearch.action.support.master
 
org.elasticsearch.action.support.master.info - package org.elasticsearch.action.support.master.info
 
org.elasticsearch.action.support.nodes - package org.elasticsearch.action.support.nodes
 
org.elasticsearch.action.support.replication - package org.elasticsearch.action.support.replication
 
org.elasticsearch.action.support.single.custom - package org.elasticsearch.action.support.single.custom
 
org.elasticsearch.action.support.single.instance - package org.elasticsearch.action.support.single.instance
 
org.elasticsearch.action.support.single.shard - package org.elasticsearch.action.support.single.shard
 
org.elasticsearch.action.termvector - package org.elasticsearch.action.termvector
Get the term vector for a specific document.
org.elasticsearch.action.update - package org.elasticsearch.action.update
 
org.elasticsearch.bootstrap - package org.elasticsearch.bootstrap
 
org.elasticsearch.bulk.udp - package org.elasticsearch.bulk.udp
 
org.elasticsearch.cache.recycler - package org.elasticsearch.cache.recycler
 
org.elasticsearch.client - package org.elasticsearch.client
The client module allowing to easily perform actions/operations.
org.elasticsearch.client.node - package org.elasticsearch.client.node
 
org.elasticsearch.client.support - package org.elasticsearch.client.support
 
org.elasticsearch.client.transport - package org.elasticsearch.client.transport
 
org.elasticsearch.client.transport.support - package org.elasticsearch.client.transport.support
 
org.elasticsearch.cluster - package org.elasticsearch.cluster
 
org.elasticsearch.cluster.ack - package org.elasticsearch.cluster.ack
 
org.elasticsearch.cluster.action.index - package org.elasticsearch.cluster.action.index
 
org.elasticsearch.cluster.action.shard - package org.elasticsearch.cluster.action.shard
 
org.elasticsearch.cluster.block - package org.elasticsearch.cluster.block
 
org.elasticsearch.cluster.metadata - package org.elasticsearch.cluster.metadata
 
org.elasticsearch.cluster.node - package org.elasticsearch.cluster.node
 
org.elasticsearch.cluster.routing - package org.elasticsearch.cluster.routing
 
org.elasticsearch.cluster.routing.allocation - package org.elasticsearch.cluster.routing.allocation
 
org.elasticsearch.cluster.routing.allocation.allocator - package org.elasticsearch.cluster.routing.allocation.allocator
 
org.elasticsearch.cluster.routing.allocation.command - package org.elasticsearch.cluster.routing.allocation.command
 
org.elasticsearch.cluster.routing.allocation.decider - package org.elasticsearch.cluster.routing.allocation.decider
 
org.elasticsearch.cluster.routing.operation - package org.elasticsearch.cluster.routing.operation
 
org.elasticsearch.cluster.routing.operation.hash - package org.elasticsearch.cluster.routing.operation.hash
 
org.elasticsearch.cluster.routing.operation.hash.djb - package org.elasticsearch.cluster.routing.operation.hash.djb
 
org.elasticsearch.cluster.routing.operation.hash.simple - package org.elasticsearch.cluster.routing.operation.hash.simple
 
org.elasticsearch.cluster.routing.operation.plain - package org.elasticsearch.cluster.routing.operation.plain
 
org.elasticsearch.cluster.service - package org.elasticsearch.cluster.service
 
org.elasticsearch.cluster.settings - package org.elasticsearch.cluster.settings
 
org.elasticsearch.common - package org.elasticsearch.common
 
org.elasticsearch.common.blobstore - package org.elasticsearch.common.blobstore
 
org.elasticsearch.common.blobstore.fs - package org.elasticsearch.common.blobstore.fs
 
org.elasticsearch.common.blobstore.support - package org.elasticsearch.common.blobstore.support
 
org.elasticsearch.common.blobstore.url - package org.elasticsearch.common.blobstore.url
 
org.elasticsearch.common.breaker - package org.elasticsearch.common.breaker
 
org.elasticsearch.common.bytes - package org.elasticsearch.common.bytes
 
org.elasticsearch.common.cli - package org.elasticsearch.common.cli
 
org.elasticsearch.common.collect - package org.elasticsearch.common.collect
 
org.elasticsearch.common.component - package org.elasticsearch.common.component
 
org.elasticsearch.common.compress - package org.elasticsearch.common.compress
 
org.elasticsearch.common.compress.lzf - package org.elasticsearch.common.compress.lzf
 
org.elasticsearch.common.geo - package org.elasticsearch.common.geo
 
org.elasticsearch.common.geo.builders - package org.elasticsearch.common.geo.builders
 
org.elasticsearch.common.hash - package org.elasticsearch.common.hash
 
org.elasticsearch.common.http.client - package org.elasticsearch.common.http.client
 
org.elasticsearch.common.inject - package org.elasticsearch.common.inject
Google Guice (pronounced "juice") is an ultra-lightweight dependency injection framework.
org.elasticsearch.common.inject.assistedinject - package org.elasticsearch.common.inject.assistedinject
Extension for combining factory interfaces with injection; this extension requires guice-jndi-2.0.jar.
org.elasticsearch.common.inject.binder - package org.elasticsearch.common.inject.binder
Interfaces which make up Binder's expression language.
org.elasticsearch.common.inject.internal - package org.elasticsearch.common.inject.internal
Guice (sounds like like "juice")
org.elasticsearch.common.inject.matcher - package org.elasticsearch.common.inject.matcher
Used for matching things.
org.elasticsearch.common.inject.multibindings - package org.elasticsearch.common.inject.multibindings
Extension for binding multiple instances in a collection; this extension requires guice-multibindings-2.0.jar.
org.elasticsearch.common.inject.name - package org.elasticsearch.common.inject.name
Support for binding to string-based names.
org.elasticsearch.common.inject.spi - package org.elasticsearch.common.inject.spi
Guice service provider interface
org.elasticsearch.common.inject.util - package org.elasticsearch.common.inject.util
Helper methods for working with Guice.
org.elasticsearch.common.io - package org.elasticsearch.common.io
 
org.elasticsearch.common.io.stream - package org.elasticsearch.common.io.stream
 
org.elasticsearch.common.jna - package org.elasticsearch.common.jna
 
org.elasticsearch.common.joda - package org.elasticsearch.common.joda
 
org.elasticsearch.common.lease - package org.elasticsearch.common.lease
 
org.elasticsearch.common.logging - package org.elasticsearch.common.logging
 
org.elasticsearch.common.logging.jdk - package org.elasticsearch.common.logging.jdk
 
org.elasticsearch.common.logging.log4j - package org.elasticsearch.common.logging.log4j
 
org.elasticsearch.common.logging.slf4j - package org.elasticsearch.common.logging.slf4j
 
org.elasticsearch.common.logging.support - package org.elasticsearch.common.logging.support
 
org.elasticsearch.common.lucene - package org.elasticsearch.common.lucene
 
org.elasticsearch.common.lucene.all - package org.elasticsearch.common.lucene.all
 
org.elasticsearch.common.lucene.docset - package org.elasticsearch.common.lucene.docset
 
org.elasticsearch.common.lucene.index - package org.elasticsearch.common.lucene.index
 
org.elasticsearch.common.lucene.search - package org.elasticsearch.common.lucene.search
 
org.elasticsearch.common.lucene.search.function - package org.elasticsearch.common.lucene.search.function
 
org.elasticsearch.common.lucene.store - package org.elasticsearch.common.lucene.store
 
org.elasticsearch.common.lucene.uid - package org.elasticsearch.common.lucene.uid
 
org.elasticsearch.common.math - package org.elasticsearch.common.math
 
org.elasticsearch.common.metrics - package org.elasticsearch.common.metrics
 
org.elasticsearch.common.netty - package org.elasticsearch.common.netty
 
org.elasticsearch.common.network - package org.elasticsearch.common.network
 
org.elasticsearch.common.os - package org.elasticsearch.common.os
 
org.elasticsearch.common.path - package org.elasticsearch.common.path
 
org.elasticsearch.common.property - package org.elasticsearch.common.property
 
org.elasticsearch.common.recycler - package org.elasticsearch.common.recycler
 
org.elasticsearch.common.regex - package org.elasticsearch.common.regex
 
org.elasticsearch.common.rounding - package org.elasticsearch.common.rounding
 
org.elasticsearch.common.settings - package org.elasticsearch.common.settings
Settings based utility.
org.elasticsearch.common.settings.loader - package org.elasticsearch.common.settings.loader
Settings loader (parser) allowing to parse different "source" formats into a Settings.
org.elasticsearch.common.text - package org.elasticsearch.common.text
 
org.elasticsearch.common.transport - package org.elasticsearch.common.transport
 
org.elasticsearch.common.unit - package org.elasticsearch.common.unit
 
org.elasticsearch.common.util - package org.elasticsearch.common.util
 
org.elasticsearch.common.util.concurrent - package org.elasticsearch.common.util.concurrent
 
org.elasticsearch.common.xcontent - package org.elasticsearch.common.xcontent
 
org.elasticsearch.common.xcontent.cbor - package org.elasticsearch.common.xcontent.cbor
 
org.elasticsearch.common.xcontent.json - package org.elasticsearch.common.xcontent.json
 
org.elasticsearch.common.xcontent.smile - package org.elasticsearch.common.xcontent.smile
 
org.elasticsearch.common.xcontent.support - package org.elasticsearch.common.xcontent.support
 
org.elasticsearch.common.xcontent.yaml - package org.elasticsearch.common.xcontent.yaml
 
org.elasticsearch.discovery - package org.elasticsearch.discovery
 
org.elasticsearch.discovery.local - package org.elasticsearch.discovery.local
 
org.elasticsearch.discovery.zen - package org.elasticsearch.discovery.zen
 
org.elasticsearch.discovery.zen.elect - package org.elasticsearch.discovery.zen.elect
 
org.elasticsearch.discovery.zen.fd - package org.elasticsearch.discovery.zen.fd
 
org.elasticsearch.discovery.zen.membership - package org.elasticsearch.discovery.zen.membership
 
org.elasticsearch.discovery.zen.ping - package org.elasticsearch.discovery.zen.ping
 
org.elasticsearch.discovery.zen.ping.multicast - package org.elasticsearch.discovery.zen.ping.multicast
 
org.elasticsearch.discovery.zen.ping.unicast - package org.elasticsearch.discovery.zen.ping.unicast
 
org.elasticsearch.discovery.zen.publish - package org.elasticsearch.discovery.zen.publish
 
org.elasticsearch.env - package org.elasticsearch.env
 
org.elasticsearch.gateway - package org.elasticsearch.gateway
 
org.elasticsearch.gateway.local - package org.elasticsearch.gateway.local
 
org.elasticsearch.gateway.local.state.meta - package org.elasticsearch.gateway.local.state.meta
 
org.elasticsearch.gateway.local.state.shards - package org.elasticsearch.gateway.local.state.shards
 
org.elasticsearch.gateway.none - package org.elasticsearch.gateway.none
 
org.elasticsearch.http - package org.elasticsearch.http
 
org.elasticsearch.http.netty - package org.elasticsearch.http.netty
 
org.elasticsearch.http.netty.pipelining - package org.elasticsearch.http.netty.pipelining
 
org.elasticsearch.index - package org.elasticsearch.index
 
org.elasticsearch.index.aliases - package org.elasticsearch.index.aliases
 
org.elasticsearch.index.analysis - package org.elasticsearch.index.analysis
 
org.elasticsearch.index.analysis.compound - package org.elasticsearch.index.analysis.compound
 
org.elasticsearch.index.cache - package org.elasticsearch.index.cache
 
org.elasticsearch.index.cache.docset - package org.elasticsearch.index.cache.docset
 
org.elasticsearch.index.cache.docset.none - package org.elasticsearch.index.cache.docset.none
 
org.elasticsearch.index.cache.docset.simple - package org.elasticsearch.index.cache.docset.simple
 
org.elasticsearch.index.cache.filter - package org.elasticsearch.index.cache.filter
 
org.elasticsearch.index.cache.filter.none - package org.elasticsearch.index.cache.filter.none
 
org.elasticsearch.index.cache.filter.support - package org.elasticsearch.index.cache.filter.support
 
org.elasticsearch.index.cache.filter.weighted - package org.elasticsearch.index.cache.filter.weighted
 
org.elasticsearch.index.cache.fixedbitset - package org.elasticsearch.index.cache.fixedbitset
 
org.elasticsearch.index.cache.id - package org.elasticsearch.index.cache.id
 
org.elasticsearch.index.cache.query - package org.elasticsearch.index.cache.query
 
org.elasticsearch.index.cache.query.parser - package org.elasticsearch.index.cache.query.parser
 
org.elasticsearch.index.cache.query.parser.none - package org.elasticsearch.index.cache.query.parser.none
 
org.elasticsearch.index.cache.query.parser.resident - package org.elasticsearch.index.cache.query.parser.resident
 
org.elasticsearch.index.codec - package org.elasticsearch.index.codec
 
org.elasticsearch.index.codec.docvaluesformat - package org.elasticsearch.index.codec.docvaluesformat
 
org.elasticsearch.index.codec.postingsformat - package org.elasticsearch.index.codec.postingsformat
 
org.elasticsearch.index.deletionpolicy - package org.elasticsearch.index.deletionpolicy
 
org.elasticsearch.index.engine - package org.elasticsearch.index.engine
 
org.elasticsearch.index.engine.internal - package org.elasticsearch.index.engine.internal
 
org.elasticsearch.index.fielddata - package org.elasticsearch.index.fielddata
 
org.elasticsearch.index.fielddata.fieldcomparator - package org.elasticsearch.index.fielddata.fieldcomparator
 
org.elasticsearch.index.fielddata.ordinals - package org.elasticsearch.index.fielddata.ordinals
 
org.elasticsearch.index.fielddata.plain - package org.elasticsearch.index.fielddata.plain
 
org.elasticsearch.index.fieldvisitor - package org.elasticsearch.index.fieldvisitor
 
org.elasticsearch.index.flush - package org.elasticsearch.index.flush
 
org.elasticsearch.index.gateway - package org.elasticsearch.index.gateway
 
org.elasticsearch.index.gateway.local - package org.elasticsearch.index.gateway.local
 
org.elasticsearch.index.gateway.none - package org.elasticsearch.index.gateway.none
 
org.elasticsearch.index.get - package org.elasticsearch.index.get
 
org.elasticsearch.index.indexing - package org.elasticsearch.index.indexing
 
org.elasticsearch.index.indexing.slowlog - package org.elasticsearch.index.indexing.slowlog
 
org.elasticsearch.index.mapper - package org.elasticsearch.index.mapper
 
org.elasticsearch.index.mapper.core - package org.elasticsearch.index.mapper.core
 
org.elasticsearch.index.mapper.geo - package org.elasticsearch.index.mapper.geo
 
org.elasticsearch.index.mapper.internal - package org.elasticsearch.index.mapper.internal
 
org.elasticsearch.index.mapper.ip - package org.elasticsearch.index.mapper.ip
 
org.elasticsearch.index.mapper.object - package org.elasticsearch.index.mapper.object
 
org.elasticsearch.index.merge - package org.elasticsearch.index.merge
 
org.elasticsearch.index.merge.policy - package org.elasticsearch.index.merge.policy
 
org.elasticsearch.index.merge.scheduler - package org.elasticsearch.index.merge.scheduler
 
org.elasticsearch.index.percolator - package org.elasticsearch.index.percolator
 
org.elasticsearch.index.percolator.stats - package org.elasticsearch.index.percolator.stats
 
org.elasticsearch.index.query - package org.elasticsearch.index.query
 
org.elasticsearch.index.query.functionscore - package org.elasticsearch.index.query.functionscore
 
org.elasticsearch.index.query.functionscore.exp - package org.elasticsearch.index.query.functionscore.exp
 
org.elasticsearch.index.query.functionscore.factor - package org.elasticsearch.index.query.functionscore.factor
 
org.elasticsearch.index.query.functionscore.fieldvaluefactor - package org.elasticsearch.index.query.functionscore.fieldvaluefactor
 
org.elasticsearch.index.query.functionscore.gauss - package org.elasticsearch.index.query.functionscore.gauss
 
org.elasticsearch.index.query.functionscore.lin - package org.elasticsearch.index.query.functionscore.lin
 
org.elasticsearch.index.query.functionscore.random - package org.elasticsearch.index.query.functionscore.random
 
org.elasticsearch.index.query.functionscore.script - package org.elasticsearch.index.query.functionscore.script
 
org.elasticsearch.index.query.functionscore.weight - package org.elasticsearch.index.query.functionscore.weight
 
org.elasticsearch.index.query.support - package org.elasticsearch.index.query.support
 
org.elasticsearch.index.recovery - package org.elasticsearch.index.recovery
 
org.elasticsearch.index.refresh - package org.elasticsearch.index.refresh
 
org.elasticsearch.index.search - package org.elasticsearch.index.search
 
org.elasticsearch.index.search.child - package org.elasticsearch.index.search.child
 
org.elasticsearch.index.search.geo - package org.elasticsearch.index.search.geo
 
org.elasticsearch.index.search.morelikethis - package org.elasticsearch.index.search.morelikethis
 
org.elasticsearch.index.search.nested - package org.elasticsearch.index.search.nested
 
org.elasticsearch.index.search.shape - package org.elasticsearch.index.search.shape
 
org.elasticsearch.index.search.slowlog - package org.elasticsearch.index.search.slowlog
 
org.elasticsearch.index.search.stats - package org.elasticsearch.index.search.stats
 
org.elasticsearch.index.settings - package org.elasticsearch.index.settings
 
org.elasticsearch.index.shard - package org.elasticsearch.index.shard
 
org.elasticsearch.index.similarity - package org.elasticsearch.index.similarity
 
org.elasticsearch.index.snapshots - package org.elasticsearch.index.snapshots
 
org.elasticsearch.index.snapshots.blobstore - package org.elasticsearch.index.snapshots.blobstore
 
org.elasticsearch.index.store - package org.elasticsearch.index.store
 
org.elasticsearch.index.store.distributor - package org.elasticsearch.index.store.distributor
 
org.elasticsearch.index.store.fs - package org.elasticsearch.index.store.fs
 
org.elasticsearch.index.store.ram - package org.elasticsearch.index.store.ram
 
org.elasticsearch.index.store.support - package org.elasticsearch.index.store.support
 
org.elasticsearch.index.suggest - package org.elasticsearch.index.suggest
 
org.elasticsearch.index.suggest.stats - package org.elasticsearch.index.suggest.stats
 
org.elasticsearch.index.termvectors - package org.elasticsearch.index.termvectors
 
org.elasticsearch.index.translog - package org.elasticsearch.index.translog
 
org.elasticsearch.index.translog.fs - package org.elasticsearch.index.translog.fs
 
org.elasticsearch.index.warmer - package org.elasticsearch.index.warmer
 
org.elasticsearch.indices - package org.elasticsearch.indices
 
org.elasticsearch.indices.analysis - package org.elasticsearch.indices.analysis
 
org.elasticsearch.indices.breaker - package org.elasticsearch.indices.breaker
 
org.elasticsearch.indices.cache.filter - package org.elasticsearch.indices.cache.filter
 
org.elasticsearch.indices.cache.filter.terms - package org.elasticsearch.indices.cache.filter.terms
 
org.elasticsearch.indices.cache.query - package org.elasticsearch.indices.cache.query
 
org.elasticsearch.indices.cluster - package org.elasticsearch.indices.cluster
 
org.elasticsearch.indices.fielddata.cache - package org.elasticsearch.indices.fielddata.cache
 
org.elasticsearch.indices.memory - package org.elasticsearch.indices.memory
 
org.elasticsearch.indices.query - package org.elasticsearch.indices.query
 
org.elasticsearch.indices.recovery - package org.elasticsearch.indices.recovery
 
org.elasticsearch.indices.store - package org.elasticsearch.indices.store
 
org.elasticsearch.indices.ttl - package org.elasticsearch.indices.ttl
 
org.elasticsearch.monitor - package org.elasticsearch.monitor
 
org.elasticsearch.monitor.fs - package org.elasticsearch.monitor.fs
 
org.elasticsearch.monitor.jvm - package org.elasticsearch.monitor.jvm
 
org.elasticsearch.monitor.network - package org.elasticsearch.monitor.network
 
org.elasticsearch.monitor.os - package org.elasticsearch.monitor.os
 
org.elasticsearch.monitor.process - package org.elasticsearch.monitor.process
 
org.elasticsearch.node - package org.elasticsearch.node
Allow to build a Node using NodeBuilder which is a node within the cluster.
org.elasticsearch.node.internal - package org.elasticsearch.node.internal
 
org.elasticsearch.node.service - package org.elasticsearch.node.service
 
org.elasticsearch.node.settings - package org.elasticsearch.node.settings
 
org.elasticsearch.percolator - package org.elasticsearch.percolator
 
org.elasticsearch.plugins - package org.elasticsearch.plugins
 
org.elasticsearch.repositories - package org.elasticsearch.repositories
 
org.elasticsearch.repositories.blobstore - package org.elasticsearch.repositories.blobstore
 
org.elasticsearch.repositories.fs - package org.elasticsearch.repositories.fs
 
org.elasticsearch.repositories.uri - package org.elasticsearch.repositories.uri
 
org.elasticsearch.rest - package org.elasticsearch.rest
 
org.elasticsearch.rest.action - package org.elasticsearch.rest.action
 
org.elasticsearch.rest.action.admin.cluster.health - package org.elasticsearch.rest.action.admin.cluster.health
 
org.elasticsearch.rest.action.admin.cluster.node.hotthreads - package org.elasticsearch.rest.action.admin.cluster.node.hotthreads
 
org.elasticsearch.rest.action.admin.cluster.node.info - package org.elasticsearch.rest.action.admin.cluster.node.info
 
org.elasticsearch.rest.action.admin.cluster.node.restart - package org.elasticsearch.rest.action.admin.cluster.node.restart
 
org.elasticsearch.rest.action.admin.cluster.node.shutdown - package org.elasticsearch.rest.action.admin.cluster.node.shutdown
 
org.elasticsearch.rest.action.admin.cluster.node.stats - package org.elasticsearch.rest.action.admin.cluster.node.stats
 
org.elasticsearch.rest.action.admin.cluster.repositories.delete - package org.elasticsearch.rest.action.admin.cluster.repositories.delete
 
org.elasticsearch.rest.action.admin.cluster.repositories.get - package org.elasticsearch.rest.action.admin.cluster.repositories.get
 
org.elasticsearch.rest.action.admin.cluster.repositories.put - package org.elasticsearch.rest.action.admin.cluster.repositories.put
 
org.elasticsearch.rest.action.admin.cluster.repositories.verify - package org.elasticsearch.rest.action.admin.cluster.repositories.verify
 
org.elasticsearch.rest.action.admin.cluster.reroute - package org.elasticsearch.rest.action.admin.cluster.reroute
 
org.elasticsearch.rest.action.admin.cluster.settings - package org.elasticsearch.rest.action.admin.cluster.settings
 
org.elasticsearch.rest.action.admin.cluster.shards - package org.elasticsearch.rest.action.admin.cluster.shards
 
org.elasticsearch.rest.action.admin.cluster.snapshots.create - package org.elasticsearch.rest.action.admin.cluster.snapshots.create
 
org.elasticsearch.rest.action.admin.cluster.snapshots.delete - package org.elasticsearch.rest.action.admin.cluster.snapshots.delete
 
org.elasticsearch.rest.action.admin.cluster.snapshots.get - package org.elasticsearch.rest.action.admin.cluster.snapshots.get
 
org.elasticsearch.rest.action.admin.cluster.snapshots.restore - package org.elasticsearch.rest.action.admin.cluster.snapshots.restore
 
org.elasticsearch.rest.action.admin.cluster.snapshots.status - package org.elasticsearch.rest.action.admin.cluster.snapshots.status
 
org.elasticsearch.rest.action.admin.cluster.state - package org.elasticsearch.rest.action.admin.cluster.state
 
org.elasticsearch.rest.action.admin.cluster.stats - package org.elasticsearch.rest.action.admin.cluster.stats
 
org.elasticsearch.rest.action.admin.cluster.tasks - package org.elasticsearch.rest.action.admin.cluster.tasks
 
org.elasticsearch.rest.action.admin.indices.alias - package org.elasticsearch.rest.action.admin.indices.alias
 
org.elasticsearch.rest.action.admin.indices.alias.delete - package org.elasticsearch.rest.action.admin.indices.alias.delete
 
org.elasticsearch.rest.action.admin.indices.alias.get - package org.elasticsearch.rest.action.admin.indices.alias.get
 
org.elasticsearch.rest.action.admin.indices.alias.head - package org.elasticsearch.rest.action.admin.indices.alias.head
 
org.elasticsearch.rest.action.admin.indices.alias.put - package org.elasticsearch.rest.action.admin.indices.alias.put
 
org.elasticsearch.rest.action.admin.indices.analyze - package org.elasticsearch.rest.action.admin.indices.analyze
 
org.elasticsearch.rest.action.admin.indices.cache.clear - package org.elasticsearch.rest.action.admin.indices.cache.clear
 
org.elasticsearch.rest.action.admin.indices.close - package org.elasticsearch.rest.action.admin.indices.close
 
org.elasticsearch.rest.action.admin.indices.create - package org.elasticsearch.rest.action.admin.indices.create
 
org.elasticsearch.rest.action.admin.indices.delete - package org.elasticsearch.rest.action.admin.indices.delete
 
org.elasticsearch.rest.action.admin.indices.exists.indices - package org.elasticsearch.rest.action.admin.indices.exists.indices
 
org.elasticsearch.rest.action.admin.indices.exists.types - package org.elasticsearch.rest.action.admin.indices.exists.types
 
org.elasticsearch.rest.action.admin.indices.flush - package org.elasticsearch.rest.action.admin.indices.flush
 
org.elasticsearch.rest.action.admin.indices.get - package org.elasticsearch.rest.action.admin.indices.get
 
org.elasticsearch.rest.action.admin.indices.mapping.delete - package org.elasticsearch.rest.action.admin.indices.mapping.delete
 
org.elasticsearch.rest.action.admin.indices.mapping.get - package org.elasticsearch.rest.action.admin.indices.mapping.get
 
org.elasticsearch.rest.action.admin.indices.mapping.put - package org.elasticsearch.rest.action.admin.indices.mapping.put
 
org.elasticsearch.rest.action.admin.indices.open - package org.elasticsearch.rest.action.admin.indices.open
 
org.elasticsearch.rest.action.admin.indices.optimize - package org.elasticsearch.rest.action.admin.indices.optimize
 
org.elasticsearch.rest.action.admin.indices.recovery - package org.elasticsearch.rest.action.admin.indices.recovery
 
org.elasticsearch.rest.action.admin.indices.refresh - package org.elasticsearch.rest.action.admin.indices.refresh
 
org.elasticsearch.rest.action.admin.indices.segments - package org.elasticsearch.rest.action.admin.indices.segments
 
org.elasticsearch.rest.action.admin.indices.settings - package org.elasticsearch.rest.action.admin.indices.settings
 
org.elasticsearch.rest.action.admin.indices.stats - package org.elasticsearch.rest.action.admin.indices.stats
 
org.elasticsearch.rest.action.admin.indices.status - package org.elasticsearch.rest.action.admin.indices.status
 
org.elasticsearch.rest.action.admin.indices.template.delete - package org.elasticsearch.rest.action.admin.indices.template.delete
 
org.elasticsearch.rest.action.admin.indices.template.get - package org.elasticsearch.rest.action.admin.indices.template.get
 
org.elasticsearch.rest.action.admin.indices.template.head - package org.elasticsearch.rest.action.admin.indices.template.head
 
org.elasticsearch.rest.action.admin.indices.template.put - package org.elasticsearch.rest.action.admin.indices.template.put
 
org.elasticsearch.rest.action.admin.indices.upgrade - package org.elasticsearch.rest.action.admin.indices.upgrade
 
org.elasticsearch.rest.action.admin.indices.validate.query - package org.elasticsearch.rest.action.admin.indices.validate.query
 
org.elasticsearch.rest.action.admin.indices.warmer.delete - package org.elasticsearch.rest.action.admin.indices.warmer.delete
 
org.elasticsearch.rest.action.admin.indices.warmer.get - package org.elasticsearch.rest.action.admin.indices.warmer.get
 
org.elasticsearch.rest.action.admin.indices.warmer.put - package org.elasticsearch.rest.action.admin.indices.warmer.put
 
org.elasticsearch.rest.action.bulk - package org.elasticsearch.rest.action.bulk
 
org.elasticsearch.rest.action.cat - package org.elasticsearch.rest.action.cat
 
org.elasticsearch.rest.action.count - package org.elasticsearch.rest.action.count
 
org.elasticsearch.rest.action.delete - package org.elasticsearch.rest.action.delete
 
org.elasticsearch.rest.action.deletebyquery - package org.elasticsearch.rest.action.deletebyquery
 
org.elasticsearch.rest.action.exists - package org.elasticsearch.rest.action.exists
 
org.elasticsearch.rest.action.explain - package org.elasticsearch.rest.action.explain
 
org.elasticsearch.rest.action.get - package org.elasticsearch.rest.action.get
 
org.elasticsearch.rest.action.index - package org.elasticsearch.rest.action.index
 
org.elasticsearch.rest.action.main - package org.elasticsearch.rest.action.main
 
org.elasticsearch.rest.action.mlt - package org.elasticsearch.rest.action.mlt
 
org.elasticsearch.rest.action.percolate - package org.elasticsearch.rest.action.percolate
 
org.elasticsearch.rest.action.script - package org.elasticsearch.rest.action.script
 
org.elasticsearch.rest.action.search - package org.elasticsearch.rest.action.search
 
org.elasticsearch.rest.action.suggest - package org.elasticsearch.rest.action.suggest
 
org.elasticsearch.rest.action.support - package org.elasticsearch.rest.action.support
 
org.elasticsearch.rest.action.template - package org.elasticsearch.rest.action.template
 
org.elasticsearch.rest.action.termvector - package org.elasticsearch.rest.action.termvector
 
org.elasticsearch.rest.action.update - package org.elasticsearch.rest.action.update
 
org.elasticsearch.rest.support - package org.elasticsearch.rest.support
 
org.elasticsearch.river - package org.elasticsearch.river
 
org.elasticsearch.river.cluster - package org.elasticsearch.river.cluster
 
org.elasticsearch.river.dummy - package org.elasticsearch.river.dummy
 
org.elasticsearch.river.routing - package org.elasticsearch.river.routing
 
org.elasticsearch.script - package org.elasticsearch.script
 
org.elasticsearch.script.expression - package org.elasticsearch.script.expression
 
org.elasticsearch.script.groovy - package org.elasticsearch.script.groovy
 
org.elasticsearch.script.mustache - package org.elasticsearch.script.mustache
 
org.elasticsearch.search - package org.elasticsearch.search
 
org.elasticsearch.search.action - package org.elasticsearch.search.action
 
org.elasticsearch.search.aggregations - package org.elasticsearch.search.aggregations
 
org.elasticsearch.search.aggregations.bucket - package org.elasticsearch.search.aggregations.bucket
 
org.elasticsearch.search.aggregations.bucket.children - package org.elasticsearch.search.aggregations.bucket.children
 
org.elasticsearch.search.aggregations.bucket.filter - package org.elasticsearch.search.aggregations.bucket.filter
 
org.elasticsearch.search.aggregations.bucket.filters - package org.elasticsearch.search.aggregations.bucket.filters
 
org.elasticsearch.search.aggregations.bucket.geogrid - package org.elasticsearch.search.aggregations.bucket.geogrid
 
org.elasticsearch.search.aggregations.bucket.global - package org.elasticsearch.search.aggregations.bucket.global
 
org.elasticsearch.search.aggregations.bucket.histogram - package org.elasticsearch.search.aggregations.bucket.histogram
 
org.elasticsearch.search.aggregations.bucket.missing - package org.elasticsearch.search.aggregations.bucket.missing
 
org.elasticsearch.search.aggregations.bucket.nested - package org.elasticsearch.search.aggregations.bucket.nested
 
org.elasticsearch.search.aggregations.bucket.range - package org.elasticsearch.search.aggregations.bucket.range
 
org.elasticsearch.search.aggregations.bucket.range.date - package org.elasticsearch.search.aggregations.bucket.range.date
 
org.elasticsearch.search.aggregations.bucket.range.geodistance - package org.elasticsearch.search.aggregations.bucket.range.geodistance
 
org.elasticsearch.search.aggregations.bucket.range.ipv4 - package org.elasticsearch.search.aggregations.bucket.range.ipv4
 
org.elasticsearch.search.aggregations.bucket.significant - package org.elasticsearch.search.aggregations.bucket.significant
 
org.elasticsearch.search.aggregations.bucket.significant.heuristics - package org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
org.elasticsearch.search.aggregations.bucket.terms - package org.elasticsearch.search.aggregations.bucket.terms
 
org.elasticsearch.search.aggregations.bucket.terms.support - package org.elasticsearch.search.aggregations.bucket.terms.support
 
org.elasticsearch.search.aggregations.metrics - package org.elasticsearch.search.aggregations.metrics
 
org.elasticsearch.search.aggregations.metrics.avg - package org.elasticsearch.search.aggregations.metrics.avg
 
org.elasticsearch.search.aggregations.metrics.cardinality - package org.elasticsearch.search.aggregations.metrics.cardinality
 
org.elasticsearch.search.aggregations.metrics.geobounds - package org.elasticsearch.search.aggregations.metrics.geobounds
 
org.elasticsearch.search.aggregations.metrics.max - package org.elasticsearch.search.aggregations.metrics.max
 
org.elasticsearch.search.aggregations.metrics.min - package org.elasticsearch.search.aggregations.metrics.min
 
org.elasticsearch.search.aggregations.metrics.percentiles - package org.elasticsearch.search.aggregations.metrics.percentiles
 
org.elasticsearch.search.aggregations.metrics.percentiles.tdigest - package org.elasticsearch.search.aggregations.metrics.percentiles.tdigest
 
org.elasticsearch.search.aggregations.metrics.scripted - package org.elasticsearch.search.aggregations.metrics.scripted
 
org.elasticsearch.search.aggregations.metrics.stats - package org.elasticsearch.search.aggregations.metrics.stats
 
org.elasticsearch.search.aggregations.metrics.stats.extended - package org.elasticsearch.search.aggregations.metrics.stats.extended
 
org.elasticsearch.search.aggregations.metrics.sum - package org.elasticsearch.search.aggregations.metrics.sum
 
org.elasticsearch.search.aggregations.metrics.tophits - package org.elasticsearch.search.aggregations.metrics.tophits
 
org.elasticsearch.search.aggregations.metrics.valuecount - package org.elasticsearch.search.aggregations.metrics.valuecount
 
org.elasticsearch.search.aggregations.support - package org.elasticsearch.search.aggregations.support
 
org.elasticsearch.search.aggregations.support.format - package org.elasticsearch.search.aggregations.support.format
 
org.elasticsearch.search.aggregations.support.values - package org.elasticsearch.search.aggregations.support.values
 
org.elasticsearch.search.builder - package org.elasticsearch.search.builder
 
org.elasticsearch.search.controller - package org.elasticsearch.search.controller
 
org.elasticsearch.search.dfs - package org.elasticsearch.search.dfs
 
org.elasticsearch.search.facet - package org.elasticsearch.search.facet
 
org.elasticsearch.search.facet.datehistogram - package org.elasticsearch.search.facet.datehistogram
 
org.elasticsearch.search.facet.filter - package org.elasticsearch.search.facet.filter
 
org.elasticsearch.search.facet.geodistance - package org.elasticsearch.search.facet.geodistance
 
org.elasticsearch.search.facet.histogram - package org.elasticsearch.search.facet.histogram
 
org.elasticsearch.search.facet.nested - package org.elasticsearch.search.facet.nested
 
org.elasticsearch.search.facet.query - package org.elasticsearch.search.facet.query
 
org.elasticsearch.search.facet.range - package org.elasticsearch.search.facet.range
 
org.elasticsearch.search.facet.statistical - package org.elasticsearch.search.facet.statistical
 
org.elasticsearch.search.facet.terms - package org.elasticsearch.search.facet.terms
 
org.elasticsearch.search.facet.terms.doubles - package org.elasticsearch.search.facet.terms.doubles
 
org.elasticsearch.search.facet.terms.longs - package org.elasticsearch.search.facet.terms.longs
 
org.elasticsearch.search.facet.terms.strings - package org.elasticsearch.search.facet.terms.strings
 
org.elasticsearch.search.facet.terms.support - package org.elasticsearch.search.facet.terms.support
 
org.elasticsearch.search.facet.terms.unmapped - package org.elasticsearch.search.facet.terms.unmapped
 
org.elasticsearch.search.facet.termsstats - package org.elasticsearch.search.facet.termsstats
 
org.elasticsearch.search.facet.termsstats.doubles - package org.elasticsearch.search.facet.termsstats.doubles
 
org.elasticsearch.search.facet.termsstats.longs - package org.elasticsearch.search.facet.termsstats.longs
 
org.elasticsearch.search.facet.termsstats.strings - package org.elasticsearch.search.facet.termsstats.strings
 
org.elasticsearch.search.fetch - package org.elasticsearch.search.fetch
 
org.elasticsearch.search.fetch.explain - package org.elasticsearch.search.fetch.explain
 
org.elasticsearch.search.fetch.fielddata - package org.elasticsearch.search.fetch.fielddata
 
org.elasticsearch.search.fetch.innerhits - package org.elasticsearch.search.fetch.innerhits
 
org.elasticsearch.search.fetch.matchedqueries - package org.elasticsearch.search.fetch.matchedqueries
 
org.elasticsearch.search.fetch.partial - package org.elasticsearch.search.fetch.partial
 
org.elasticsearch.search.fetch.script - package org.elasticsearch.search.fetch.script
 
org.elasticsearch.search.fetch.source - package org.elasticsearch.search.fetch.source
 
org.elasticsearch.search.fetch.version - package org.elasticsearch.search.fetch.version
 
org.elasticsearch.search.highlight - package org.elasticsearch.search.highlight
 
org.elasticsearch.search.highlight.vectorhighlight - package org.elasticsearch.search.highlight.vectorhighlight
 
org.elasticsearch.search.internal - package org.elasticsearch.search.internal
 
org.elasticsearch.search.lookup - package org.elasticsearch.search.lookup
 
org.elasticsearch.search.query - package org.elasticsearch.search.query
 
org.elasticsearch.search.rescore - package org.elasticsearch.search.rescore
 
org.elasticsearch.search.scan - package org.elasticsearch.search.scan
 
org.elasticsearch.search.sort - package org.elasticsearch.search.sort
 
org.elasticsearch.search.suggest - package org.elasticsearch.search.suggest
 
org.elasticsearch.search.suggest.completion - package org.elasticsearch.search.suggest.completion
 
org.elasticsearch.search.suggest.context - package org.elasticsearch.search.suggest.context
 
org.elasticsearch.search.suggest.phrase - package org.elasticsearch.search.suggest.phrase
 
org.elasticsearch.search.suggest.term - package org.elasticsearch.search.suggest.term
 
org.elasticsearch.search.warmer - package org.elasticsearch.search.warmer
 
org.elasticsearch.snapshots - package org.elasticsearch.snapshots
 
org.elasticsearch.threadpool - package org.elasticsearch.threadpool
 
org.elasticsearch.transport - package org.elasticsearch.transport
 
org.elasticsearch.transport.local - package org.elasticsearch.transport.local
 
org.elasticsearch.transport.netty - package org.elasticsearch.transport.netty
 
org.elasticsearch.transport.support - package org.elasticsearch.transport.support
 
org.elasticsearch.tribe - package org.elasticsearch.tribe
 
org.elasticsearch.watcher - package org.elasticsearch.watcher
 
org.joda.time.base - package org.joda.time.base
 
orientation - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
 
orientation(ShapeBuilder.Orientation) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
ORIENTATION - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
 
ORIENTATION - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
 
orientation() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
orientationFromString(String) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
 
origin() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
origin() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
origin() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
origin() - Method in interface org.elasticsearch.index.engine.Engine.Operation
 
origin() - Method in class org.elasticsearch.index.mapper.SourceToParse
 
ORIGIN - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
 
originalChildQuery - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
OriginalIndices - Class in org.elasticsearch.action
Used to keep track of original indices within internal (e.g.
OriginalIndices(IndicesRequest) - Constructor for class org.elasticsearch.action.OriginalIndices
 
OriginalIndices(String[], IndicesOptions) - Constructor for class org.elasticsearch.action.OriginalIndices
 
originalIndices - Variable in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
originalMessage() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
 
originalQuery() - Method in class org.elasticsearch.search.highlight.HighlighterContext.HighlightQuery
 
originalTerm - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
 
os() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Should the node OS be returned.
os(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
Should the node OS be returned.
os() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node OS be returned.
os(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node OS be returned.
OS_NAME - Static variable in class org.elasticsearch.common.os.OsUtils
The value of System.getProperty("os.name").
osInfo() - Method in class org.elasticsearch.monitor.os.JmxOsProbe
 
OsInfo - Class in org.elasticsearch.monitor.os
 
osInfo() - Method in interface org.elasticsearch.monitor.os.OsProbe
 
OsInfo.Cpu - Class in org.elasticsearch.monitor.os
 
OsInfo.Mem - Class in org.elasticsearch.monitor.os
 
OsInfo.Swap - Class in org.elasticsearch.monitor.os
 
OsProbe - Interface in org.elasticsearch.monitor.os
 
osService() - Method in class org.elasticsearch.monitor.MonitorService
 
OsService - Class in org.elasticsearch.monitor.os
 
OsService(Settings, OsProbe) - Constructor for class org.elasticsearch.monitor.os.OsService
 
OsStats() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
 
osStats() - Method in class org.elasticsearch.monitor.os.JmxOsProbe
 
osStats() - Method in interface org.elasticsearch.monitor.os.OsProbe
 
OsStats - Class in org.elasticsearch.monitor.os
 
OsStats.Cpu - Class in org.elasticsearch.monitor.os
 
OsStats.Mem - Class in org.elasticsearch.monitor.os
 
OsStats.Swap - Class in org.elasticsearch.monitor.os
 
OsUtils - Class in org.elasticsearch.common.os
 
otherDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
otherStatsToXCotent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
 
otherStatsToXCotent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
out - Variable in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
out - Variable in class org.elasticsearch.common.lucene.store.FilterIndexOutput
 
OutOfScopeException - Exception in org.elasticsearch.common.inject
Thrown from Provider.get() when an attempt is made to access a scoped object while the scope in question is not currently active.
OutOfScopeException(String) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
 
OutOfScopeException(String, Throwable) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
 
OutOfScopeException(Throwable) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
 
OutputStreamIndexOutput - Class in org.elasticsearch.common.lucene.store
 
OutputStreamIndexOutput(IndexOutput) - Constructor for class org.elasticsearch.common.lucene.store.OutputStreamIndexOutput
 
OutputStreamStreamOutput - Class in org.elasticsearch.common.io.stream
 
OutputStreamStreamOutput(OutputStream) - Constructor for class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
 
outRsts() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
outSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
override(Module...) - Static method in class org.elasticsearch.common.inject.util.Modules
Returns a builder that creates a module that overlays override modules over the given modules.
override(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.util.Modules
Returns a builder that creates a module that overlays override modules over the given modules.
overridePath(ContentPath) - Method in class org.elasticsearch.index.mapper.ParseContext
Return a new context that will have the provided path.
overSize(long) - Static method in class org.elasticsearch.common.util.BigArrays
Returns the next size to grow when working with parallel arrays that may have different page sizes or number of bytes per element.
overSize(long, int, int) - Static method in class org.elasticsearch.common.util.BigArrays
Return the next size to grow to that is >= minTargetSize.

P

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, FieldMapper.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
 
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
 
PageCacheRecyclerModule - Class in org.elasticsearch.cache.recycler
 
PageCacheRecyclerModule(Settings) - Constructor for class org.elasticsearch.cache.recycler.PageCacheRecyclerModule
 
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, FieldMapper.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, Object) - Method in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionBuilder
Additional parameters that can be provided to the script.
param(String) - Method in class org.elasticsearch.rest.RestRequest
 
param(String, Object) - Method in class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
 
param(String, Object) - Method in class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
Sets the value of a parameter that is used in the script (if one is configured).
param(String, Object) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
 
param(String, Object) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
param(String, Object) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
 
param(String, Object) - Method in class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
 
param(String, Object) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
A parameter that will be passed to the script.
param(String, Object) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
A parameter that will be passed to the script.
param(String, Object) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
Adds a parameter to the script.
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
 
paramAsBooleanOptional(String, Boolean) - Method in class org.elasticsearch.common.xcontent.ToXContent.DelegatingMapParams
Deprecated.
paramAsBooleanOptional(String, Boolean) - Method in class org.elasticsearch.common.xcontent.ToXContent.MapParams
Deprecated.
paramAsBooleanOptional(String, Boolean) - Method in interface org.elasticsearch.common.xcontent.ToXContent.Params
Deprecated.
paramAsBooleanOptional(String, Boolean) - Method in class org.elasticsearch.rest.RestRequest
Deprecated.
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(Map<String, Object>) - Method in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionBuilder
Additional parameters that can be provided to the script.
params(Map<String, Object>) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
 
PARAMS - Static variable in class org.elasticsearch.index.query.TemplateQueryParser
Name of query parameter containing the template parameters.
params() - Method in class org.elasticsearch.index.query.TemplateQueryParser.TemplateContext
 
params() - Method in class org.elasticsearch.rest.RestRequest
 
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(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
 
params(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
Sets the values of a parameters that are used in the script (if one is configured).
PARAMS_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricParser
 
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.termvector.TermVectorRequest
Sets the parent id of this document.
parent(String) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the parent id of this document.
parent() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
parent() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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 - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
parent() - Method in class org.elasticsearch.search.aggregations.Aggregator
 
parent - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
 
parent() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
 
ParentChild(ParentChildIndexFieldData, ValuesSource.MetaData) - 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, FieldMapper.Names, FieldDataType, IndexFieldDataCache, MapperService, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.plain.ParentChildIndexFieldData
 
ParentChildIndexFieldData.Builder - 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, Query, Map<String, InnerHitsContext.BaseInnerHits>, 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
 
ParentConstantScoreQuery - Class in org.elasticsearch.index.search.child
A query that only return child documents that are linked to the parent documents that matched with the inner query.
ParentConstantScoreQuery(ParentChildIndexFieldData, Query, String, Filter) - Constructor for class org.elasticsearch.index.search.child.ParentConstantScoreQuery
 
parentFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
ParentFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
ParentFieldMapper(String, String, String, PostingsFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
ParentFieldMapper(Settings) - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
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
 
parentFilter - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
parentIdxs - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
ParentQuery - Class in org.elasticsearch.index.search.child
A query implementation that executes the wrapped parent query and connects the matching parent docs to the related child documents using the ParentChildIndexFieldData.
ParentQuery(ParentChildIndexFieldData, Query, String, Filter) - Constructor for class org.elasticsearch.index.search.child.ParentQuery
 
ParentScoreCollector(IndexParentChildFieldData, SearchContext, String) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCollector
 
ParentScoreCountCollector(IndexParentChildFieldData, SearchContext, String) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery.ParentScoreCountCollector
 
ParentToChildrenAggregator - Class in org.elasticsearch.search.aggregations.bucket.children
 
ParentToChildrenAggregator(String, AggregatorFactories, AggregationContext, Aggregator, String, Filter, Filter, ValuesSource.Bytes.ParentChild, long) - 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
 
parentType - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
ParentWeight(Weight, Filter, long, ChildrenQuery.ParentCollector, int, int) - Constructor for class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
parse(String) - Method in class org.apache.lucene.queryparser.classic.MapperQueryParser
 
parse(String) - Static method in enum org.elasticsearch.cache.recycler.CacheRecycler.Type
 
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.operation.plain.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
Create a new ShapeBuilder from XContent
parse(XContentParser, GeoShapeFieldMapper) - Static method in class org.elasticsearch.common.geo.builders.ShapeBuilder
Create a new ShapeBuilder from XContent
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(ParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.CopyTo
Creates instances of the fields that the current field should be copied to
parse(String, ParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.CopyTo
Creates an copy of the current field with given field name and boost
parse(AbstractFieldMapper, ParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields
 
parse(ParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
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
 
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.Murmur3FieldMapper.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(BytesReference) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
parse(String, String, BytesReference) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
parse(SourceToParse) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
parse(SourceToParse, DocumentMapper.ParseListener) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
parse(String) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
parse(String, String) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
parse(String, String, String) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
parse(String, FieldMapper.Loading) - Static method in enum org.elasticsearch.index.mapper.FieldMapper.Loading
 
parse(ParseContext) - 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(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.AnalyzerMapper
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper.TypeParser
 
parse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper.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(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
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.SizeFieldMapper
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.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(ParseContext) - Method in interface org.elasticsearch.index.mapper.Mapper
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in interface org.elasticsearch.index.mapper.Mapper.TypeParser
 
parse(String, CompressedString, boolean) - Method in class org.elasticsearch.index.mapper.MapperService
 
parse(String, Map<String, Object>) - Static method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
parse(ParseContext) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
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.AndFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.BoolFilterParser
 
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.ExistsFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FilteredQueryParser
 
parse(QueryParseContext) - Method in interface org.elasticsearch.index.query.FilterParser
Parses the into a filter from the current parser location.
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FQueryFilterParser
 
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.FuzzyLikeThisFieldQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.FuzzyQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoDistanceFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeohashCellFilter.Parser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoPolygonFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoShapeFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.GeoShapeQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.HasChildFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.HasChildQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.HasParentFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.HasParentQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.IdsFilterParser
 
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.IndicesFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.IndicesQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.LimitFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MatchAllFilterParser
 
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.MissingFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryParser
Deprecated.
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryParser
 
parse(String) - Static method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
 
parse(String, EnumSet<ParseField.Flag>) - 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.NestedFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.NestedQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.NotFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.NumericRangeFilterParser
Deprecated.
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.OrFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.PrefixFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.PrefixQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.QueryFilterParser
 
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.RangeFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.RangeQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.RegexpFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.RegexpQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.ScriptFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SimpleQueryStringParser
 
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.support.InnerHitsQueryParserHelper
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TemplateQueryParser
Parses the template query replacing template parameters with provided values.
parse(XContentParser, String, String...) - Static method in class org.elasticsearch.index.query.TemplateQueryParser
 
parse(XContentParser, String) - Static method in class org.elasticsearch.index.query.TemplateQueryParser
 
parse(XContentParser, String, Map<String, ScriptService.ScriptType>) - Static method in class org.elasticsearch.index.query.TemplateQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TermFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TermQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TermsFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TermsQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TopChildrenQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.TypeFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.WildcardQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.WrapperFilterParser
 
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(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) - Static method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
 
parse(String, EnumSet<ParseField.Flag>) - 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(XContentParser) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDParser
 
parse(XContentParser) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore.JLHScoreParser
 
parse(XContentParser) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYParser
 
parse(XContentParser) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore.PercentageScoreParser
 
parse(XContentParser) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicParser
 
parse(XContentParser) - 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.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(String) - Static method in class org.elasticsearch.search.aggregations.support.OrderPath
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetParser
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.FacetBinaryParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.FacetParseElement
 
parse(String, XContentParser, SearchContext) - Method in interface org.elasticsearch.search.facet.FacetParser
Parses the facet into a FacetExecutor.
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.filter.FilterFacetParser
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetParser
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetParser
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.query.QueryFacetParser
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.range.RangeFacetParser
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetParser
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.terms.TermsFacetParser
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetParser
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.explain.ExplainParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.fielddata.FieldDataFieldsParseElement
 
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.partial.PartialFieldsParseElement
 
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.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
Parses the RescoreSearchContext for this impelementation
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) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestParser
 
parse(XContentParser, MapperService) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestParser
 
parse(XContentParser, MapperService) - Method in interface org.elasticsearch.search.suggest.SuggestContextParser
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.suggest.SuggestParseElement
 
parse(XContentParser, MapperService) - 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, Version) - 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 true iff the sequence is neither of the following: false, 0, off, no, otherwise false
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
 
parseBytesSizeValue(String) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
 
parseBytesSizeValue(String, ByteSizeValue) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
 
parseBytesSizeValueOrHeapRatio(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
 
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, Version, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
 
parseCompressed(String, CompressedString) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
parseCompressed(String, CompressedString, String) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
parseConfig(Map<String, Object>, boolean) - 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
A ContextMapping combined with the information provided by a document form a ContextMapping.ContextConfig which is used to build the underlying FST.
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, AbstractFieldMapper.Builder) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parseCreateField(ParseContext, List<Field>) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
Parse the field value and populate fields.
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.geo.GeoPointFieldMapper
 
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.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>, Analyzer, BytesReference, boolean) - Constructor for class org.elasticsearch.index.mapper.ParsedDocument
 
parsedFilter() - Method in class org.elasticsearch.index.aliases.IndexAlias
 
ParsedFilter - Class in org.elasticsearch.index.query
 
ParsedFilter(Filter, ImmutableMap<String, Filter>) - Constructor for class org.elasticsearch.index.query.ParsedFilter
 
parseDirectSpellcheckerSettings(XContentParser, String, DirectSpellcheckerSettings) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
 
parseDistance(String) - Static method in class org.elasticsearch.common.unit.DistanceUnit.Distance
Parse a DistanceUnit.Distance from a given String.
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.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
 
parseDoubleValue(Object) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Converts an object value into a double
parsedPostFilter(ParsedFilter) - Method in class org.elasticsearch.percolator.PercolateContext
 
parsedPostFilter() - Method in class org.elasticsearch.percolator.PercolateContext
 
parsedPostFilter(ParsedFilter) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
parsedPostFilter() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
parsedPostFilter(ParsedFilter) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
parsedPostFilter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
parsedPostFilter(ParsedFilter) - Method in class org.elasticsearch.search.internal.SearchContext
 
parsedPostFilter() - Method in class org.elasticsearch.search.internal.SearchContext
 
parsedPostFilter(ParsedFilter) - 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, Filter>) - 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
 
ParsedScrollId - Class in org.elasticsearch.action.search.type
 
ParsedScrollId(String, String, Tuple<String, Long>[], Map<String, String>) - Constructor for class org.elasticsearch.action.search.type.ParsedScrollId
 
parseDynamicValue(ParseContext, String, XContentParser.Token) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
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.facet.FacetPhase
 
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.partial.PartialFieldsFetchSubPhase
 
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
 
ParseField(String, String...) - Constructor for class org.elasticsearch.common.ParseField
 
parseField(AbstractFieldMapper.Builder, String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parseField() - Method in enum org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
 
parseField() - Method in enum org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
 
ParseField.Flag - Enum in org.elasticsearch.common
 
parseFields(XContentParser, IndexQueryParserService) - Method in class org.elasticsearch.search.highlight.HighlighterParseElement
 
parseFlags(EnumSet<ParseField.Flag>) - Method in class org.elasticsearch.index.query.QueryParseContext
 
parseFlags() - Method in class org.elasticsearch.index.query.QueryParseContext
 
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, ShapeBuilder.Orientation) - 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
Parse a GeoPoint with a XContentParser:
parseGeoPoint(XContentParser, GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
Parse a GeoPoint with a XContentParser.
parseGroup(MatchQuery.Type, String, Float, Object, String) - Method in class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
 
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, AbstractFieldMapper.Builder) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
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
 
parseInternal(XContentParser, MapperService, String, int) - Method in class org.elasticsearch.search.suggest.SuggestParseElement
 
parseLambda(Settings) - Method in class org.elasticsearch.index.similarity.IBSimilarityProvider
Parses the given Settings and creates the appropriate Lambda
parseLinearRing(ShapeBuilder.CoordinateNode) - 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
 
ParseListenerAdapter() - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.ParseListenerAdapter
 
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) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Converts an object value into a long
parseMultiField(AbstractFieldMapper.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) - 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.merge.policy.AbstractMergePolicyProvider
 
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, 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) - 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
Parse a set of ContextMapping.ContextQuery according to a given mapping
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.GeohashCellFilter.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(String, InternalAggregation.Type, SearchContext) - 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
 
parser(String) - Method in class org.elasticsearch.search.facet.FacetParsers
 
parseRatioValue(String) - Static method in class org.elasticsearch.common.unit.RatioValue
Parses the provided string as a RatioValue, the string can either be in percentage format (eg.
parserContext() - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
ParserContext(PostingsFormatService, DocValuesFormatService, AnalysisService, SimilarityLookupService, ImmutableMap<String, Mapper.TypeParser>, Version) - Constructor for class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
 
parseRequest(TermVectorRequest, XContentParser) - Static method in class org.elasticsearch.action.termvector.TermVectorRequest
populates a request object (pre-populated with defaults) based on a parser.
parseRewriteMethod(String) - Static method in class org.elasticsearch.index.query.support.QueryParsers
 
parseRewriteMethod(String, MultiTermQuery.RewriteMethod) - Static method in class org.elasticsearch.index.query.support.QueryParsers
 
parseScrollId(String) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
parseSearchRequest(RestRequest) - 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, Version) - Static method in class org.elasticsearch.index.analysis.Analysis
 
parseStopWords(Environment, Settings, CharArraySet, Version) - Static method in class org.elasticsearch.index.analysis.Analysis
 
parseStopWords(Environment, Settings, CharArraySet, Version, 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) - Static method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
parseStringValue(String, PropertyPlaceholder.PlaceholderResolver, Set<String>) - Method in class org.elasticsearch.common.property.PropertyPlaceholder
 
parseSuggestContext(XContentParser, MapperService, String, SuggestionSearchContext.SuggestionContext) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
 
parseTermVector(String, String, AbstractFieldMapper.Builder) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parseTimeValue(String, TimeValue) - Static method in class org.elasticsearch.common.unit.TimeValue
 
parseToMilliseconds(Object) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
parseToMilliseconds(Object, boolean, DateTimeZone, DateMathParser) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
parseToMilliseconds(String, boolean, DateTimeZone, DateMathParser) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
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
 
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, ImmutableMap<String, Set<?>>, Version, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
 
parseZone(String) - Static method in class org.elasticsearch.common.joda.DateMathParser
 
parsingStillNeeded() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
Is parsing still needed?
partBytes() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
Return maximum number of bytes in a 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.repositories.blobstore.BlobStoreSnapshot.Builder
Marks snapshot as partially successful
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
partialField(String, String, String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Deprecated.
partialField(String, String[], String[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Deprecated.
PartialField(String, String[], String[]) - Constructor for class org.elasticsearch.search.fetch.partial.PartialFieldsContext.PartialField
 
partialFields() - Method in class org.elasticsearch.percolator.PercolateContext
 
partialFields() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
partialFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
partialFields() - Method in class org.elasticsearch.search.internal.SearchContext
 
PartialFieldsContext - Class in org.elasticsearch.search.fetch.partial
 
PartialFieldsContext() - Constructor for class org.elasticsearch.search.fetch.partial.PartialFieldsContext
 
PartialFieldsContext.PartialField - Class in org.elasticsearch.search.fetch.partial
 
PartialFieldsFetchSubPhase - Class in org.elasticsearch.search.fetch.partial
 
PartialFieldsFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.partial.PartialFieldsFetchSubPhase
 
PartialFieldsParseElement - Class in org.elasticsearch.search.fetch.partial
"partial_fields" : { "test1" : { "includes" : "doc['field_name'].value" }, "test2" : { "excludes" : "..." } }
PartialFieldsParseElement() - Constructor for class org.elasticsearch.search.fetch.partial.PartialFieldsParseElement
 
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
passiveOpens() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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 - Static variable in class org.elasticsearch.index.mapper.internal.AnalyzerMapper.Defaults
 
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.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.core.AbstractFieldMapper.Defaults
 
PATH_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
PATH_TYPE - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Defaults
 
pathAsText(String) - Method in class org.elasticsearch.index.mapper.ContentPath
 
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, Settings, 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() - Constructor for class org.elasticsearch.common.path.PathTrie
 
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.core.AbstractFieldMapper.MultiFields.Builder
 
pathType - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
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
 
PatternAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
PatternAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternAnalyzerProvider
 
PatternCaptureGroupTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
PatternCaptureGroupTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternCaptureGroupTokenFilterFactory
 
PatternReplaceCharFilterFactory - Class in org.elasticsearch.index.analysis
 
PatternReplaceCharFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternReplaceCharFilterFactory
 
PatternReplaceTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
PatternReplaceTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternReplaceTokenFilterFactory
 
PatternTokenizerFactory - Class in org.elasticsearch.index.analysis
 
PatternTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternTokenizerFactory
 
payload() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryResponse
 
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.termvector.TermVectorRequest
 
payloads(boolean) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
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
 
payloadScore - Variable in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
payloadsSeen - Variable in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
pb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
pbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
peakCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
peakMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
peakUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
peek() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
 
PeerRecoveryStatus - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
PeerRecoveryStatus(PeerRecoveryStatus.Stage, long, long, long, long, long, long) - Constructor for class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
Deprecated.
 
PeerRecoveryStatus.Stage - Enum in org.elasticsearch.action.admin.indices.status
Deprecated.
 
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.
pendingClusterTasks(PendingClusterTasksRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
pendingClusterTasks(PendingClusterTasksRequest, ActionListener<PendingClusterTasksResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequestBuilder
 
PendingClusterTasksResponse - Class in org.elasticsearch.action.admin.cluster.tasks
 
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
 
Percent - Class in org.elasticsearch.common.unit
 
Percent(double) - Constructor for class org.elasticsearch.common.unit.Percent
 
percent() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu usage.
percent(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentileRanks
 
percent(double) - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanks
Return the percentile for the given value.
PERCENT_TERMS_TO_MATCH - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
PERCENTAGE - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
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.InternalPercentileRanks
 
percentAsString(double) - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanks
Return the percentile for the given value as a String.
percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
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.
percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
percentileAsString(double) - Method in interface org.elasticsearch.search.aggregations.metrics.percentiles.Percentiles
Return the value associated with the provided percentile as a String.
percentileRanks(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new PercentileRanks aggregation with the given name.
PercentileRanks - Interface in org.elasticsearch.search.aggregations.metrics.percentiles
An aggregation that computes approximate percentiles given values.
PercentileRanksAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
PercentileRanksAggregator(String, long, ValuesSource.Numeric, AggregationContext, Aggregator, double[], double, boolean, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentileRanksAggregator
 
PercentileRanksAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
PercentileRanksBuilder - Class in org.elasticsearch.search.aggregations.metrics.percentiles
Builder for the PercentileRanks aggregation.
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.
PercentilesAggregator - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
PercentilesAggregator(String, long, ValuesSource.Numeric, AggregationContext, Aggregator, double[], double, boolean, ValueFormatter) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesAggregator
 
PercentilesAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
PercentilesBuilder - Class in org.elasticsearch.search.aggregations.metrics.percentiles
Builder for the Percentiles aggregation.
PercentilesBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesBuilder
Sole constructor.
PercentilesParser - Class in org.elasticsearch.search.aggregations.metrics.percentiles
 
PercentilesParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.percentiles.PercentilesParser
 
percentTermsToMatch(float) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Deprecated.
percentTermsToMatch() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Deprecated.
percentTermsToMatch(float) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
percentTermsToMatch(float) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Deprecated.
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(PercolateRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
percolate(PercolateRequest, ActionListener<PercolateResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
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, CacheRecycler, PageCacheRecycler, BigArrays, ScriptService, Filter) - Constructor for class org.elasticsearch.percolator.PercolateContext
 
PercolateException - Exception in org.elasticsearch.percolator
Exception during percolating document(s) at runtime.
PercolateException(String, ShardId) - Constructor for exception org.elasticsearch.percolator.PercolateException
 
PercolateException(ShardId, String, Throwable) - 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(Client) - 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
 
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) - Constructor for exception org.elasticsearch.index.percolator.PercolatorException
 
PercolatorException(Index, String, Throwable) - 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
Each shard will have a percolator registry even if there isn't a PercolatorService.TYPE_NAME document type in the index.
PercolatorQueriesRegistry(ShardId, Settings, IndexQueryParserService, ShardIndexingService, IndicesLifecycle, MapperService, IndexCache, IndexFieldDataService, ShardPercolateService) - Constructor for class org.elasticsearch.index.percolator.PercolatorQueriesRegistry
 
PercolatorService - Class in org.elasticsearch.percolator
 
PercolatorService(Settings, IndicesService, CacheRecycler, PageCacheRecycler, BigArrays, HighlightPhase, ClusterService, FacetPhase, AggregationPhase, ScriptService, MappingUpdatedAction) - Constructor for class org.elasticsearch.percolator.PercolatorService
 
PercolatorService.ReduceResult - Class in org.elasticsearch.percolator
 
PercolatorShardModule - Class in org.elasticsearch.index.percolator
 
PercolatorShardModule() - Constructor for class org.elasticsearch.index.percolator.PercolatorShardModule
 
percolatorTypeId() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
 
percolatorTypeId - Variable in class org.elasticsearch.percolator.PercolateContext
 
perFieldAnalyzer() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Return the overridden analyzers at each field
perFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Override the analyzer used at each field when generating term vectors
PerFieldMappingPostingFormatCodec - Class in org.elasticsearch.index.codec
This postings format is the default PostingsFormat for Elasticsearch.
PerFieldMappingPostingFormatCodec(MapperService, PostingsFormat, DocValuesFormat, ESLogger) - Constructor for class org.elasticsearch.index.codec.PerFieldMappingPostingFormatCodec
 
performOperation(ShardIterator, ShardRouting, int) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction.AsyncBroadcastAction
 
performRecoveryOperation(Translog.Operation) - Method in class org.elasticsearch.index.shard.IndexShard
Performs a single recovery operation, and returns the indexing operation (or null if its not an indexing operation) that can then be used for mapping updates (for example) if needed.
performRecoveryRestart() - Method in class org.elasticsearch.index.shard.IndexShard
called if recovery has to be restarted after network error / delay **
performStateRecovery(Gateway.GatewayStateRecoveredListener) - Method in interface org.elasticsearch.gateway.Gateway
 
performStateRecovery(Gateway.GatewayStateRecoveredListener) - Method in class org.elasticsearch.gateway.local.LocalGateway
 
performStateRecovery(Gateway.GatewayStateRecoveredListener) - Method in class org.elasticsearch.gateway.none.NoneGateway
 
PersianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
PersianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PersianAnalyzerProvider
 
PersianNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
 
PersianNormalizationFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PersianNormalizationFilterFactory
 
persistent() - Method in class org.elasticsearch.index.store.fs.FsIndexStore
 
persistent() - Method in interface org.elasticsearch.index.store.IndexStore
Is the store a persistent store that can survive full restarts.
persistent() - Method in class org.elasticsearch.index.store.ram.RamIndexStore
 
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) - Method in interface org.elasticsearch.index.engine.Engine.RecoveryHandler
 
phase1(SnapshotIndexCommit) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
Perform phase1 of the recovery operations.
phase1(SnapshotIndexCommit) - Method in class org.elasticsearch.indices.recovery.SharedFSRecoverySourceHandler
 
phase2(Translog.Snapshot) - Method in interface org.elasticsearch.index.engine.Engine.RecoveryHandler
 
phase2(Translog.Snapshot) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
Perform phase2 of the recovery process Phase2 takes a snapshot of the current translog *without* acquiring the write lock (however, the translog snapshot is a point-in-time view of the translog).
phase2(Translog.Snapshot) - Method in class org.elasticsearch.indices.recovery.SharedFSRecoverySourceHandler
 
phase3(Translog.Snapshot) - Method in interface org.elasticsearch.index.engine.Engine.RecoveryHandler
 
phase3(Translog.Snapshot) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
Perform phase 3 of the recovery process Phase3 again takes a snapshot of the translog, however this time the snapshot is acquired under a write lock.
phase3(Translog.Snapshot) - Method in class org.elasticsearch.indices.recovery.SharedFSRecoverySourceHandler
 
phaseName() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
 
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(Client, ScriptService) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggester
 
PhraseSuggestion - Class in org.elasticsearch.search.suggest.phrase
Suggestion entry returned from the PhraseSuggester.
PhraseSuggestion() - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
 
PhraseSuggestion(String, int) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
 
phraseSuggestion(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
CandidateGenerator base class.
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
A "stupid-backoff" smoothing model simialr to Katz's Backoff.
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.gateway.CommitPoint.FileInfo
 
physicalName() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
Returns original file name
pick(SortedNumericDocValues, long) - Method in enum org.elasticsearch.search.MultiValueMode
 
pick(SortedNumericDoubleValues, double) - Method in enum org.elasticsearch.search.MultiValueMode
 
pick(SortedBinaryDocValues, BytesRef) - Method in enum org.elasticsearch.search.MultiValueMode
 
pick(RandomAccessOrds) - Method in enum org.elasticsearch.search.MultiValueMode
 
pid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
The process id.
ping(ZenPing.PingListener, TimeValue) - Method in class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
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
 
pingAndWait(TimeValue) - Method in class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
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
 
pingInterval - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
 
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
 
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(boolean, ThreadPool) - Constructor for class org.elasticsearch.action.support.PlainListenableActionFuture
 
PlainOperationRouting - Class in org.elasticsearch.cluster.routing.operation.plain
 
PlainOperationRouting(Settings, HashFunction, AwarenessAllocationDecider) - Constructor for class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
PlainOperationRoutingModule - Class in org.elasticsearch.cluster.routing.operation.plain
 
PlainOperationRoutingModule() - Constructor for class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRoutingModule
 
PlainShardIterator - Class in org.elasticsearch.cluster.routing
The PlainShardIterator is a ShardsIterator which iterates all shards or a given shard id
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
A simple ShardsIterator that iterates a list or sub-list of shard routings.
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 - Interface in org.elasticsearch.plugins
An extension point allowing to plug in custom functionality.
PluginInfo - Class in org.elasticsearch.action.admin.cluster.node.info
 
PluginInfo() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
PluginInfo(String, String, boolean, boolean, String) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
Information about plugins
PluginManager - Class in org.elasticsearch.plugins
 
PluginManager(Environment, String, PluginManager.OutputMode, TimeValue) - Constructor for class org.elasticsearch.plugins.PluginManager
 
PluginManager.ACTION - Class in org.elasticsearch.plugins
 
PluginManager.OutputMode - Enum in org.elasticsearch.plugins
 
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
 
plugins() - Method in class org.elasticsearch.plugins.PluginsService
 
pluginsFile() - Method in class org.elasticsearch.env.Environment
 
PluginsInfo - Class in org.elasticsearch.action.admin.cluster.node.info
 
PluginsInfo() - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginsInfo
 
PluginsInfo(int) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginsInfo
 
PluginsModule - Class in org.elasticsearch.plugins
 
PluginsModule(Settings, PluginsService) - Constructor for class org.elasticsearch.plugins.PluginsModule
 
PluginsService - Class in org.elasticsearch.plugins
 
PluginsService(Settings, Environment) - 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.GeoDistanceFilterBuilder
 
point(double, double) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
point(GeoPoint) - Method in class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
point(double, double) - Method in class org.elasticsearch.index.query.GeohashCellFilter.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.facet.geodistance.GeoDistanceFacetBuilder
The point to create the range distance facets 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
The PointCollection is an abstract base implementation for all GeoShapes.
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.GeoPolygonFilterBuilder
 
POINTS - Static variable in class org.elasticsearch.index.query.GeoPolygonFilterParser
 
points() - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
points(GeoPoint...) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
The point to create the range distance facets from.
poll() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
 
poll(long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
 
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
 
popCachedStream() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
port - Variable in class org.elasticsearch.common.network.MulticastChannel.Config
 
port - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
PorterStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
PorterStemTokenFilterFactory(Index, Settings, 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, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PortugueseAnalyzerProvider
 
pos - Variable in class org.elasticsearch.common.io.FastCharArrayReader
The current buffer position.
pos - Variable in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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.AdapterStreamOutput
 
position() - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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.index.translog.fs.FsChannelSnapshot
 
position() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
Returns the current position in the translog stream
position() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
position - Variable in class org.elasticsearch.search.lookup.TermPosition
 
POSITION_OFFSET_GAP - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
 
PositionIterator - Class in org.elasticsearch.search.lookup
 
PositionIterator(IndexFieldTerm) - Constructor for class org.elasticsearch.search.lookup.PositionIterator
 
positionOffsetGap - Variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
positionOffsetGap(int) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
positions(boolean) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Return the positions for each term if stored or skip.
positions() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
positions - Variable in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
positive(QueryBuilder) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
 
POSITIVE_INTEGER - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
possibleMergeNeeded() - Method in class org.elasticsearch.index.engine.Engine
Returns true if a possible merge is really needed.
possibleMergeNeeded() - Method in class org.elasticsearch.index.engine.InternalEngine
 
possibleMergeNeeded() - Method in class org.elasticsearch.index.engine.ShadowEngine
 
post(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
 
post() - Method in class org.elasticsearch.search.facet.FacetExecutor
A post based facet that executes the facet using the aggregated docs.
Post() - Constructor for class org.elasticsearch.search.facet.FacetExecutor.Post
 
post() - Method in class org.elasticsearch.search.facet.filter.FilterFacetExecutor
 
post() - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor
 
Post(FacetExecutor.Post, Filter, Filter) - Constructor for class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Post
 
Post(NestedFacetExecutor.Post, Filter) - Constructor for class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Post
 
post() - Method in class org.elasticsearch.search.facet.query.QueryFacetExecutor
 
postAdded() - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
 
postCollection() - Method in class org.elasticsearch.common.lucene.MultiCollector
 
postCollection() - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
 
postCollection() - Method in class org.elasticsearch.common.lucene.search.XCollector
 
postCollection() - Method in class org.elasticsearch.search.aggregations.AggregationPhase.AggregationsCollector
 
postCollection() - Method in class org.elasticsearch.search.aggregations.Aggregator
Called after collection of all document is done.
postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
 
postCollection() - Method in class org.elasticsearch.search.aggregations.BucketCollector
Post collection callback.
postCollection() - Method in class org.elasticsearch.search.aggregations.FilteringBucketCollector
 
postCollection() - Method in class org.elasticsearch.search.aggregations.RecordingPerReaderBucketCollector
 
postCollection() - Method in class org.elasticsearch.search.facet.FacetExecutor.Collector
 
postCollection() - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Collector
 
postCollection() - Method in class org.elasticsearch.search.internal.DocIdSetCollector
 
postCreate(Engine.Create) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
Called after the indexing operation occurred.
postCreate(Engine.Create) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
postCreate(Engine.Create, long) - Method in class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService
 
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) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
postDeleteByQuery(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
 
postDeleteByQuery(Engine.DeleteByQuery) - 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(FilterBuilder) - 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 or facets).
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 facets 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 facets 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 facets 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 facets 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) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
postIndex(Engine.Index, long) - Method in class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService
 
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
 
PostingFormats - Class in org.elasticsearch.index.codec.postingsformat
This class represents the set of Elasticsearch "built-in" postings format factories default: the default Lucene postings format offering best general purpose performance.
PostingFormats() - Constructor for class org.elasticsearch.index.codec.postingsformat.PostingFormats
 
postingFormatService() - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
 
POSTINGS_FORMAT_SETTINGS_PREFIX - Static variable in interface org.elasticsearch.index.codec.postingsformat.PostingsFormatProvider
 
postingsFormat(PostingsFormatProvider) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
postingsFormat - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
postingsFormat - Variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
 
postingsFormat(PostingsFormatProvider) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
 
PostingsFormatProvider - Interface in org.elasticsearch.index.codec.postingsformat
A PostingsFormatProvider acts as a named container for specific PostingsFormat implementations.
postingsFormatProvider() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
postingsFormatProvider() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
postingsFormatProvider() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
PostingsFormatProvider.Factory - Interface in org.elasticsearch.index.codec.postingsformat
A simple factory used to create PostingsFormatProvider used by delegating providers.
PostingsFormatProvider.Helper - Class in org.elasticsearch.index.codec.postingsformat
A helper class to lookup providers by their unique name
postingsFormatService() - Method in class org.elasticsearch.index.codec.CodecService
 
PostingsFormatService - Class in org.elasticsearch.index.codec.postingsformat
The PostingsFormatService provides access to all configured PostingsFormatProvider instances by name.
PostingsFormatService(Index) - Constructor for class org.elasticsearch.index.codec.postingsformat.PostingsFormatService
 
PostingsFormatService(Index, Settings) - Constructor for class org.elasticsearch.index.codec.postingsformat.PostingsFormatService
 
PostingsFormatService(Index, Settings, Map<String, PostingsFormatProvider.Factory>) - Constructor for class org.elasticsearch.index.codec.postingsformat.PostingsFormatService
 
PostingsHighlighter - Class in org.elasticsearch.search.highlight
 
PostingsHighlighter() - Constructor for class org.elasticsearch.search.highlight.PostingsHighlighter
 
postingsProvider - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
postOffset(long) - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
postOffset(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Deprecated.
the postOffset option will be replaced by offset in future version.
postOffset(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramBuilder
Set the offset to apply after having computed buckets.
postOffset(TimeValue) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Sets a post offset that will be applied after rounding the results.
postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
postParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
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.SizeFieldMapper
 
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 interface org.elasticsearch.index.mapper.RootMapper
postPercolate(long) - Method in class org.elasticsearch.index.percolator.stats.ShardPercolateService
 
postPrimaryOperation(TransportShardReplicationOperationAction<Request, ReplicaRequest, Response>.InternalRequest, TransportShardReplicationOperationAction.PrimaryResponse<Response, ReplicaRequest>) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
Called once replica operations have been dispatched on the
postProcess(MapperService) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
postProcess(DocumentMapper) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
postProcess(FieldMapper) - 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.ShardSuggestService
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
 
postZone(DateTimeZone) - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
postZone(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Deprecated.
this option is going to be removed in 2.0 releases
postZone(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Sets the post time zone to use when bucketing the values.
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
 
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
 
PreBuiltDocValuesFormatProvider - Class in org.elasticsearch.index.codec.docvaluesformat
Pre-built format provider which accepts no configuration option.
PreBuiltDocValuesFormatProvider(DocValuesFormat) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider
 
PreBuiltDocValuesFormatProvider(String, DocValuesFormat) - Constructor for class org.elasticsearch.index.codec.docvaluesformat.PreBuiltDocValuesFormatProvider
 
PreBuiltDocValuesFormatProvider.Factory - Class in org.elasticsearch.index.codec.docvaluesformat
 
PreBuiltPostingsFormatProvider - Class in org.elasticsearch.index.codec.postingsformat
 
PreBuiltPostingsFormatProvider(PostingsFormat) - Constructor for class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider
 
PreBuiltPostingsFormatProvider(String, PostingsFormat) - Constructor for class org.elasticsearch.index.codec.postingsformat.PreBuiltPostingsFormatProvider
 
PreBuiltPostingsFormatProvider.Factory - Class in org.elasticsearch.index.codec.postingsformat
 
PreBuiltSimilarityProvider - Class in org.elasticsearch.index.similarity
SimilarityProvider for pre-built Similarities
PreBuiltSimilarityProvider(String, Similarity) - Constructor for class org.elasticsearch.index.similarity.PreBuiltSimilarityProvider
Creates a new PreBuiltSimilarityProvider with the given name and given pre-built Similarity
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 - Static variable in class org.elasticsearch.common.geo.GeoHashUtils
 
precision() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Encoding
 
precision(int) - Method in class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
precision(String) - Method in class org.elasticsearch.index.query.GeohashCellFilter.Builder
 
PRECISION - Static variable in class org.elasticsearch.index.query.GeohashCellFilter
 
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.
precisionStep(int) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
 
precisionStep - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
precisionStep() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
precisionStep(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.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.Aggregator
 
Preconditions - Class in org.elasticsearch.common
Simple static methods to be called at the start of your own methods to verify correct arguments and state.
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
 
preDeleteByQuery(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.indexing.IndexingOperationListener
 
preDeleteByQuery(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
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
 
preference() - Method in class org.elasticsearch.action.count.CountRequest
 
preference(String) - Method in class org.elasticsearch.action.exists.ExistsRequest
Routing preference for executing the search on shards
preference() - Method in class org.elasticsearch.action.exists.ExistsRequest
 
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(String) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsShardRequest
Sets the preference to execute the search.
preference() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsShardRequest
 
preference - Variable in class org.elasticsearch.action.termvector.TermVectorRequest
 
preference() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
preference(String) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Sets the preference to execute the search.
Preference - Enum in org.elasticsearch.cluster.routing.operation.plain
Routing Preference Type
preferLocal(boolean) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
if this operation hits a node with a local relevant shard, should it be preferred to be executed on, or just do plain round robin.
preferLocalShard() - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
if this operation hits a node with a local relevant shard, should it be preferred to be executed on, or just do plain round robin.
preferNodeActiveInitializingShardsIt(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
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
Create a new PrefixAnalyzer.
PrefixAnalyzer(Analyzer, char, Iterable<? extends CharSequence>) - Constructor for class org.apache.lucene.analysis.PrefixAnalyzer
Create a new PrefixAnalyzer.
PrefixAnalyzer.PrefixTokenFilter - Class in org.apache.lucene.analysis
The PrefixAnalyzer.PrefixTokenFilter wraps a TokenStream and adds a set prefixes ahead.
prefixFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
prefixFilter(Object, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
prefixFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
prefixFilter(String, String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter that restricts search results to values that have a matching prefix in a given field.
PrefixFilterBuilder - Class in org.elasticsearch.index.query
A filter that restricts search results to values that have a matching prefix in a given field.
PrefixFilterBuilder(String, String) - Constructor for class org.elasticsearch.index.query.PrefixFilterBuilder
A filter that restricts search results to values that have a matching prefix in a given field.
PrefixFilterParser - Class in org.elasticsearch.index.query
 
PrefixFilterParser() - Constructor for class org.elasticsearch.index.query.PrefixFilterParser
 
prefixLength(int) - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
 
prefixLength(int) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
 
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(Object, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
prefixQuery(Object, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
prefixQuery(Object, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
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
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
 
preOffset(long) - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
preOffset(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Deprecated.
the preOffset option will be replaced by offset in future version.
preOffset(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramBuilder
Set the offset to apply prior to computing buckets.
preOffset(TimeValue) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Sets a pre offset that will be applied before rounding the results.
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_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.
prepareAliases() - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareAliasesExist(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Allows to check to existence of aliases from indices.
prepareAliasesExist(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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(String, String) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareAnalyze(String) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
 
prepareClearCache(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Clear indices cache.
prepareClearCache(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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.
prepareClose(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareClusterStats() - Method in interface org.elasticsearch.client.ClusterAdminClient
 
prepareClusterStats() - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareCount(String...) - Method in interface org.elasticsearch.client.Client
A count of all the documents matching a specific query.
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.
prepareCreate(String) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareCreate(SourceToParse, long, VersionType, Engine.Operation.Origin, boolean, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
 
prepareCreateSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
Creates a new snapshot.
prepareCreateSnapshot(String, String) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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
 
prepareDelete(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareDelete(String, String, long, VersionType, Engine.Operation.Origin) - Method in class org.elasticsearch.index.shard.IndexShard
 
prepareDeleteByQuery(String...) - Method in interface org.elasticsearch.client.Client
Deletes all documents from one or more indices based on a query.
prepareDeleteByQuery(String...) - Method in class org.elasticsearch.client.support.AbstractClient
 
prepareDeleteByQuery(BytesReference, String[], Engine.Operation.Origin, String...) - Method in class org.elasticsearch.index.shard.IndexShard
 
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
prepareDeleteMapping(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes mapping definition for a type into one or more indices.
prepareDeleteMapping(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareDeleteRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
Unregisters a repository.
prepareDeleteRepository(String) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareDeleteSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
Delete snapshot.
prepareDeleteSnapshot(String, String) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareDeleteTemplate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes an index template.
prepareDeleteTemplate(String) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareDeleteWarmer() - Method in interface org.elasticsearch.client.IndicesAdminClient
Deletes an index warmer.
prepareDeleteWarmer() - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareExecute(Action<Request, Response, RequestBuilder, Client>) - Method in interface org.elasticsearch.client.ElasticsearchClient
Prepares a request builder to execute, specified by Action.
prepareExecute(Action<Request, Response, RequestBuilder, Client>) - Method in class org.elasticsearch.client.support.AbstractClient
 
prepareExecute(Action<Request, Response, RequestBuilder, ClusterAdminClient>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareExecute(Action<Request, Response, RequestBuilder, IndicesAdminClient>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareExists(String...) - Method in interface org.elasticsearch.client.Client
Checks existence of any documents matching a specific query.
prepareExists(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices exists.
prepareExists(String...) - Method in class org.elasticsearch.client.support.AbstractClient
 
prepareExists(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
 
prepareFlush(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Explicitly flush one or more indices (releasing memory from the node).
prepareFlush(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareForIndexRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
called before starting to copy index files over
prepareForTranslogRecovery() - 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
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.
prepareGetAliases(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareGetFieldMappings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Get the mappings of specific fields
prepareGetFieldMappings(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareGetIndex() - Method in interface org.elasticsearch.client.IndicesAdminClient
Get index metadata for particular indices.
prepareGetIndex() - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
prepareGetMappings(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareGetRepositories(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
Gets repositories.
prepareGetRepositories(String...) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareGetSettings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Returns a builder for a per index settings get request.
prepareGetSettings(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareGetSnapshots(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
Get snapshot.
prepareGetSnapshots(String) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareGetTemplates(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Gets an index template (optional).
prepareGetTemplates(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareGetWarmers(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Returns a new builder to fetch index warmer metadata for the given indices.
prepareGetWarmers(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareHealth(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
The health of the cluster.
prepareHealth(String...) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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
 
prepareIndex(SourceToParse, long, VersionType, Engine.Operation.Origin, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
 
prepareMoreLikeThis(String, String, String) - Method in interface org.elasticsearch.client.Client
A more like this action to search for documents that are "like" a specific document.
prepareMoreLikeThis(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
 
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.
prepareNodesHotThreads(String...) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareNodesInfo(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
Nodes info of the cluster.
prepareNodesInfo(String...) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareNodesRestart(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
Restarts nodes in the cluster.
prepareNodesRestart(String...) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareNodesShutdown(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
Shutdown nodes in the cluster.
prepareNodesShutdown(String...) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareNodesStats(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
Nodes stats of the cluster.
prepareNodesStats(String...) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareOpen(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Opens one or more indices based on their index name.
prepareOpen(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareOptimize(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Explicitly optimize one or more indices into a the number of segments.
prepareOptimize(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
preparePendingClusterTasks() - Method in interface org.elasticsearch.client.ClusterAdminClient
Returns a list of the pending cluster tasks, that are scheduled to be executed.
preparePendingClusterTasks() - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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.
preparePutMapping(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
preparePutRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
Registers a snapshot repository.
preparePutRepository(String) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
preparePutTemplate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
Puts an index template.
preparePutTemplate(String) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
preparePutWarmer(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
Puts an index search warmer to be applies when applicable.
preparePutWarmer(String) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareRecoveries(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices recoveries
prepareRecoveries(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareRefresh(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Explicitly refresh one or more indices (making the content indexed since the last refresh searchable).
prepareRefresh(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareReroute() - Method in interface org.elasticsearch.client.ClusterAdminClient
Update settings in the cluster.
prepareReroute() - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareRestoreSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
Restores a snapshot.
prepareRestoreSnapshot(String, String) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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.
prepareSearchShards() - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareSearchShards(String...) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareSegments(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
The segments of one or more indices.
prepareSegments(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
Plays a selection of the data cached from previous collect calls to the deferred collector.
prepareSettings(Settings, boolean) - Static method in class org.elasticsearch.node.internal.InternalSettingsPreparer
 
prepareSnapshotStatus(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
Get snapshot status.
prepareSnapshotStatus() - Method in interface org.elasticsearch.client.ClusterAdminClient
Get snapshot status.
prepareSnapshotStatus(String) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareSnapshotStatus() - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareState() - Method in interface org.elasticsearch.client.ClusterAdminClient
The state of the cluster.
prepareState() - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareStats(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices stats.
prepareStats(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareStatus(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deprecated.
prepareStatus(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareSuggest(String...) - Method in interface org.elasticsearch.client.Client
Suggestions matching a specific phrase.
prepareSuggest(String...) - Method in class org.elasticsearch.client.support.AbstractClient
 
prepareTermVector() - Method in interface org.elasticsearch.client.Client
Builder for the term vector request.
prepareTermVector(String, String, String) - Method in interface org.elasticsearch.client.Client
Builder for the term vector request.
prepareTermVector() - Method in class org.elasticsearch.client.support.AbstractClient
 
prepareTermVector(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
 
prepareTypesExists(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices exists.
prepareTypesExists(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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.
prepareUpdateSettings() - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareUpdateSettings(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareValidateQuery(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Validate a query for correctness.
prepareValidateQuery(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareVerifyRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
Verifies a repository.
prepareVerifyRepository(String) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
preParse(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
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.SizeFieldMapper
 
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 interface org.elasticsearch.index.mapper.RootMapper
prePercolate() - Method in class org.elasticsearch.index.percolator.stats.ShardPercolateService
 
PrePostRounding(Rounding, long, long) - Constructor for class org.elasticsearch.common.rounding.Rounding.PrePostRounding
 
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.facet.FacetPhase
 
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
 
preSuggest() - Method in class org.elasticsearch.index.suggest.stats.ShardSuggestService
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.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
 
previousState() - Method in class org.elasticsearch.river.cluster.RiverClusterChangedEvent
 
preZone(DateTimeZone) - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
preZone(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Deprecated.
use timeZone() instead
preZone(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Sets the pre time zone to use when bucketing the values.
preZoneAdjustLargeInterval(boolean) - Method in class org.elasticsearch.common.rounding.TimeZoneRounding.Builder
 
preZoneAdjustLargeInterval(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramBuilder
Deprecated.
this option is going to be removed in 2.0 releases
preZoneAdjustLargeInterval(boolean) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Should pre zone be adjusted for large (day and above) intervals.
primary - Variable in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
primary() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
primary() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
Returns true iff this shard is a primary.
primary - Variable in class org.elasticsearch.gateway.local.state.shards.ShardStateInfo
 
primary() - Method in class org.elasticsearch.index.store.distributor.AbstractDistributor
 
primary() - Method in interface org.elasticsearch.index.store.distributor.Distributor
Returns primary directory (typically first directory in the list)
primaryActiveInitializingShardIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
primaryAllocatedPostApi() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Has this shard group primary shard been allocated post API creation.
primaryFirstActiveInitializingShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
primaryInterface() - Method in class org.elasticsearch.monitor.network.NetworkInfo
 
PrimaryMissingActionException - Exception in org.elasticsearch.action
 
PrimaryMissingActionException(String) - Constructor for exception org.elasticsearch.action.PrimaryMissingActionException
 
PrimaryOperationRequest(int, String, Request) - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryOperationRequest
 
PrimaryResponse(ReplicaRequest, Response, Object) - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryResponse
 
primaryShard() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
primaryShardIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Returns an iterator only on the primary shard.
primaryShardsActive() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
Calculates the number of primary shards in active state in routing table
primaryShardsUnassigned() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
Calculates the number of primary shards in the routing table the are in ShardRoutingState.UNASSIGNED state.
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
 
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 - 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
 
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
 
proceed(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
 
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
 
processBeforeDelegationToMaster(NodesShutdownRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
processBeforeDelegationToMaster(Request, ClusterState) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
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
 
ProcessedClusterStateNonMasterUpdateTask - Class in org.elasticsearch.cluster
A combination between ProcessedClusterStateUpdateTask and ClusterStateNonMasterUpdateTask to allow easy creation of anonymous classes
ProcessedClusterStateNonMasterUpdateTask() - Constructor for class org.elasticsearch.cluster.ProcessedClusterStateNonMasterUpdateTask
 
ProcessedClusterStateUpdateTask - Class in org.elasticsearch.cluster
An extension interface to ClusterStateUpdateTask that allows to be notified when the cluster state update has been processed.
ProcessedClusterStateUpdateTask() - Constructor for class org.elasticsearch.cluster.ProcessedClusterStateUpdateTask
 
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
processField(ObjectMapper.Builder, String, Object) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.TypeParser
 
processFirstPhaseResult(int, ShardRouting, FirstResult) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
processInfo() - Method in class org.elasticsearch.monitor.process.JmxProcessProbe
 
ProcessInfo - Class in org.elasticsearch.monitor.process
 
ProcessInfo(long, long) - Constructor for class org.elasticsearch.monitor.process.ProcessInfo
 
processInfo() - Method in interface org.elasticsearch.monitor.process.ProcessProbe
 
processModule(Module) - Method in interface org.elasticsearch.common.inject.PreProcessModule
 
processModule(Module) - Method in class org.elasticsearch.gateway.local.LocalGatewayModule
 
processModule(Module) - Method in class org.elasticsearch.gateway.none.NoneGatewayModule
 
processModule(Module) - Method in class org.elasticsearch.plugins.AbstractPlugin
 
processModule(Module) - Method in class org.elasticsearch.plugins.IndexPluginsModule
 
processModule(Module) - Method in interface org.elasticsearch.plugins.Plugin
Process a specific module.
processModule(Module) - Method in class org.elasticsearch.plugins.PluginsModule
 
processModule(Module) - Method in class org.elasticsearch.plugins.PluginsService
 
processModule(Module) - Method in class org.elasticsearch.plugins.ShardsPluginsModule
 
processModule(Module) - Method in class org.elasticsearch.river.RiversPluginsModule
 
processModules(Iterable<Module>) - Static method in class org.elasticsearch.common.inject.Modules
 
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.
processPayload() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
processPendingDeletes(Index, Settings, TimeValue) - Method in class org.elasticsearch.indices.IndicesService
Processes all pending deletes for the given index.
ProcessProbe - Interface 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.JmxProcessProbe
 
processStats() - Method in interface 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
 
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
 
processXContentFilterParsers(IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings) - Method in class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor
Extension point to bind a custom FilterParserFactory.
processXContentQueryFilter(String, Class<? extends FilterParser>) - Method in class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings
 
processXContentQueryParser(String, Class<? extends QueryParser>) - Method in class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings
 
processXContentQueryParsers(IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings) - Method in class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor
Extension point to bind a custom QueryParserFactory.
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
profileName - Variable in class org.elasticsearch.transport.netty.MessageChannelHandler
 
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
 
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.
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
 
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(ClusterState, 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(ClusterState, 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(ClusterState, Discovery.AckListener) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
publish(ClusterState, Discovery.AckListener) - Method in class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
 
publish(ClusterState, Discovery.AckListener) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
end of PingContextProvider implementation
publish(RiverClusterState) - Method in class org.elasticsearch.river.cluster.PublishRiverClusterStateAction
 
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, ClusterName) - 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
 
publishHost - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
publishPort - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
PublishRiverClusterStateAction - Class in org.elasticsearch.river.cluster
 
PublishRiverClusterStateAction(Settings, TransportService, ClusterService, PublishRiverClusterStateAction.NewClusterStateListener) - Constructor for class org.elasticsearch.river.cluster.PublishRiverClusterStateAction
 
PublishRiverClusterStateAction.NewClusterStateListener - Interface in org.elasticsearch.river.cluster
 
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(long, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.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.ImmutableSettings.Builder
Puts tuples of key value pairs of settings.
put(String, String) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets a setting with the provided setting key and value.
put(String, Class) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets a setting with the provided setting key and class as value.
put(String, boolean) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the boolean value.
put(String, int) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the int value.
put(String, Version) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
 
put(String, long) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the long value.
put(String, float) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the float value.
put(String, double) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the double value.
put(String, long, TimeUnit) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the time value.
put(String, long, ByteSizeUnit) - Method in class org.elasticsearch.common.settings.ImmutableSettings.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.ImmutableSettings.Builder
Sets the setting group.
put(Settings) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets all the provided settings.
put(Map<String, String>) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Sets all the provided settings.
put(Properties) - Method in class org.elasticsearch.common.settings.ImmutableSettings.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(QueryParserSettings, Query) - Method in class org.elasticsearch.index.cache.query.parser.none.NoneQueryParserCache
 
put(QueryParserSettings, Query) - Method in interface org.elasticsearch.index.cache.query.parser.QueryParserCache
 
put(QueryParserSettings, Query) - Method in class org.elasticsearch.index.cache.query.parser.resident.ResidentQueryParserCache
 
put(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
put(Version, T) - Method in interface org.elasticsearch.indices.analysis.PreBuiltCacheFactory.PreBuiltCache
 
put(RiverRouting) - Method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
put(Object, Object) - Method in class org.elasticsearch.search.lookup.DocLookup
 
put(Object, Object) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
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<Long, VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
Puts all the entries in the map to the builder.
putAll(LongObjectAssociativeContainer<? extends VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
putAll(Iterable<? extends LongObjectCursor<? extends VType>>) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.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.DocLookup
 
putAll(Map) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
putAll(Map) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
putAllInContext(ObjectObjectAssociativeContainer<Object, Object>) - Method in class org.elasticsearch.common.ContextHolder
Attaches the given values to the context
putArray(String, String...) - Method in class org.elasticsearch.common.settings.ImmutableSettings.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
 
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.transport.TransportMessage
 
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.ContextHolder
Attaches the given value to the context.
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(Client) - 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(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(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
 
PutIndexTemplateRequestBuilder(IndicesAdminClient, 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(PutMappingRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
putMapping(PutMappingRequest, ActionListener<PutMappingResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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, CompressedString) - 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(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(IndicesAdminClient) - 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.
putNodeAttribute(String, String) - Method in class org.elasticsearch.node.service.NodeService
Deprecated.
putProperties(String, Properties) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Puts all the properties with keys starting with the provided prefix.
putProperties(String, Properties, String[]) - Method in class org.elasticsearch.common.settings.ImmutableSettings.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.
putRepository(PutRepositoryRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
putRepository(PutRepositoryRequest, ActionListener<PutRepositoryResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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(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(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
Constructs register repository request
PutRepositoryRequestBuilder(ClusterAdminClient, 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
 
putRootTypeParser(String, Mapper.TypeParser) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
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(PutIndexTemplateRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
putTemplate(PutIndexTemplateRequest, ActionListener<PutIndexTemplateResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
putTemplate(MetaDataIndexTemplateService.PutRequest, MetaDataIndexTemplateService.PutListener) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService
 
putTypeParser(String, Mapper.TypeParser) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
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.
putWarmer(PutWarmerRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
putWarmer(PutWarmerRequest, ActionListener<PutWarmerResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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(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
Builder for PutWarmerRequest
PutWarmerRequestBuilder(IndicesAdminClient, String) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
Creates a new PutWarmerRequestBuilder with a given name.
PutWarmerRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
Creates a new PutWarmerRequestBuilder Note: PutWarmerRequestBuilder.setName(String) must be called with a non-null value before this request is executed.
PutWarmerResponse - Class in org.elasticsearch.action.admin.indices.warmer.put
An acknowledged response of put warmer operation.

Q

QUADTREE_LEVELS - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
 
quadTreeCellHeight(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
Calculate the height (in meters) of quadtree cells at a specific level
quadTreeCellSize(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
Calculate the size (in meters) of quadtree cells at a specific level
quadTreeCellWidth(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
Calculate the width (in meters) of quadtree cells at a specific level
quadTreeLevelsForPrecision(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
Calculate the number of levels needed for a specific precision.
quadTreeLevelsForPrecision(String) - Static method in class org.elasticsearch.common.geo.GeoUtils
Calculate the number of levels needed for a specific precision.
QUARTER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
QuarterOfYear - Static variable in class org.elasticsearch.common.joda.Joda
 
Quarters - Static variable in class org.elasticsearch.common.joda.Joda
 
Queries - Class in org.elasticsearch.common.lucene.search
 
Queries() - Constructor for class org.elasticsearch.common.lucene.search.Queries
 
query(QueryParseContext, String) - Method in class org.apache.lucene.queryparser.classic.ExistsFieldQueryExtension
 
query(QueryParseContext, String) - Method in interface org.apache.lucene.queryparser.classic.FieldQueryExtension
 
query(QueryParseContext, String) - Method in class org.apache.lucene.queryparser.classic.MissingFieldQueryExtension
 
query() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
query() - Method in class org.elasticsearch.index.query.ParsedQuery
The query parsed.
query() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
QUERY - Static variable in class org.elasticsearch.index.query.TemplateQueryParser
Name of query parameter containing the template string.
query() - Method in class org.elasticsearch.percolator.PercolateContext
 
query(QueryBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a search query.
query(byte[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a raw search query.
query(byte[], int, int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a raw search query.
query(BytesReference) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a raw search query.
query(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a raw search query.
query(XContentBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a query from a builder.
query(Map) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a query from a map.
query(QueryBuilder) - Method in class org.elasticsearch.search.facet.query.QueryFacetBuilder
 
query - Variable in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.BaseInnerHits
 
query() - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsContext.BaseInnerHits
 
query() - Method in class org.elasticsearch.search.highlight.HighlighterContext.HighlightQuery
 
query - Variable in class org.elasticsearch.search.highlight.HighlighterContext
 
query() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
The query to execute, might be rewritten.
query() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
query() - Method in class org.elasticsearch.search.internal.SearchContext
The query to execute, might be rewritten.
query() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
 
query(String, CharSequence...) - Static method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
 
query(String, Iterable<? extends CharSequence>) - Static method in class org.elasticsearch.search.suggest.context.CategoryContextMapping
 
query(String, GeoPoint) - Static method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
Create a new geolocation query from a given GeoPoint
query(String, double, double, int...) - Static method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
Create a new geolocation query from a given geocoordinate
query(String, double, double, String...) - Static method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
 
query(String, String, int...) - Static method in class org.elasticsearch.search.suggest.context.GeolocationContextMapping
Create a new geolocation query from a given geohash
QUERY_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
 
QUERY_AND_FETCH_TYPE - Static variable in class org.elasticsearch.action.search.type.ParsedScrollId
 
QUERY_FETCH_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
 
QUERY_FETCH_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
 
QUERY_ID_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
 
QUERY_PREFIX - Static variable in class org.elasticsearch.index.query.IndexQueryParserService.Defaults
 
QUERY_QUERY_FETCH_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
 
QUERY_RESULT_ORDERING - Static variable in class org.elasticsearch.search.controller.SearchPhaseController
 
QUERY_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.search.action.SearchServiceTransportAction
 
QUERY_STRING_LENIENT - Static variable in class org.elasticsearch.index.query.IndexQueryParserService
 
QUERY_THEN_FETCH_TYPE - Static variable in class org.elasticsearch.action.search.type.ParsedScrollId
 
QueryBinaryParseElement - Class in org.elasticsearch.search.query
 
QueryBinaryParseElement() - Constructor for class org.elasticsearch.search.query.QueryBinaryParseElement
 
queryBoost() - Method in class org.elasticsearch.percolator.PercolateContext
 
queryBoost(float) - Method in class org.elasticsearch.percolator.PercolateContext
 
queryBoost() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
queryBoost(float) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
queryBoost() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
queryBoost(float) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
queryBoost() - Method in class org.elasticsearch.search.internal.SearchContext
 
queryBoost(float) - Method in class org.elasticsearch.search.internal.SearchContext
 
queryBoost(float) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
QueryBuilder - Interface in org.elasticsearch.index.query
 
QueryBuilder(float) - Constructor for class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
 
QueryBuilder(boolean, float) - Constructor for class org.elasticsearch.index.search.MultiMatchQuery.QueryBuilder
 
QueryBuilders - Class in org.elasticsearch.index.query
A static factory for simple "import static" usage.
queryCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
queryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
queryCache - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
queryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
queryCache() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
queryCache(Boolean) - Method in class org.elasticsearch.action.search.SearchRequest
Sets if this request should use the query cache or not, assuming that it can (for example, if "now" is used, it will never be cached).
queryCache() - Method in class org.elasticsearch.action.search.SearchRequest
 
queryCache() - Method in class org.elasticsearch.index.shard.IndexShard
 
queryCache() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
 
queryCache() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
 
queryCache() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 
queryCache() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
 
QueryCacheStats - Class in org.elasticsearch.index.cache.query
 
QueryCacheStats() - Constructor for class org.elasticsearch.index.cache.query.QueryCacheStats
 
QueryCacheStats(long, long, long, long) - Constructor for class org.elasticsearch.index.cache.query.QueryCacheStats
 
QueryExplanation - Class in org.elasticsearch.action.admin.indices.validate.query
 
QueryExplanation(String, boolean, String, String) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
queryFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
queryFacet(String, QueryBuilder) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
QueryFacet - Interface in org.elasticsearch.search.facet.query
A query facets returns the count (number of hits) for a facet based on a query.
QueryFacetBuilder - Class in org.elasticsearch.search.facet.query
 
QueryFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.query.QueryFacetBuilder
 
QueryFacetExecutor - Class in org.elasticsearch.search.facet.query
 
QueryFacetExecutor(Query) - Constructor for class org.elasticsearch.search.facet.query.QueryFacetExecutor
 
QueryFacetParser - Class in org.elasticsearch.search.facet.query
 
QueryFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.query.QueryFacetParser
 
QueryFetchSearchResult - Class in org.elasticsearch.search.fetch
 
QueryFetchSearchResult() - Constructor for class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
QueryFetchSearchResult(QuerySearchResult, FetchSearchResult) - Constructor for class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
queryFilter(QueryBuilder) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter that simply wraps a query.
QueryFilterBuilder - Class in org.elasticsearch.index.query
A filter that simply wraps a query.
QueryFilterBuilder(QueryBuilder) - Constructor for class org.elasticsearch.index.query.QueryFilterBuilder
A filter that simply wraps a query.
QueryFilterParser - Class in org.elasticsearch.index.query
 
QueryFilterParser() - Constructor for class org.elasticsearch.index.query.QueryFilterParser
 
queryFound - Variable in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
queryFound() - Method in class org.elasticsearch.index.query.support.NestedInnerQueryParseSupport
 
QueryInnerHitBuilder - Class in org.elasticsearch.index.query.support
 
QueryInnerHitBuilder() - Constructor for class org.elasticsearch.index.query.support.QueryInnerHitBuilder
 
queryName(String) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.FilteredQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.HasParentQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.IndicesQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
Specify a name for the query
queryName(String) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.SpanTermQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.TermQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.TopChildrenQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryName(String) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
Sets the query name for the filter that can be used when searching for matched_filters per hit.
queryNorm - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
QueryParseContext - Class in org.elasticsearch.index.query
 
QueryParseContext(Index, IndexQueryParserService) - Constructor for class org.elasticsearch.index.query.QueryParseContext
 
QueryParseContext(Index, IndexQueryParserService, boolean) - Constructor for class org.elasticsearch.index.query.QueryParseContext
 
QueryParseElement - Class in org.elasticsearch.search.query
 
QueryParseElement() - Constructor for class org.elasticsearch.search.query.QueryParseElement
 
queryParser(String) - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
queryParser(QueryParserSettings) - Method in class org.elasticsearch.index.query.QueryParseContext
 
QueryParser - Interface in org.elasticsearch.index.query
 
QUERYPARSER_VERSION - Static variable in class org.elasticsearch.common.lucene.Lucene
 
queryParserCache() - Method in class org.elasticsearch.index.cache.IndexCache
 
QueryParserCache - Interface in org.elasticsearch.index.cache.query.parser
The main benefit of the query parser cache is to not parse the same query string on different shards.
queryParserCache() - Method in class org.elasticsearch.index.query.QueryParseContext
 
QueryParserCacheModule - Class in org.elasticsearch.index.cache.query.parser
 
QueryParserCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.query.parser.QueryParserCacheModule
 
QueryParserFactory - Interface in org.elasticsearch.index.query
 
QueryParsers - Class in org.elasticsearch.index.query.support
 
queryParsers() - Method in class org.elasticsearch.indices.query.IndicesQueriesRegistry
 
queryParserService() - Method in class org.elasticsearch.index.IndexService
 
queryParserService() - Method in class org.elasticsearch.percolator.PercolateContext
 
queryParserService() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
queryParserService() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
queryParserService() - Method in class org.elasticsearch.search.internal.SearchContext
 
QueryParserSettings - Class in org.apache.lucene.queryparser.classic
 
QueryParserSettings() - Constructor for class org.apache.lucene.queryparser.classic.QueryParserSettings
 
QueryParsersProcessor() - Constructor for class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor
 
QueryParserUtils - Class in org.elasticsearch.index.query
 
QueryParsingException - Exception in org.elasticsearch.index.query
 
QueryParsingException(Index, String) - Constructor for exception org.elasticsearch.index.query.QueryParsingException
 
QueryParsingException(Index, String, Throwable) - Constructor for exception org.elasticsearch.index.query.QueryParsingException
 
QueryPhase - Class in org.elasticsearch.search.query
 
QueryPhase(FacetPhase, AggregationPhase, SuggestPhase, RescorePhase) - Constructor for class org.elasticsearch.search.query.QueryPhase
 
QueryPhaseExecutionException - Exception in org.elasticsearch.search.query
 
QueryPhaseExecutionException(SearchContext, String, Throwable) - Constructor for exception org.elasticsearch.search.query.QueryPhaseExecutionException
 
QueryPhaseExecutionException(SearchContext, String) - Constructor for exception org.elasticsearch.search.query.QueryPhaseExecutionException
 
QueryRescoreContext(QueryRescorer) - Constructor for class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
 
QueryRescorer - Class in org.elasticsearch.search.rescore
 
QueryRescorer() - Constructor for class org.elasticsearch.search.rescore.QueryRescorer
 
queryRescorer(QueryBuilder) - Static method in class org.elasticsearch.search.rescore.RescoreBuilder
 
QueryRescorer(QueryBuilder) - Constructor for class org.elasticsearch.search.rescore.RescoreBuilder.QueryRescorer
Creates a new QueryRescorer instance
QueryRescorer.QueryRescoreContext - Class in org.elasticsearch.search.rescore
 
queryResult() - Method in class org.elasticsearch.percolator.PercolateContext
 
queryResult() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
queryResult() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
queryResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
queryResult() - Method in class org.elasticsearch.search.internal.SearchContext
 
queryResult() - Method in class org.elasticsearch.search.internal.SubSearchContext
 
queryResult() - Method in class org.elasticsearch.search.query.QuerySearchResult
 
queryResult() - Method in class org.elasticsearch.search.query.QuerySearchResultProvider
 
queryResult() - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
 
queryRewritten() - Method in class org.elasticsearch.percolator.PercolateContext
 
queryRewritten() - Method in class org.elasticsearch.search.highlight.HighlighterContext.HighlightQuery
 
queryRewritten() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
Has the query been rewritten already?
queryRewritten() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
queryRewritten() - Method in class org.elasticsearch.search.internal.SearchContext
Has the query been rewritten already?
queryScriptIndex(GetIndexedScriptRequest, ActionListener<GetResponse>) - Method in class org.elasticsearch.script.ScriptService
 
QuerySearchRequest - Class in org.elasticsearch.search.query
 
QuerySearchRequest() - Constructor for class org.elasticsearch.search.query.QuerySearchRequest
 
QuerySearchRequest(SearchRequest, long, AggregatedDfs) - Constructor for class org.elasticsearch.search.query.QuerySearchRequest
 
QuerySearchResult - Class in org.elasticsearch.search.query
 
QuerySearchResult() - Constructor for class org.elasticsearch.search.query.QuerySearchResult
 
QuerySearchResult(long, SearchShardTarget) - Constructor for class org.elasticsearch.search.query.QuerySearchResult
 
QuerySearchResultProvider - Class in org.elasticsearch.search.query
 
QuerySearchResultProvider() - Constructor for class org.elasticsearch.search.query.QuerySearchResultProvider
 
QuerySourceBuilder - Class in org.elasticsearch.action.support
 
QuerySourceBuilder() - Constructor for class org.elasticsearch.action.support.QuerySourceBuilder
 
queryString() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
queryString(String) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
queryString(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
by queryStringQuery(String)
queryStringLenient() - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
queryStringLenient() - Method in class org.elasticsearch.index.query.QueryParseContext
 
queryStringQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that parses a query string and runs it.
QueryStringQueryBuilder - Class in org.elasticsearch.index.query
A query that parses a query string and runs it.
QueryStringQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.QueryStringQueryBuilder
 
QueryStringQueryBuilder.Operator - Enum in org.elasticsearch.index.query
 
QueryStringQueryParser - Class in org.elasticsearch.index.query
 
QueryStringQueryParser(Settings) - Constructor for class org.elasticsearch.index.query.QueryStringQueryParser
 
queryStringTermQuery(Term) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
queryStringTermQuery(Term) - Method in interface org.elasticsearch.index.mapper.FieldMapper
A term query to use when parsing a query string.
queryStringTermQuery(Term) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
queryTypes() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
queryTypes(Collection<String>) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
queryTypes() - Method in class org.elasticsearch.index.query.QueryParseContext
Returns the narrowed down explicit types, or, if not set, all types.
queryWeight - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
queryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
 
quote(String) - Static method in class org.elasticsearch.common.Strings
Quote the given String with single quotes.
quoteAnalyzer(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
The optional analyzer used to analyze the query string for phrase searches.
quoteFieldSuffix(String) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
quoteFieldSuffix() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
quoteFieldSuffix(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
An optional field name suffix to automatically try and add to the field searched when using quoted text.

R

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
raf() - Method in class org.elasticsearch.index.translog.fs.RafReference
 
RafReference - Class in org.elasticsearch.index.translog.fs
 
RafReference(File, ESLogger) - Constructor for class org.elasticsearch.index.translog.fs.RafReference
 
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.common.lucene.docset.AllDocIdSet
 
ramBytesUsed() - Method in class org.elasticsearch.common.lucene.docset.AndDocIdSet
 
ramBytesUsed() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet
 
ramBytesUsed() - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet
 
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.FSTBytesAtomicFieldData
 
ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointCompressedAtomicFieldData.Single
 
ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayAtomicFieldData.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.SortedSetDVBytesAtomicFieldData
 
ramBytesUsed() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
ramBytesUsed() - Method in class org.elasticsearch.index.translog.Translog.Location
 
ramBytesUsed() - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache.Key
 
ramBytesUsed() - Method in class org.elasticsearch.indices.cache.query.IndicesQueryCache.Value
 
ramBytesUsed() - Method in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.LookupFactory
 
RamDirectoryService - Class in org.elasticsearch.index.store.ram
 
RamDirectoryService(ShardId, Settings) - Constructor for class org.elasticsearch.index.store.ram.RamDirectoryService
 
RamIndexStore - Class in org.elasticsearch.index.store.ram
 
RamIndexStore(Index, Settings, IndexService, IndicesStore, NodeEnvironment) - Constructor for class org.elasticsearch.index.store.ram.RamIndexStore
 
RamIndexStoreModule - Class in org.elasticsearch.index.store.ram
 
RamIndexStoreModule() - Constructor for class org.elasticsearch.index.store.ram.RamIndexStoreModule
 
random() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
RANDOM_WEIGHT_DISTRIBUTOR - Static variable in class org.elasticsearch.index.store.StoreModule
 
randomAllActiveShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
Returns an unordered iterator over all active shards (including replicas).
randomAllShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
Returns an unordered iterator over all 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
 
randomNodeName(URL) - Static method in class org.elasticsearch.common.Names
 
RandomScoreFunction - Class in org.elasticsearch.common.lucene.search.function
Pseudo randomly generate a score for each RandomScoreFunction.score(int, float).
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
 
RandomWeightedDistributor - Class in org.elasticsearch.index.store.distributor
Implements directory distributor that picks a directory at random.
RandomWeightedDistributor(DirectoryService) - Constructor for class org.elasticsearch.index.store.distributor.RandomWeightedDistributor
 
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) - 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
Builder for the Range aggregation.
RangeBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeBuilder
Sole constructor.
rangeFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
RangeFacet - Interface in org.elasticsearch.search.facet.range
 
RangeFacet.Entry - Class in org.elasticsearch.search.facet.range
 
RangeFacetBuilder - Class in org.elasticsearch.search.facet.range
A facet builder of range facets.
RangeFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.range.RangeFacetBuilder
Constructs a new range facet with the provided facet logical name.
RangeFacetExecutor - Class in org.elasticsearch.search.facet.range
 
RangeFacetExecutor(IndexNumericFieldData, RangeFacet.Entry[], SearchContext) - Constructor for class org.elasticsearch.search.facet.range.RangeFacetExecutor
 
RangeFacetExecutor.RangeProc - Class in org.elasticsearch.search.facet.range
 
RangeFacetParser - Class in org.elasticsearch.search.facet.range
 
RangeFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.range.RangeFacetParser
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, DateTimeZone, DateMathParser, QueryParseContext, Boolean) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, DateTimeZone, DateMathParser, QueryParseContext, Boolean) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
rangeFilter(Double, Double, boolean, boolean) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
A range filter based on the field data cache.
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
rangeFilter(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
rangeFilter(QueryParseContext, Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
rangeFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter that restricts search results to values that are within the given range.
RangeFilterBuilder - Class in org.elasticsearch.index.query
A filter that restricts search results to values that are within the given range.
RangeFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.RangeFilterBuilder
A filter that restricts search results to values that are within the given range.
RangeFilterParser - Class in org.elasticsearch.index.query
 
RangeFilterParser() - Constructor for class org.elasticsearch.index.query.RangeFilterParser
 
RangeParser - Class in org.elasticsearch.search.aggregations.bucket.range
 
RangeParser() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeParser
 
RangeProc(RangeFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.range.KeyValueRangeFacetExecutor.RangeProc
 
RangeProc(RangeFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.range.RangeFacetExecutor.RangeProc
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, DateTimeZone, DateMathParser, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
rangeQuery(Object, Object, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
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
 
rangeScriptFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
RangeScriptFacetBuilder - Class in org.elasticsearch.search.facet.range
 
RangeScriptFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
 
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.fs.FsDirectoryService
 
rateLimiting() - Method in interface 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.index.store.support.AbstractIndexStore
 
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, byte[]) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
rawField(String, byte[], int, int) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
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.
read(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.alias.Alias
Allows to read an alias from the provided input stream
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.AdapterStreamInput
 
read(byte[]) - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
read(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
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.BytesStreamInput
 
read(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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(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(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.ThreadSafeInputStreamIndexInput
 
read(StreamInput) - Static method in class org.elasticsearch.common.rounding.Rounding.Streams
 
read(File) - Method in class org.elasticsearch.gateway.local.state.meta.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(StreamInput) - Static method in class org.elasticsearch.index.store.Store.MetadataSnapshot
 
read() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
 
read(StreamInput) - Method in class org.elasticsearch.index.translog.ChecksummedTranslogStream
 
read(Translog.Location) - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
read(Translog.Location) - Method in class org.elasticsearch.index.translog.fs.FsTranslog
Read the Operation object from the given location, returns null if the Operation could not be read.
read(Translog.Location) - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
read(Translog.Location) - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
read(StreamInput) - Method in class org.elasticsearch.index.translog.LegacyTranslogStream
 
read(Translog.Location) - Method in interface org.elasticsearch.index.translog.Translog
 
read(StreamInput) - Method in interface org.elasticsearch.index.translog.TranslogStream
Read the next translog operation from the input stream
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.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
 
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.AdapterStreamInput
 
readByte() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
 
readByte() - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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.index.translog.BufferedChecksumStreamInput
 
readByte() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
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.AdapterStreamInput
 
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.BytesStreamInput
 
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.index.translog.BufferedChecksumStreamInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
readBytesRef(int) - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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.AdapterStreamInput
 
readBytesReference(int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readBytesReference(int) - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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
 
readClassDescriptor() - Method in class org.elasticsearch.common.io.ThrowableObjectInputStream
 
readClusterBlock(StreamInput) - Static method in class org.elasticsearch.cluster.block.ClusterBlock
 
readClusterBlocks(StreamInput) - Static method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
readClusterIndexHealth(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
readClusterName(StreamInput) - Static method in class org.elasticsearch.cluster.ClusterName
 
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.CompressedString
 
readCounts(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
 
readCpu(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
readCpu(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
readCpu(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
 
readDfsSearchResult(StreamInput) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
 
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.
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() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
reader - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
 
ReaderAggregator(RandomAccessOrds, int, CacheRecycler) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor.ReaderAggregator
 
readerContext() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
ReaderContextAware - Interface in org.elasticsearch.common.lucene
 
readerKey() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
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.query.IndicesQueryCache.Key
 
readExplanation(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
 
readFacet(StreamInput) - Method in interface org.elasticsearch.search.facet.InternalFacet.Stream
 
readFacets(StreamInput) - Static method in class org.elasticsearch.search.facet.InternalFacets
 
readFailure(StreamInput) - Static method in class org.elasticsearch.action.get.MultiGetResponse.Failure
 
readFailure(StreamInput) - Static method in class org.elasticsearch.action.termvector.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, ObjectObjectOpenHashMap<String, CollectionStatistics>) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
 
readFile(StreamInput) - Static method in class org.elasticsearch.indices.recovery.RecoveryState.File
 
readFilterCacheStats(StreamInput) - Static method in class org.elasticsearch.index.cache.filter.FilterCacheStats
 
readFilterFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
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.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.health.ClusterIndexHealth
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
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.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.PluginInfo
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsInfo
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction.NodeRestartRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse
 
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.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.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.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.tasks.PendingClusterTasksRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.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.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.FlushResponse
 
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.delete.DeleteMappingRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingResponse
 
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.optimize.OptimizeRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeResponse
 
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.recovery.ShardRecoveryResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
 
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.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.status.IndicesStatusRequest
Deprecated.
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
Deprecated.
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
 
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.validate.query.QueryExplanation
 
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
 
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
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.count.CountResponse
 
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.delete.IndexDeleteResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.delete.ShardDeleteRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.delete.ShardDeleteResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.exists.ExistsRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.exists.ExistsResponse
 
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.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.mlt.MoreLikeThisRequest
 
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.SuggestRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.suggest.SuggestResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationResponse
 
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.MasterNodeOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.NodeOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.NodeOperationResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ReplicaOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.ShardSingleOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsItemResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse.Failure
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsShardRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsShardResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
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.MappingUpdatedAction.MappingUpdatedRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.ClusterName
 
readFrom(StreamInput, DiscoveryNode, ClusterName) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
 
readFrom(StreamInput) - Method in interface org.elasticsearch.cluster.ClusterState.Custom.Factory
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
 
readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
readFrom(StreamInput) - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom.Factory
 
readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
readFrom(StreamInput) - Static 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.Custom.Factory
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData.Factory
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.RestoreMetaData.Factory
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
Reads restore status from stream input
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.SnapshotId
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Factory
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
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) - 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
Reads an AllocationCommand of type T from a StreamInput
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, String, int) - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
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.RoutingTableValidation
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.service.PendingClusterTask
 
readFrom(StreamInput) - Static method in enum org.elasticsearch.common.breaker.CircuitBreaker.Name
 
readFrom(StreamInput) - Method in class org.elasticsearch.common.compress.CompressedString
 
readFrom(StreamInput) - Method in interface org.elasticsearch.common.io.stream.Streamable
 
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.PrePostRounding
 
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.Percent
 
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) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.PingRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices.AllocateDangledResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState
 
readFrom(StreamInput) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState
 
readFrom(StreamInput) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards
 
readFrom(StreamInput) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards
 
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.filter.FilterCacheStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
readFrom(StreamInput) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
 
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
 
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.NodeIndicesStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
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.Start
 
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.StartRecoveryRequest
 
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.StoreFilesMetaData
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.fs.FsStats
 
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.GarbageCollector.LastGc
 
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.network.NetworkInfo.Interface
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.network.NetworkInfo
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.network.NetworkStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsInfo.Mem
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsInfo
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsInfo.Swap
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
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.repositories.VerificationFailure
 
readFrom(StreamInput) - Static method in enum org.elasticsearch.rest.RestStatus
 
readFrom(StreamInput) - Static method in class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
readFrom(StreamInput) - Method in class org.elasticsearch.river.routing.RiverRouting
 
readFrom(StreamInput) - Static method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
readFrom(StreamInput) - Static method in enum org.elasticsearch.script.ScriptService.ScriptType
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
 
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.SignificantLongTerms
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
 
readFrom(StreamInput, BigArrays) - Static method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
 
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.facet.datehistogram.InternalCountDateHistogramFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.InternalFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.InternalFacets
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
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.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.Factory
 
readFrom(StreamInput) - Method in class org.elasticsearch.snapshots.RestoreInfo
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.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.
readFromThin(StreamInput) - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
readFromThin(StreamInput, String) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
readFromThin(StreamInput) - Method in interface org.elasticsearch.cluster.routing.ShardRouting
 
readFromWithId(long, StreamInput) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
readFsStats(StreamInput) - Static method in class org.elasticsearch.monitor.fs.FsStats
 
readFully(byte[]) - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
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
 
readGeoDistanceFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
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
 
readHistogramFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
readHistogramFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
readHistogramFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
readHistogramFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
readHttpInfo(StreamInput) - Static method in class org.elasticsearch.http.HttpInfo
 
readHttpStats(StreamInput) - Static method in class org.elasticsearch.http.HttpStats
 
readIdCacheStats(StreamInput) - Static method in class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
readIndex(StreamInput) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
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
 
readIndexShardStatus(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
 
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
 
readInetSocketTransportAddress(StreamInput) - Static method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
readInfoFrom(StreamInput) - Static method in class org.elasticsearch.monitor.fs.FsStats.Info
 
readInt() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
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.termvector.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
 
readLastCommittedSegmentsInfo() - Method in class org.elasticsearch.index.store.Store
Returns the last committed segments info for this store
readLastGc(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
readListShardStoreNodeOperationResponse(StreamInput) - Static method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
 
readLocal(StreamInput) - Method in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequest
Reads the local flag
readLocal(StreamInput, Version) - Method in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequest
Reads the local flag if on or after the specified min version or if the version is null.
readLock - Variable in class org.elasticsearch.index.engine.Engine
 
readLong() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
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.JvmInfo.Mem
 
readMem(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
readMem(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsInfo.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(File[], 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.
readNetworkInfo(StreamInput) - Static method in class org.elasticsearch.monitor.network.NetworkInfo
 
readNetworkInterface(StreamInput) - Static method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
readNetworkStats(StreamInput) - Static method in class org.elasticsearch.monitor.network.NetworkStats
 
readNetworkTcp(StreamInput) - Static method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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
 
readNodeRestartResponse(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartResponse.NodeRestartResponse
 
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
 
readOnlyRoutingNodes() - Method in class org.elasticsearch.cluster.ClusterState
Returns a built (on demand) routing nodes view of the routing table.
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
 
readOptionalFacets(StreamInput) - Static method in class org.elasticsearch.search.facet.InternalFacets
 
readOptionalOriginalIndices(StreamInput) - Static method in class org.elasticsearch.action.OriginalIndices
 
readOptionalRestoreInfo(StreamInput) - Static method in class org.elasticsearch.snapshots.RestoreInfo
Reads optional restore info from StreamInput
readOptionalRestoreSource(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RestoreSource
 
readOptionalSharedString() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
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
 
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
 
readPingResponse(StreamInput) - Static method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
readPluginInfo(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
readPluginsInfo(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.info.PluginsInfo
 
readProcessInfo(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessInfo
 
readProcessStats(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessStats
 
readQueryExplanation(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
readQueryFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
readQueryFetchSearchResult(StreamInput) - Static method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
readQuerySearchResult(StreamInput) - Static method in class org.elasticsearch.search.query.QuerySearchResult
 
readRangeFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
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
 
readResponseFrom(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
readRestoreInfo(StreamInput) - Static method in class org.elasticsearch.snapshots.RestoreInfo
Reads restore info from StreamInput
readRestoreSource(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RestoreSource
 
readResult(StreamInput) - Method in interface org.elasticsearch.search.aggregations.AggregationStreams.Stream
 
readResult(StreamInput) - Method in interface org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicStreams.Stream
 
readRiverRouting(StreamInput) - Static method in class org.elasticsearch.river.routing.RiverRouting
 
readScoreDoc(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
 
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
 
readSearchResponse(StreamInput) - Static method in class org.elasticsearch.action.search.SearchResponse
 
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, Directory) - 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.ImmutableSettings
 
readShardId(StreamInput) - Static method in class org.elasticsearch.index.shard.ShardId
 
readShardOperationFailed(StreamInput) - Static method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
 
readShardRecoveryResponse(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.recovery.ShardRecoveryResponse
Builds a new ShardRecoveryResponse from the give input stream.
readShardRestoreStatus(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
Reads restore status from stream input
readShardRoutingEntry(StreamInput) - Static method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
readShardRoutingEntry(StreamInput, String, int) - Static method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
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.metadata.SnapshotMetaData.ShardSnapshotStatus
 
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
 
readSharedString() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readSharedString() - Method in class org.elasticsearch.common.io.stream.HandlesStreamInput
 
readSharedString() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
readSharedText() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readSharedText() - Method in class org.elasticsearch.common.io.stream.HandlesStreamInput
 
readSharedText() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
readShort() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
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(InputStream) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
Parses JSON representation of a snapshot
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

This file can be used by read-only repositories that are unable to list files in the repository

readSnapshotMetaData(SnapshotId, ImmutableList<String>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
Returns global metadata associate with the snapshot.
readSnapshotMetaData(SnapshotId, ImmutableList<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
 
readStatisticalFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
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
 
readStreamHeader() - Method in class org.elasticsearch.common.io.ThrowableObjectInputStream
 
readString() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readString() - Method in class org.elasticsearch.common.io.stream.HandlesStreamInput
 
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.OsInfo.Swap
 
readSwap(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsStats.Swap
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
readTermsStatsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
readTermsStatsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
readTermsStatsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
readTermStats(StreamInput, Term[]) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
 
readTermVectorRequest(StreamInput) - Static method in class org.elasticsearch.action.termvector.TermVectorRequest
 
readText(String, Object...) - Method in class org.elasticsearch.common.cli.Terminal
 
readText() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readText() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
readTextArray() - 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
 
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
 
readTranslogOperation(StreamInput) - Static method in class org.elasticsearch.index.translog.TranslogStreams
Read the next Translog.Operation from the stream using the latest translog version
readTransportInfo(StreamInput) - Static method in class org.elasticsearch.transport.TransportInfo
 
readTransportStats(StreamInput) - Static method in class org.elasticsearch.transport.TransportStats
 
readURIParameters(TermVectorRequest, RestRequest) - Static method in class org.elasticsearch.rest.action.termvector.RestTermVectorAction
 
readVersion(StreamInput) - Static method in class org.elasticsearch.common.lucene.uid.Versions
 
readVersion(StreamInput) - Static method in class org.elasticsearch.Version
 
readVersionWithVLongForBW(StreamInput) - Static method in class org.elasticsearch.common.lucene.uid.Versions
 
readVInt() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readVInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
Reads an int stored in variable-length format.
readVLong() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
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).
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() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
realtime(Boolean) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
realtime() - Method in class org.elasticsearch.index.engine.Engine.Get
 
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.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.metadata.RestoreMetaData.ShardRestoreStatus
Returns failure reason
reason() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
reason(String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets snapshot failure reason
reason() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns reason for complete snapshot failure
reason() - Method in interface 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
rebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
 
rebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
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
 
reclaimed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
RecordingBucketCollector - Class in org.elasticsearch.search.aggregations
Abstraction for implementations that record a "collect" stream for subsequent play-back
RecordingBucketCollector() - Constructor for class org.elasticsearch.search.aggregations.RecordingBucketCollector
 
RecordingPerReaderBucketCollector - Class in org.elasticsearch.search.aggregations
Records a "collect" stream for subsequent play-back using a per-segment object to collect matches.
RecordingPerReaderBucketCollector(AggregationContext) - Constructor for class org.elasticsearch.search.aggregations.RecordingPerReaderBucketCollector
 
recover(Engine.RecoveryHandler) - Method in class org.elasticsearch.index.engine.Engine
 
recover(Engine.RecoveryHandler) - Method in class org.elasticsearch.index.engine.InternalEngine
 
recover(Engine.RecoveryHandler) - Method in class org.elasticsearch.index.engine.ShadowEngine
 
recover(Engine.RecoveryHandler) - Method in class org.elasticsearch.index.engine.SharedFSEngine
 
recover(boolean, RecoveryState) - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
Recovers the state of the shard from the gateway.
recover(boolean, IndexShardGatewayService.RecoveryListener) - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
Recovers the state of the shard from the gateway.
recover(boolean, RecoveryState) - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
recover(boolean, RecoveryState) - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
recover(Engine.RecoveryHandler) - Method in class org.elasticsearch.index.shard.IndexShard
 
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
 
recoveries(RecoveryRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices recoveries
recoveries(RecoveryRequest, ActionListener<RecoveryResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices recoveries
recoveries(RecoveryRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
recoveries(RecoveryRequest, ActionListener<RecoveryResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
a reference to RecoveryStatus, which implements AutoCloseable.
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.
recovery(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
recovery() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
recovery(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Deprecated.
Should the status include recovery information.
recovery() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Deprecated.
 
RecoveryAction - Class in org.elasticsearch.action.admin.indices.recovery
Recovery information action
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
 
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
 
RecoveryFileChunkRequest - Class in org.elasticsearch.indices.recovery
 
RecoveryFileChunkRequest(long, ShardId, StoreFileMetaData, long, BytesReference, boolean, int, long) - Constructor for class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
recoveryId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
 
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(IndicesAdminClient) - 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<ShardRecoveryResponse>>, 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, MappingUpdatedAction, 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, ClusterService, IndicesService, MappingUpdatedAction, ESLogger) - Constructor for class org.elasticsearch.indices.recovery.RecoverySourceHandler
 
recoveryState(RecoveryState) - Method in class org.elasticsearch.action.admin.indices.recovery.ShardRecoveryResponse
Sets the recovery state information for the shard.
recoveryState() - Method in class org.elasticsearch.action.admin.indices.recovery.ShardRecoveryResponse
Gets the recovery state information for the shard.
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(IndexShard) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
 
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.Start - Class 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
 
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
 
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
 
recursiveStrategy() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
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>) - Method in class org.elasticsearch.percolator.PercolatorService
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
 
reduce(List<? extends InternalSignificantTerms.Bucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
 
reduce(List<? extends InternalTerms.Bucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
 
reduce(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.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
 
reduce(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.InternalFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
reduce(InternalFacet.ReduceContext) - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
reduce(double, int) - Method in enum org.elasticsearch.search.MultiValueMode
Returns the aggregated value based on the sort mode.
reduce(long, int) - Method in enum org.elasticsearch.search.MultiValueMode
Returns the aggregated value based on the sort mode.
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
 
ReduceContext(List<InternalAggregation>, BigArrays, ScriptService) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
 
ReduceContext(CacheRecycler, List<Facet>) - Constructor for class org.elasticsearch.search.facet.InternalFacet.ReduceContext
 
reducedAggregations() - Method in class org.elasticsearch.percolator.PercolatorService.ReduceResult
 
reducedFacets() - 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
 
reduceParams(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set parameters that will be available in the reduce phase.
ReduceResult(long, InternalFacets, InternalAggregations) - Constructor for class org.elasticsearch.percolator.PercolatorService.ReduceResult
 
reduceScript(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the reduce script.
reduceScriptFile(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the reduce script file.
reduceScriptId(String) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricBuilder
Set the indexed reduce script id.
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, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.ReduceSearchPhaseException
 
ReduceSearchPhaseException(String, String, Throwable, ShardSearchFailure[]) - 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() - Method in class org.elasticsearch.action.delete.ShardDeleteRequest
 
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(RefreshRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
refresh(RefreshRequest, ActionListener<RefreshResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
 
refreshInterval() - Method in class org.elasticsearch.monitor.network.NetworkInfo
 
refreshInterval() - Method in class org.elasticsearch.monitor.os.OsInfo
 
refreshInterval() - Method in class org.elasticsearch.monitor.process.ProcessInfo
 
refreshMapping(String, 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(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(IndicesAdminClient) - 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
 
refreshSource() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
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
 
regex(String) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
A regular expression to use in order to further filter terms.
regex(String, int) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
A regular expression (with flags) to use in order to further filter terms.
regexp() - Method in class org.elasticsearch.common.lucene.search.RegexpFilter
 
RegexpFilter - Class in org.elasticsearch.common.lucene.search
A lazy regexp filter which only builds the automaton on the first call to RegexpFilter.getDocIdSet(AtomicReaderContext, Bits).
RegexpFilter(Term) - Constructor for class org.elasticsearch.common.lucene.search.RegexpFilter
 
RegexpFilter(Term, int) - Constructor for class org.elasticsearch.common.lucene.search.RegexpFilter
 
RegexpFilter(Term, int, int) - Constructor for class org.elasticsearch.common.lucene.search.RegexpFilter
 
regexpFilter(Object, int, int, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
regexpFilter(Object, int, int, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
regexpFilter(Object, int, int, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
regexpFilter(String, String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter that restricts search results to field values that match a given regular expression.
RegexpFilterBuilder - Class in org.elasticsearch.index.query
A filter that restricts search results to values that have a matching regular expression in a given field.
RegexpFilterBuilder(String, String) - Constructor for class org.elasticsearch.index.query.RegexpFilterBuilder
A filter that restricts search results to values that have a matching prefix in a given field.
RegexpFilterParser - Class in org.elasticsearch.index.query
 
RegexpFilterParser() - Constructor for class org.elasticsearch.index.query.RegexpFilterParser
 
RegexpFlag - Enum in org.elasticsearch.index.query
Regular expression syntax flags.
regexpQuery(Object, int, int, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
regexpQuery(Object, int, int, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
regexpQuery(Object, int, int, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
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.
registerAction(GenericAction<Request, Response>, Class<? extends TransportAction<Request, Response>>, Class...) - Method in class org.elasticsearch.action.ActionModule
Registers an action.
registerConnectionListener - Variable in class org.elasticsearch.discovery.zen.fd.FaultDetection
 
registerCoreListener(AtomicReader, AtomicReader.CoreClosedListener) - Static method in class org.elasticsearch.common.lucene.SegmentReaderUtils
 
registerFactory(String, ClusterState.Custom.Factory) - Static method in class org.elasticsearch.cluster.ClusterState
Register a custom index meta data factory.
registerFactory(String, IndexMetaData.Custom.Factory) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
Register a custom index meta data factory.
registerFactory(String, MetaData.Custom.Factory) - Static method in class org.elasticsearch.cluster.metadata.MetaData
Register a custom index meta data factory.
registerFactory(String, AllocationCommand.Factory) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
Register a custom index meta data factory.
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.
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.
registerHandler(String, TransportRequestHandler) - Method in class org.elasticsearch.transport.TransportService
 
registerHighlighter(Class<? extends Highlighter>) - Method in class org.elasticsearch.search.highlight.HighlightModule
 
registerIndexTemplateFilter(Class<? extends IndexTemplateFilter>) - Method in class org.elasticsearch.cluster.ClusterModule
 
registerParser(Class<? extends ScoreFunctionParser>) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreModule
 
registerParser(Class<? extends SignificanceHeuristicParser>) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificantTermsHeuristicModule
 
registerReaderContextAware(ReaderContextAware) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
registerRelevantHeaders(String...) - Method in class org.elasticsearch.rest.RestController
Controls which REST headers get copied over from a RestRequest to its corresponding TransportRequest(s).
registerRepository(String, Class<? extends Module>) - Method in class org.elasticsearch.repositories.RepositoriesModule
Registers a custom repository type name against a module.
registerRepository(RepositoriesService.RegisterRepositoryRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
Registers new repository in the cluster

This method can be only called on the master node.

RegisterRepositoryRequest(String, String, String, boolean) - Constructor for class org.elasticsearch.repositories.RepositoriesService.RegisterRepositoryRequest
Constructs new register repository request
registerRiver(String, Class<? extends Module>) - Method in class org.elasticsearch.river.RiversModule
Registers a custom river type name against a module.
registerScorerAware(ScorerAware) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
registerScript(String, Class<? extends NativeScriptFactory>) - Method in class org.elasticsearch.script.ScriptModule
 
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() - 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.InternalDateHistogram
 
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, String...) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicStreams
Registers the given stream and associate it with the given types.
registerStream(SignificanceHeuristicStreams.Stream) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.TransportSignificantTermsHeuristicModule
 
registerStream() - Static method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
 
registerStream(InternalFacet.Stream, BytesReference...) - Static method in class org.elasticsearch.search.facet.InternalFacet.Streams
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
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.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.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.InternalPercentileRanks
 
registerStreams() - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
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.facet.datehistogram.InternalCountDateHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.datehistogram.InternalDateHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.histogram.InternalHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.terms.InternalTermsFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.termsstats.InternalTermsStatsFacet
 
registerSuggester(Class<? extends Suggester>) - Method in class org.elasticsearch.search.suggest.SuggestModule
 
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(MutableShardRouting) - 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
 
relation(ShapeRelation) - Method in class org.elasticsearch.index.query.GeoShapeFilterBuilder
Sets the relation of query shape and indexed shape.
Releasable - Interface in org.elasticsearch.common.lease
Specialization of AutoCloseable that may only throw an ElasticsearchException.
ReleasableBytesReference - Interface in org.elasticsearch.common.bytes
A bytes reference that needs to be released once its usage is done.
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
An bytes stream output that allows providing a BigArrays instance expecting it to require releasing its content (ReleasableBytesStreamOutput.bytes()) once done.
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
An extension to PagedBytesReference that requires releasing its content.
ReleasablePagedBytesReference(BigArrays, ByteArray, int) - Constructor for class org.elasticsearch.common.bytes.ReleasablePagedBytesReference
 
ReleasablePagedBytesReference(BigArrays, ByteArray, int, int) - Constructor for class org.elasticsearch.common.bytes.ReleasablePagedBytesReference
 
Releasables - Enum in org.elasticsearch.common.lease
Utility methods to work with Releasables.
release(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock.GlobalLockable
 
release(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
 
release(ContextDocIdSet) - Method in interface org.elasticsearch.index.cache.docset.DocSetCache
 
release(ContextDocIdSet) - Method in class org.elasticsearch.index.cache.docset.none.NoneDocSetCache
 
release(ContextDocIdSet) - Method in class org.elasticsearch.index.cache.docset.simple.SimpleDocSetCache
 
release() - Method in class org.elasticsearch.index.engine.Engine.GetResult
 
release() - Method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
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
 
releaseIrrelevantSearchContexts(AtomicArray<? extends QuerySearchResultProvider>, AtomicArray<IntArrayList>) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
Releases shard targets that are not used in the docsIdsToLoad.
relevantHeaders() - Method in class org.elasticsearch.rest.RestController
Returns the REST headers that get copied over from a RestRequest to its corresponding TransportRequest(s).
reloadConfig() - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
relocate(MutableShardRouting, String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
Relocate a shard to another node.
relocated(String) - Method in class org.elasticsearch.index.shard.IndexShard
 
relocating() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
relocating() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
Returns true iff the this shard is currently relocating to another node.
relocatingNodeId - Variable in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
relocatingNodeId() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
relocatingNodeId() - Method in interface 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
Return the number of shards remaining in this ShardsIterator
remaining - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
remainingCapacity() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
 
remote(String) - Method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
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
 
removalListener - Variable in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
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(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(Object) - Method in class org.elasticsearch.common.collect.IdentityHashSet
Removes the specified element from this set if it is present.
remove(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
 
remove(long) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
remove(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
 
remove(K) - Method in class org.elasticsearch.common.collect.MapBuilder
 
remove(MulticastChannel.Listener) - Method in class org.elasticsearch.common.network.MulticastChannel.MultiListener
 
remove(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings.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(String) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
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.mapper.MapperService
 
remove(Iterable<ObjectMapper>) - Method in class org.elasticsearch.index.mapper.ObjectMappers
 
remove(ObjectMapper) - Method in class org.elasticsearch.index.mapper.ObjectMappers
 
remove(String) - Method in class org.elasticsearch.index.store.Store.LegacyChecksums
 
REMOVE - Static variable in class org.elasticsearch.plugins.PluginManager.ACTION
 
remove(RiverClusterStateListener) - Method in class org.elasticsearch.river.cluster.RiverClusterService
 
remove(RiverRouting) - Method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
remove(RiverName) - Method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
remove(Object) - Method in class org.elasticsearch.search.lookup.DocLookup
 
remove(Object) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
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(LongContainer) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
removeAll(LongPredicate) - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap.Builder
 
removeAll(ObjectContainer<? extends KType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
 
removeAll(ObjectPredicate<? super KType>) - 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
 
removeAttribute(String) - Method in class org.elasticsearch.node.service.NodeService
 
removeConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
 
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
 
removeFailureListener(MergeSchedulerProvider.FailureListener) - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
removeFilter(SettingsFilter.Filter) - Method in class org.elasticsearch.common.settings.SettingsFilter
 
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(MergeSchedulerProvider.Listener) - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
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

This listener is called for each snapshot that finishes restore operation in the cluster.

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
 
removeMapping(DeleteMappingClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
 
removeNodeAttribute(String) - Method in class org.elasticsearch.node.service.NodeService
Deprecated.
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) - 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(Directory, String, String) - Method in class org.elasticsearch.index.store.DirectoryService
 
renameFile(DirectoryService, String, String) - Method in class org.elasticsearch.index.store.DistributorDirectory
Renames the given source file to the given target file unless the target already exists.
renameFile(Directory, String, String) - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
renameFile(Directory, String, String) - Method in class org.elasticsearch.index.store.ram.RamDirectoryService
 
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

See RestoreSnapshotRequest.renamePattern(String) for more information.

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.
replace(String, String, String) - Static method in class org.elasticsearch.common.Strings
Replace all occurences 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
 
replacePlaceholders(String, PropertyPlaceholder.PlaceholderResolver) - Method in class org.elasticsearch.common.property.PropertyPlaceholder
Replaces all placeholders of format ${name} with the value returned from the supplied PropertyPlaceholder.PlaceholderResolver.
replacePropertyPlaceholders() - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Runs across all the settings set on this builder and replaces ${...} elements in the each setting value according to the following logic:

replayCollection(BucketCollector) - Method in class org.elasticsearch.search.aggregations.RecordingBucketCollector
Replay a previously executed set of calls to the BucketCollector.collect(int, long) method
replayCollection(BucketCollector) - Method in class org.elasticsearch.search.aggregations.RecordingPerReaderBucketCollector
 
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
 
replicaRequest() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryResponse
 
replicaShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
replicaShardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
ReplicationShardOperationFailedException - Exception in org.elasticsearch.action.support.replication
An exception indicating that a failure occurred performing an operation on the shard.
ReplicationShardOperationFailedException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationShardOperationFailedException
 
ReplicationShardOperationFailedException(ShardId, Throwable) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationShardOperationFailedException
 
ReplicationShardOperationFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationShardOperationFailedException
 
replicationType(ReplicationType) - Method in class org.elasticsearch.action.bulk.BulkRequest
Set the replication type for this operation.
replicationType() - Method in class org.elasticsearch.action.bulk.BulkRequest
 
replicationType() - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
replicationType - Variable in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
replicationType() - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
replicationType(ReplicationType) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
Sets the replication type.
replicationType(String) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
Sets the replication type.
ReplicationType - Enum in org.elasticsearch.action.support.replication
The type of replication to perform.
replicationType() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
The replication type.
replicationType(ReplicationType) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Sets the replication type.
replicationType(String) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Sets the replication type.
replicationType() - Method in class org.elasticsearch.action.update.UpdateRequest
The replication type.
replicationType(ReplicationType) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the replication type.
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
RepositoriesMetaData.Factory - Class in org.elasticsearch.cluster.metadata
Repository metadata factory
RepositoriesModule - Class in org.elasticsearch.repositories
Module responsible for registering other repositories.
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

This method is called only on the master node

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
 
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
 
RepositoryModule - Class in org.elasticsearch.repositories
This module spawns specific repository module
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
Map of registered repository types and associated with these types modules
RepositoryTypesRegistry(ImmutableMap<String, Class<? extends Module>>) - Constructor for class org.elasticsearch.repositories.RepositoryTypesRegistry
Creates new repository with given map of types
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
 
request - Variable in class org.elasticsearch.action.ActionRequestBuilder
 
request() - Method in class org.elasticsearch.action.ActionRequestBuilder
 
request() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
 
request() - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
 
request() - Method in class org.elasticsearch.action.search.SearchRequestBuilder
 
request - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
request() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.InternalRequest
 
request - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryOperationRequest
 
request - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ReplicaOperationRequest
 
request() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.InternalRequest
 
request() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.ShardSingleOperationRequest
 
request() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction.InternalRequest
 
request() - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction.InternalRequest
 
Request(String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Request
 
request() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
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
 
requestedSize() - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
 
requestHandler - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport.HttpChannelPipelineFactory
 
requestId() - Method in exception org.elasticsearch.transport.ResponseHandlerNotFoundTransportException
 
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.
requireCustomQueryWrappingFilter() - Method in class org.elasticsearch.index.query.QueryParseContext
 
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
 
requiredAverageNumberOfShardsPerNode() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
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
 
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(ClusterRerouteRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
reroute(ClusterRerouteRequest, ActionListener<ClusterRerouteResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
Reroutes the routing table based on the live nodes.
reroute(ClusterState, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
Reroutes the routing table based on the live nodes.
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
 
rerouteWithNoReassign(ClusterState) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
Only handles reroute but *without* any reassignment of unassigned shards or rebalancing.
rerouteWithNoReassign(ClusterState, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
Only handles reroute but *without* any reassignment of unassigned shards or rebalancing.
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, String, DiscoveryNode) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
 
reset() - Method in class jsr166e.DoubleAdder
Resets variables maintaining the sum to zero.
reset() - Method in class jsr166e.DoubleMaxUpdater
Resets variables maintaining updates to Double.NEGATIVE_INFINITY.
reset() - Method in class jsr166e.LongAdder
Resets variables maintaining the sum to zero.
reset() - Method in class jsr166e.LongMaxUpdater
Resets variables maintaining updates to Long.MIN_VALUE.
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() - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
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(StreamInput) - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
reset() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
reset() - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
reset() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
 
reset() - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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.HandlesStreamInput
 
reset(StreamInput) - Method in class org.elasticsearch.common.io.stream.HandlesStreamInput
 
reset() - Method in class org.elasticsearch.common.io.stream.HandlesStreamOutput
 
reset() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
 
reset() - Method in class org.elasticsearch.common.io.stream.NoopStreamOutput
 
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() - Static method in class org.elasticsearch.common.logging.log4j.LogConfigurator
sets the loaded flag to false so that logging configuration can be overridden.
reset() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
reset(BytesRef, int) - Method in class org.elasticsearch.common.lucene.HashedBytesRef
 
reset() - Method in class org.elasticsearch.common.lucene.Lucene.EarlyTerminatingCollector
 
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 interface org.elasticsearch.gateway.Gateway
 
reset() - Method in class org.elasticsearch.gateway.local.LocalGateway
 
reset() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
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, DocumentMapper.ParseListener) - 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.Start
 
reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
 
reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
 
reset(InternalSearchHit, AtomicReaderContext, int, IndexReader) - 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
 
resetFromGeoHash(String) - Method in class org.elasticsearch.common.geo.GeoPoint
 
resetFromString(String) - Method in class org.elasticsearch.common.geo.GeoPoint
 
resetHashCode() - Method in class org.elasticsearch.common.lucene.HashedBytesRef
 
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
 
resetToBufferStart() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
Expert!, resets to buffer start, without the need to decompress it again.
Resident(ESLogger, IndexService, FieldMapper.Names, FieldDataType, IndicesFieldDataCacheListener) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataCache.Resident
 
resident() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
ResidentQueryParserCache - Class in org.elasticsearch.index.cache.query.parser.resident
A small (by default) query parser cache mainly to not parse the same query string several times if several shards exists on the same node.
ResidentQueryParserCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.query.parser.resident.ResidentQueryParserCache
 
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
Set the SortingNumericDocValues.count() and ensure that the SortingNumericDocValues.values array can store at least that many entries.
ResolvableFilter - Class in org.elasticsearch.common.lucene.search
A filter implementation that resolves details at the last possible moment between filter parsing and execution.
ResolvableFilter() - Constructor for class org.elasticsearch.common.lucene.search.ResolvableFilter
 
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() - Method in class org.elasticsearch.common.lucene.search.ResolvableFilter
 
resolve(byte) - Static method in enum org.elasticsearch.common.rounding.DateTimeUnit
 
resolveAggregator(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.OrderPath
Resolves the aggregator pointed by this path using the given root as a point of reference.
resolveBindHostAddress(String) - Method in class org.elasticsearch.common.network.NetworkService
 
resolveBindHostAddress(String, String) - Method in class org.elasticsearch.common.network.NetworkService
 
resolveClass(ObjectStreamClass) - Method in class org.elasticsearch.common.io.ThrowableObjectInputStream
 
resolveClosestNestedObjectMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
Resolves the closest inherited ObjectMapper that is nested.
resolveConfig(Environment, ImmutableSettings.Builder) - Static method in class org.elasticsearch.common.logging.log4j.LogConfigurator
 
resolveConfig(String) - Method in class org.elasticsearch.env.Environment
 
resolveConfigAndLoadToString(String) - Method in class org.elasticsearch.env.Environment
 
resolveCustomLocation(Settings, ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
Resolve the custom path for a index's shard.
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
 
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() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
resolveIndex() - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
resolveIndex() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
resolveIndex() - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
resolveIndex() - Method in class org.elasticsearch.action.get.TransportGetAction
 
resolveIndex() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
resolveIndex() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
resolveIndex() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction
 
resolveIndex() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
resolveIndex(Request) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
resolveIndex() - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
resolveIndex() - Method in class org.elasticsearch.action.termvector.TransportSingleShardMultiTermsVectorAction
 
resolveIndex() - Method in class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
resolveIndexRouting(String, String) - Method in class org.elasticsearch.cluster.metadata.MetaData
Returns indexing routing for the given index.
resolveInetAddress(String, String, String) - Method in class org.elasticsearch.common.network.NetworkService
 
resolveNode(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Resolve a node with a given id
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.
resolvePublishHostAddress(String) - Method in class org.elasticsearch.common.network.NetworkService
 
resolvePublishHostAddress(String, String) - Method in class org.elasticsearch.common.network.NetworkService
 
resolveRequest(ClusterState, TransportShardReplicationOperationAction<DeleteRequest, DeleteRequest, DeleteResponse>.InternalRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
resolveRequest(ClusterState, TransportShardSingleOperationAction<ExplainRequest, ExplainResponse>.InternalRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
resolveRequest(ClusterState, TransportShardSingleOperationAction<GetRequest, GetResponse>.InternalRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
 
resolveRequest(ClusterState, TransportShardSingleOperationAction<MultiGetShardRequest, MultiGetShardResponse>.InternalRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
resolveRequest(ClusterState, TransportShardReplicationOperationAction<IndexRequest, IndexRequest, IndexResponse>.InternalRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
resolveRequest(ClusterState, TransportShardReplicationOperationAction<Request, ReplicaRequest, Response>.InternalRequest, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
Resolves the request, by default doing nothing.
resolveRequest(ClusterState, TransportInstanceSingleOperationAction<Request, Response>.InternalRequest, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
Resolves the request.
resolveRequest(ClusterState, TransportShardSingleOperationAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
resolveRequest(ClusterState, TransportShardSingleOperationAction<TermVectorRequest, TermVectorResponse>.InternalRequest) - Method in class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
resolveRequest(ClusterState, TransportInstanceSingleOperationAction<UpdateRequest, UpdateResponse>.InternalRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
resolveRouting(ClusterState, DeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
resolveRouting(ClusterState, Request) - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
resolveSearchRouting(String, String) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
resolveSearchRouting(String, String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
resolveSort(String) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
 
resolveStrategy(String) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
resolveSuggestMode(String) - Static method in class org.elasticsearch.search.suggest.SuggestUtils
 
resolveTopmostAggregator(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.OrderPath
Resolves the topmost aggregator pointed by this path using the given root as a point of reference.
resolveTypeVariable(Type, Class<?>, TypeVariable) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
 
resolveValue(HasAggregations) - Method in class org.elasticsearch.search.aggregations.support.OrderPath
Resolves the value pointed by this path given an aggregations root
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
Generic resource watcher service Other elasticsearch services can register their resource watchers with this service using ResourceWatcherService.add(ResourceWatcher) method.
ResourceWatcherService(Settings, ThreadPool) - Constructor for class org.elasticsearch.watcher.ResourceWatcherService
 
ResourceWatcherService.Frequency - Enum in org.elasticsearch.watcher
 
response() - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse.Item
 
Response() - Constructor for class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response
 
response() - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response.Item
 
response() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryResponse
 
Response(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Response
 
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
 
ResponseHandlerNotFoundTransportException - Exception in org.elasticsearch.transport
 
ResponseHandlerNotFoundTransportException(long) - Constructor for exception org.elasticsearch.transport.ResponseHandlerNotFoundTransportException
 
REST_DECODER - Static variable in class org.elasticsearch.rest.support.RestUtils
 
RestActionListener<Response> - Class in org.elasticsearch.rest.action.support
An action listener that requires RestActionListener.processResponse(Object) to be implemented and will automatically handle failures.
RestActionListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.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
 
restart(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
RestBuilderListener<Response> - Class in org.elasticsearch.rest.action.support
A REST action listener that builds an XContentBuilder based response.
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
 
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
 
RestDeleteByQueryAction - Class in org.elasticsearch.rest.action.deletebyquery
 
RestDeleteByQueryAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.deletebyquery.RestDeleteByQueryAction
 
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
 
RestDeleteMappingAction - Class in org.elasticsearch.rest.action.admin.indices.mapping.delete
 
RestDeleteMappingAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.mapping.delete.RestDeleteMappingAction
 
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
Action for /_search/exists endpoint
RestExistsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.exists.RestExistsAction
 
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
 
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
 
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) - 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) - 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
 
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
 
RestIndicesStatusAction - Class in org.elasticsearch.rest.action.admin.indices.status
 
RestIndicesStatusAction(Settings, RestController, Client, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.indices.status.RestIndicesStatusAction
 
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
 
RestMoreLikeThisAction - Class in org.elasticsearch.rest.action.mlt
 
RestMoreLikeThisAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.mlt.RestMoreLikeThisAction
 
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.termvector
 
RestMultiTermVectorsAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.termvector.RestMultiTermVectorsAction
 
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
 
RestNodesRestartAction - Class in org.elasticsearch.rest.action.admin.cluster.node.restart
 
RestNodesRestartAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.node.restart.RestNodesRestartAction
 
RestNodesShutdownAction - Class in org.elasticsearch.rest.action.admin.cluster.node.shutdown
 
RestNodesShutdownAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.cluster.node.shutdown.RestNodesShutdownAction
 
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
 
RestOptimizeAction - Class in org.elasticsearch.rest.action.admin.indices.optimize
 
RestOptimizeAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.admin.indices.optimize.RestOptimizeAction
 
restorable() - Method in enum org.elasticsearch.snapshots.SnapshotState
Returns true if snapshot can be restored (at least partially)
restore(SnapshotId, ShardId, ShardId, RecoveryState) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
Restores snapshot of the shard.
restore(SnapshotId, ShardId, ShardId, RecoveryState) - Method in interface org.elasticsearch.index.snapshots.IndexShardRepository
Restores snapshot of the shard.
restore(RecoveryState) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotAndRestoreService
Restores shard from RestoreSource associated with this shard in routing table
RestoreInfo - Class in org.elasticsearch.snapshots
Information about successfully completed restore operation.
RestoreInfo(String, ImmutableList<String>, int, int) - Constructor for class org.elasticsearch.snapshots.RestoreInfo
 
RestoreMetaData - Class in org.elasticsearch.cluster.metadata
Meta data about restore processes that are currently executing
RestoreMetaData(ImmutableList<RestoreMetaData.Entry>) - Constructor for class org.elasticsearch.cluster.metadata.RestoreMetaData
Constructs new restore metadata
RestoreMetaData(RestoreMetaData.Entry...) - Constructor for class org.elasticsearch.cluster.metadata.RestoreMetaData
Constructs new restore metadata
RestoreMetaData.Entry - Class in org.elasticsearch.cluster.metadata
Restore metadata
RestoreMetaData.Factory - Class in org.elasticsearch.cluster.metadata
Restore metadata factory
RestoreMetaData.ShardRestoreStatus - Class in org.elasticsearch.cluster.metadata
Represents status of a restored shard
RestoreMetaData.State - Enum in org.elasticsearch.cluster.metadata
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

Restore operation is performed in several stages.

RestoreService(Settings, ClusterService, RepositoriesService, TransportService, AllocationService, MetaDataCreateIndexService, DynamicSettings) - Constructor for class org.elasticsearch.snapshots.RestoreService
 
RestoreService.RestoreCompletionResponse - Class in org.elasticsearch.snapshots
 
RestoreService.RestoreRequest - Class in org.elasticsearch.snapshots
Restore snapshot request
restoreSnapshot(RestoreSnapshotRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Restores a snapshot.
restoreSnapshot(RestoreSnapshotRequest, ActionListener<RestoreSnapshotResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Restores a snapshot.
restoreSnapshot(RestoreSnapshotRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
restoreSnapshot(RestoreSnapshotRequest, ActionListener<RestoreSnapshotResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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(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(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
Constructs new restore snapshot request builder
RestoreSnapshotRequestBuilder(ClusterAdminClient, 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 - Variable in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
restoreSource() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
RestoreSource - Class in org.elasticsearch.cluster.routing
Represents snapshot and index from which a recovering index should be restored
RestoreSource(SnapshotId, String) - Constructor for class org.elasticsearch.cluster.routing.RestoreSource
 
restoreSource() - Method in interface 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
 
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
A REST enabled action listener that has a basic onFailure implementation, and requires sub classes to only implement RestResponseListener.buildResponse(Object).
RestResponseListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.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
 
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 - 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
 
RestTable - Class in org.elasticsearch.rest.action.support
 
RestTable() - Constructor for class org.elasticsearch.rest.action.support.RestTable
 
RestTermVectorAction - Class in org.elasticsearch.rest.action.termvector
This class parses the json request and translates it into a TermVectorRequest.
RestTermVectorAction(Settings, RestController, Client) - Constructor for class org.elasticsearch.rest.action.termvector.RestTermVectorAction
 
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
 
resume() - Method in class org.elasticsearch.watcher.WatcherHandle
 
reThrow(Throwable) - Static method in class org.apache.lucene.util.XIOUtils
Simple utility method that takes a previously caught Throwable and rethrows either IOException or an unchecked exception.
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.
reThrowUnchecked(Throwable) - Static method in class org.apache.lucene.util.XIOUtils
Simple utility method that takes a previously caught Throwable and rethrows it as an unchecked exception.
retransSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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.
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>, ImmutableList<DiscoveryNode>, int, ThreadPool, ESLogger) - 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
 
retryPrimaryException(Throwable) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
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.
reuse(FsTranslogFile) - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
reuse(FsTranslogFile) - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
reuse(FsTranslogFile) - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
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
Create a new ReverseNested aggregation with the given name.
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) - 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
Builder for the ReverseNested aggregation.
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, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ReverseTokenFilterFactory
 
revertTransient() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
revertTransient() - Method in interface org.elasticsearch.index.translog.Translog
Reverts back to not have a transient translog.
revision - Variable in class org.elasticsearch.Version
 
rewrite(IndexReader) - Method in class org.apache.lucene.queries.BlendedTermQuery
 
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(IndexReader) - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
Rewrites the query.
rewrite(IndexReader) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.LateParsingQuery
 
rewrite(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
 
rewrite(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
 
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
 
rewrite(IndexReader) - Method in class org.elasticsearch.index.search.child.ChildrenQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.index.search.child.ParentQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
 
rewrite(Query) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
rewrite(Query) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
rewriteIndexReader - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
rewriteMethod() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
rewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
rewriteMethod - Variable in class org.elasticsearch.index.search.MatchQuery
 
rewrittenChildQuery - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
RIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
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
 
River - Interface in org.elasticsearch.river
Allows to import data into elasticsearch via plugin Gets allocated on a node and eventually automatically re-allocated if needed
riverClusterChanged(RiverClusterChangedEvent) - Method in interface org.elasticsearch.river.cluster.RiverClusterStateListener
 
RiverClusterChangedEvent - Class in org.elasticsearch.river.cluster
 
RiverClusterChangedEvent(String, RiverClusterState, RiverClusterState) - Constructor for class org.elasticsearch.river.cluster.RiverClusterChangedEvent
 
RiverClusterService - Class in org.elasticsearch.river.cluster
 
RiverClusterService(Settings, TransportService, ClusterService) - Constructor for class org.elasticsearch.river.cluster.RiverClusterService
 
RiverClusterState - Class in org.elasticsearch.river.cluster
 
RiverClusterState(long, RiverClusterState) - Constructor for class org.elasticsearch.river.cluster.RiverClusterState
 
RiverClusterState.Builder - Class in org.elasticsearch.river.cluster
 
RiverClusterStateListener - Interface in org.elasticsearch.river.cluster
 
RiverClusterStateUpdateTask - Interface in org.elasticsearch.river.cluster
 
RiverComponent - Interface in org.elasticsearch.river
 
RiverException - Exception in org.elasticsearch.river
 
RiverException(RiverName, String) - Constructor for exception org.elasticsearch.river.RiverException
 
RiverException(RiverName, String, Throwable) - Constructor for exception org.elasticsearch.river.RiverException
 
RiverException(RiverName, boolean, String, Throwable) - Constructor for exception org.elasticsearch.river.RiverException
 
RiverIndexName - Annotation Type in org.elasticsearch.river
 
RiverIndexName.Conf - Class in org.elasticsearch.river
 
RiverModule - Class in org.elasticsearch.river
 
RiverModule(RiverName, Map<String, Object>, Settings, RiversTypesRegistry) - Constructor for class org.elasticsearch.river.RiverModule
 
riverName - Variable in class org.elasticsearch.river.AbstractRiverComponent
 
riverName() - Method in class org.elasticsearch.river.AbstractRiverComponent
 
riverName() - Method in interface org.elasticsearch.river.RiverComponent
 
riverName() - Method in exception org.elasticsearch.river.RiverException
 
RiverName - Class in org.elasticsearch.river
 
RiverName(String, String) - Constructor for class org.elasticsearch.river.RiverName
 
riverName() - Method in class org.elasticsearch.river.routing.RiverRouting
 
RiverNameModule - Class in org.elasticsearch.river
 
RiverNameModule(RiverName) - Constructor for class org.elasticsearch.river.RiverNameModule
 
RiverNodeHelper - Class in org.elasticsearch.river.cluster
 
RiverNodeHelper() - Constructor for class org.elasticsearch.river.cluster.RiverNodeHelper
 
RiverRouting - Class in org.elasticsearch.river.routing
 
RiverSettings - Class in org.elasticsearch.river
(shayy.banon)
RiverSettings(Settings, Map<String, Object>) - Constructor for class org.elasticsearch.river.RiverSettings
 
RiversManager - Class in org.elasticsearch.river
 
RiversManager(Settings, RiversService, RiverClusterService, RiversRouter) - Constructor for class org.elasticsearch.river.RiversManager
 
RiversModule - Class in org.elasticsearch.river
 
RiversModule(Settings) - Constructor for class org.elasticsearch.river.RiversModule
 
RiversPluginsModule - Class in org.elasticsearch.river
A module that simply calls the PluginsService.processModule(org.elasticsearch.common.inject.Module) in order to allow plugins to pre process specific river modules.
RiversPluginsModule(Settings, PluginsService) - Constructor for class org.elasticsearch.river.RiversPluginsModule
 
RiversRouter - Class in org.elasticsearch.river.routing
 
RiversRouter(Settings, Client, ClusterService, RiverClusterService, ThreadPool) - Constructor for class org.elasticsearch.river.routing.RiversRouter
 
RiversRouting - Class in org.elasticsearch.river.routing
 
RiversRouting.Builder - Class in org.elasticsearch.river.routing
 
RiversService - Class in org.elasticsearch.river
 
RiversService(Settings, Client, ThreadPool, ClusterService, RiversTypesRegistry, RiverClusterService, Injector) - Constructor for class org.elasticsearch.river.RiversService
 
RiversTypesRegistry - Class in org.elasticsearch.river
A type registry for rivers
RiversTypesRegistry(ImmutableMap<String, Class<? extends Module>>) - Constructor for class org.elasticsearch.river.RiversTypesRegistry
 
rm(Path...) - Static method in class org.apache.lucene.util.XIOUtils
Deletes one or more files or directories (and everything underneath it).
RollbackFailedEngineException - Exception in org.elasticsearch.index.engine
 
RollbackFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.RollbackFailedEngineException
 
RollbackNotAllowedEngineException - Exception in org.elasticsearch.index.engine
 
RollbackNotAllowedEngineException(ShardId, String) - Constructor for exception org.elasticsearch.index.engine.RollbackNotAllowedEngineException
 
RomanianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
RomanianAnalyzerProvider(Index, Settings, 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.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(AtomicReaderContext) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
Get a FixedBitSet 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
 
rootMapper(Class<T>) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
RootMapper - Interface in org.elasticsearch.index.mapper
A mapper that exists only as a mapper within a root object.
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
Basic ShardShuffler implementation that uses an AtomicInteger to generate seeds and uses a rotation to permute shards.
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)).
ROUND_CEIL - Static variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
 
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.PrePostRounding - 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.PrePostRounding
 
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
 
routing() - Method in class org.elasticsearch.action.count.CountRequest
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
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
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() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
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.deletebyquery.DeleteByQueryRequest
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.deletebyquery.DeleteByQueryRequest
The routing values to control the shards that the search will be executed on.
routing() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
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
 
routing() - Method in class org.elasticsearch.action.exists.ExistsRequest
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
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
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.mlt.MoreLikeThisRequest
 
routing(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
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.termvector.TermVectorRequest
 
routing(String) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
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.UidAndRoutingFieldsVisitor
 
routing() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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() - 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
 
routing(RiversRouting.Builder) - Method in class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
routing(RiversRouting) - Method in class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
routing() - Method in class org.elasticsearch.river.cluster.RiverClusterState
 
routing(RiversRouting) - Method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
routing(RiverName) - Method in class org.elasticsearch.river.routing.RiversRouting
 
RoutingAllocation - Class in org.elasticsearch.cluster.routing.allocation
The RoutingAllocation keep the state of the current allocation of shards and holds the AllocationDeciders which are responsible for the current routing state.
RoutingAllocation(AllocationDeciders, RoutingNodes, DiscoveryNodes, ClusterInfo) - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
Creates a new RoutingAllocation
RoutingAllocation.Result - Class in org.elasticsearch.cluster.routing.allocation
this class is used to describe results of a RoutingAllocation
routingEntry() - Method in class org.elasticsearch.index.shard.IndexShard
Returns the latest cluster routing entry received with this shard.
routingEntry(ShardRouting) - Method in class org.elasticsearch.index.shard.IndexShard
 
routingEntry(ShardRouting) - Method in class org.elasticsearch.index.shard.ShadowIndexShard
In addition to the regular accounting done in IndexShard.routingEntry(org.elasticsearch.cluster.routing.ShardRouting), if this shadow replica needs to be promoted to a primary, the shard is failed in order to allow a new primary to be re-allocated.
RoutingException - Exception in org.elasticsearch.cluster.routing
A base Exceptions 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
 
RoutingExplanations - Class in org.elasticsearch.cluster.routing.allocation
Class used to encapsulate a number of RerouteExplanation explanations.
RoutingExplanations() - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
 
routingFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
RoutingFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
RoutingFieldMapper() - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
RoutingFieldMapper(FieldType, boolean, String, PostingsFormatProvider, DocValuesFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
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
 
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<MutableShardRouting>) - 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.ClusterState
 
routingNodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
Get current routing nodes
RoutingNodes - Class in org.elasticsearch.cluster.routing
RoutingNodes represents a copy the routing information contained in the cluster state.
RoutingNodes(ClusterState) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
 
routingNodes(ClusterState) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
RoutingNodes.RoutingNodeIterator - Class in org.elasticsearch.cluster.routing
 
RoutingNodes.RoutingNodesIterator - Class in org.elasticsearch.cluster.routing
 
RoutingNodes.UnassignedShards - 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
A RoutingService listens to clusters state.
RoutingService(Settings, ThreadPool, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.routing.RoutingService
 
routingStateChanged() - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
Should be called when the shard routing state has changed (note, after the state has been set on the shard).
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
Get the RoutingTable referenced by this 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
 
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
This class defines RoutingExceptions related to the validation of routing
RoutingValidationException(RoutingTableValidation) - Constructor for exception org.elasticsearch.cluster.routing.RoutingValidationException
 
run() - Method in class org.elasticsearch.cluster.InternalClusterInfoService.ClusterInfoUpdateJob
 
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.
run() - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
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 class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
runAsDouble() - Method in interface org.elasticsearch.script.SearchScript
 
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 class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
runAsFloat() - Method in interface org.elasticsearch.script.SearchScript
 
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 class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
runAsLong() - Method in interface org.elasticsearch.script.SearchScript
 
runDeferredCollections(long...) - Method in class org.elasticsearch.search.aggregations.Aggregator
 
runOnlyOnMaster() - Method in class org.elasticsearch.cluster.ClusterStateNonMasterUpdateTask
 
runOnlyOnMaster() - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
indicates whether this task should only run if current node is master
runOnlyOnMaster() - Method in class org.elasticsearch.cluster.ProcessedClusterStateNonMasterUpdateTask
 
RussianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
RussianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.RussianAnalyzerProvider
 
RussianStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
RussianStemTokenFilterFactory(Index, Settings, 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
 

S

safeClose(IndexWriter) - Static method in class org.elasticsearch.common.lucene.Lucene
Closes the index writer, returning false if it failed to close.
safeSource() - Method in class org.elasticsearch.action.index.IndexRequest
 
safeSource() - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
 
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
 
sandboxed() - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
sandboxed() - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
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 - Static variable in class org.elasticsearch.action.search.type.ParsedScrollId
 
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.ScanFilter - Class in org.elasticsearch.search.scan
 
ScandinavianFoldingFilterFactory - Class in org.elasticsearch.index.analysis
Factory for ScandinavianFoldingFilter
ScandinavianFoldingFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ScandinavianFoldingFilterFactory
 
ScandinavianNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
Factory for ScandinavianNormalizationFilter
ScandinavianNormalizationFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ScandinavianNormalizationFilterFactory
 
ScanFilter(ConcurrentMap<IndexReader, ScanContext.ReaderState>, ScanContext.ScanCollector) - Constructor for class org.elasticsearch.search.scan.ScanContext.ScanFilter
 
schedule(TimeValue, String, Runnable) - Method in class org.elasticsearch.threadpool.ThreadPool
 
scheduler() - Method in class org.elasticsearch.threadpool.ThreadPool
 
scheduleReroute() - Method in class org.elasticsearch.cluster.routing.RoutingService
make sure that a reroute will be done by the next scheduled check
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() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
score() - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
score(int, float) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
Deprecated.
 
score(int, float) - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
 
score(int, float) - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
 
score(int, float) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
 
score(int, float) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
 
score(int, float) - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
 
score(int, float) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionParser.AbstractDistanceScoreFunction
 
score(String) - Method in class org.elasticsearch.index.query.TopChildrenQueryBuilder
How to compute the score.
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
 
scoreDocsInOrder() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
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.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(AtomicReaderContext, Bits) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight
 
scorer - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
scorer(AtomicReaderContext, Bits) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentWeight
 
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
 
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
Defines how the scores from the matching child documents are mapped into the parent document.
scoreType(String) - Method in class org.elasticsearch.index.query.HasParentQueryBuilder
Defines how the parent score is mapped into the child documents.
scoreType - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
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.update.UpdateRequest
 
script(String, ScriptService.ScriptType) - Method in class org.elasticsearch.action.update.UpdateRequest
The script to execute.
script(String) - Method in class org.elasticsearch.action.update.UpdateRequest
The script to execute.
script(String, ScriptService.ScriptType, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
The script to execute.
script(String, String, ScriptService.ScriptType, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
The script to execute.
script(String) - Method in class org.elasticsearch.index.query.functionscore.script.ScriptScoreFunctionBuilder
 
script() - Method in class org.elasticsearch.script.ScriptParameterParser.ScriptParameterValue
 
script(String) - Method in class org.elasticsearch.search.aggregations.metrics.ValuesSourceMetricsAggregationBuilder
 
script() - Method in interface org.elasticsearch.search.aggregations.support.ScriptValues
 
script() - Method in class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
 
script() - Method in class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
 
script() - Method in class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
 
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(String) - Method in class org.elasticsearch.search.aggregations.ValuesSourceAggregationBuilder
Sets the script which generates the values.
script(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
 
script(String) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
A script allowing to either modify or ignore a provided term (can be accessed using term var).
script() - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsContext.ScriptField
 
SCRIPT_CACHE_EXPIRE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
 
SCRIPT_CACHE_SIZE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
 
SCRIPT_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
 
ScriptAggregator(GeoDistance.FixedSourceDistance, GeoDistanceFacet.Entry[], SearchScript) - Constructor for class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetExecutor.ScriptAggregator
 
ScriptAggregator(DoubleObjectOpenHashMap<InternalTermsStatsDoubleFacet.DoubleEntry>, SearchScript) - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor.ScriptAggregator
 
ScriptAggregator(LongObjectOpenHashMap<InternalTermsStatsLongFacet.LongEntry>, SearchScript) - Constructor for class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor.ScriptAggregator
 
ScriptAggregator(ObjectObjectOpenHashMap<HashedBytesRef, InternalTermsStatsStringFacet.StringEntry>, SearchScript) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor.ScriptAggregator
 
ScriptBytesValues - Class in org.elasticsearch.search.aggregations.support.values
SortedBinaryDocValues implementation that reads values from a script.
ScriptBytesValues(SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
 
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
DoubleValues implementation which is based on a script
ScriptDoubleValues(SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
 
scriptedMetric(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new ScriptedMetric aggregation with the given name.
ScriptedMetric - Interface in org.elasticsearch.search.aggregations.metrics.scripted
A metric aggregation that computes both its final and intermediate states using scripts.
ScriptedMetricAggregator - Class in org.elasticsearch.search.aggregations.metrics.scripted
 
ScriptedMetricAggregator(String, String, ScriptService.ScriptType, String, ScriptService.ScriptType, String, ScriptService.ScriptType, String, ScriptService.ScriptType, String, Map<String, Object>, Map<String, Object>, AggregationContext, Aggregator) - 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
Builder for the ScriptedMetric aggregation.
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
 
scriptField(String, String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Adds a script field under the given name with the provided script.
scriptField(String, String, Map<String, Object>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Adds a script field.
scriptField(String, String, String, Map<String, Object>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Adds a script field.
scriptField(String) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
Define a script field that will control the terms that will be used (and not filtered, as is the case when the script is provided on top of field / fields).
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
 
scriptFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A builder for filter based on a script.
ScriptFilter(String, String, ScriptService.ScriptType, Map<String, Object>, ScriptService, SearchLookup) - Constructor for class org.elasticsearch.index.query.ScriptFilterParser.ScriptFilter
 
ScriptFilterBuilder - Class in org.elasticsearch.index.query
 
ScriptFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.ScriptFilterBuilder
 
ScriptFilterParser - Class in org.elasticsearch.index.query
 
ScriptFilterParser() - Constructor for class org.elasticsearch.index.query.ScriptFilterParser
 
ScriptFilterParser.ScriptFilter - Class in org.elasticsearch.index.query
 
scriptFunction(String) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
scriptFunction(String, String) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
scriptFunction(String, String, Map<String, Object>) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
scriptFunction(String, Map<String, Object>) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
ScriptGeoDistanceFacetExecutor - Class in org.elasticsearch.search.facet.geodistance
 
ScriptGeoDistanceFacetExecutor(IndexGeoPointFieldData, double, double, DistanceUnit, GeoDistance, GeoDistanceFacet.Entry[], SearchContext, String, String, ScriptService.ScriptType, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetExecutor
 
ScriptGeoDistanceFacetExecutor.ScriptAggregator - Class in org.elasticsearch.search.facet.geodistance
 
ScriptHeuristic - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
ScriptHeuristic(ExecutableScript, String, String, ScriptService.ScriptType, Map<String, Object>) - 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
 
ScriptHistogramFacetExecutor - Class in org.elasticsearch.search.facet.histogram
 
ScriptHistogramFacetExecutor(String, String, ScriptService.ScriptType, String, ScriptService.ScriptType, Map<String, Object>, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.ScriptHistogramFacetExecutor
 
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
The language of the script to execute.
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(SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
 
ScriptModule - Class in org.elasticsearch.script
An Module which manages ScriptEngineServices, as well as named script
ScriptModule(Settings) - Constructor for class org.elasticsearch.script.ScriptModule
 
scriptParam(String, Object) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
Parameters for GeoDistanceFacetBuilder.valueScript(String) to improve performance when executing the same script with different parameters.
ScriptParameterParseException(String) - Constructor for exception org.elasticsearch.script.ScriptParameterParser.ScriptParameterParseException
 
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.ScriptParameterParseException - Exception in org.elasticsearch.script
 
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
Sets the script parameters to use with the script.
ScriptRangeFacetExecutor - Class in org.elasticsearch.search.facet.range
 
ScriptRangeFacetExecutor(String, String, ScriptService.ScriptType, String, ScriptService.ScriptType, Map<String, Object>, RangeFacet.Entry[], SearchContext) - Constructor for class org.elasticsearch.search.facet.range.ScriptRangeFacetExecutor
 
scriptRemoved(CompiledScript) - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
scriptRemoved(CompiledScript) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
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(String, Map<String, Object>, 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() - 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, NodeSettingsService) - 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
scriptSort(String, String) - Static method in class org.elasticsearch.search.sort.SortBuilders
Constructs a new script based sort.
ScriptSortBuilder - Class in org.elasticsearch.search.sort
Script sort builder allows to sort based on a custom script expression.
ScriptSortBuilder(String, String) - Constructor for class org.elasticsearch.search.sort.ScriptSortBuilder
Constructs a script sort builder with the script and the type.
ScriptSortParser - Class in org.elasticsearch.search.sort
 
ScriptSortParser() - Constructor for class org.elasticsearch.search.sort.ScriptSortParser
 
ScriptStatisticalFacetExecutor - Class in org.elasticsearch.search.facet.statistical
 
ScriptStatisticalFacetExecutor(String, String, ScriptService.ScriptType, Map<String, Object>, SearchContext) - Constructor for class org.elasticsearch.search.facet.statistical.ScriptStatisticalFacetExecutor
 
ScriptTermsStringFieldFacetExecutor - Class in org.elasticsearch.search.facet.terms.strings
 
ScriptTermsStringFieldFacetExecutor(int, int, TermsFacet.ComparatorType, SearchContext, ImmutableSet<BytesRef>, Pattern, String, String, ScriptService.ScriptType, Map<String, Object>, CacheRecycler) - Constructor for class org.elasticsearch.search.facet.terms.strings.ScriptTermsStringFieldFacetExecutor
 
scriptType() - Method in class org.elasticsearch.action.update.UpdateRequest
 
scriptType() - Method in class org.elasticsearch.index.query.TemplateQueryParser.TemplateContext
 
scriptType() - Method in class org.elasticsearch.script.ScriptParameterParser.ScriptParameterValue
 
ScriptValues - Interface in org.elasticsearch.search.aggregations.support
 
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.percolator.PercolateContext
 
scroll(Scroll) - Method in class org.elasticsearch.percolator.PercolateContext
 
scroll() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
scroll(Scroll) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
scroll() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
scroll(Scroll) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
scroll() - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
scroll(Scroll) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
scroll() - Method in class org.elasticsearch.search.internal.SearchContext
 
scroll(Scroll) - Method in class org.elasticsearch.search.internal.SearchContext
 
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(Scroll) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
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.
SCROLL_SEARCH_AFTER_MINIMUM_VERSION - Static variable in class org.elasticsearch.action.search.type.ParsedScrollId
 
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(SearchRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
search(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
search - Variable in class org.elasticsearch.index.engine.Segment
 
search(Object, SearchLookup, Map<String, Object>) - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
search(Object, SearchLookup, Map<String, Object>) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
search(Object, SearchLookup, Map<String, Object>) - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
 
search(Object, SearchLookup, Map<String, Object>) - Method in class org.elasticsearch.script.NativeScriptEngineService
 
search(Object, SearchLookup, Map<String, Object>) - Method in interface org.elasticsearch.script.ScriptEngineService
 
search(SearchLookup, String, String, ScriptService.ScriptType, Map<String, Object>) - Method in class org.elasticsearch.script.ScriptService
Compiles (or retrieves from cache) and executes the provided search script
search(List<AtomicReaderContext>, Weight, Collector) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(Weight, ScoreDoc, int) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(List<AtomicReaderContext>, Weight, ScoreDoc, int) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(Weight, int, Sort, boolean, boolean) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(Weight, FieldDoc, int, Sort, boolean, boolean, boolean) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(List<AtomicReaderContext>, Weight, FieldDoc, int, Sort, boolean, boolean, boolean) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(List<AtomicReaderContext>, Weight, Collector) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
SEARCH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
SEARCH_ANALYZER - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
 
SearchAction - Class in org.elasticsearch.action.search
 
searchAnalyzer - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
searchAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
searchAnalyzer - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
searchAnalyzer() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
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.DocumentMapper.Builder
 
searchAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
searchAnalyzer() - Method in interface org.elasticsearch.index.mapper.FieldMapper
The analyzer that will be used to search the field.
searchAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService
 
searchAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
The best effort search analyzer associated with this field.
searchContext - Variable in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
searchContext() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
SearchContext - Class in org.elasticsearch.search.internal
 
SearchContext() - Constructor for class org.elasticsearch.search.internal.SearchContext
 
SearchContext.Lifetime - Enum in org.elasticsearch.search.internal
The life time of an object that is used during search execution.
SearchContextAggregations - Class in org.elasticsearch.search.aggregations
The aggregation context that is part of the search context.
SearchContextAggregations(AggregatorFactories) - 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
 
SearchContextFacets - Class in org.elasticsearch.search.facet
 
SearchContextFacets(List<SearchContextFacets.Entry>) - Constructor for class org.elasticsearch.search.facet.SearchContextFacets
 
SearchContextFacets.Entry - Class in org.elasticsearch.search.facet
 
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
 
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.fetch.FetchSubPhase.HitContext
 
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
 
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
 
searchFrom(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
From which search result set to return.
searchFrom() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
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.
searchIndices(String...) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The indices the resulting mlt query will run against.
searchIndices() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The indices the resulting mlt query will run against.
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) - Constructor for exception org.elasticsearch.search.SearchParseException
 
SearchParseException(SearchContext, String, Throwable) - Constructor for exception org.elasticsearch.search.SearchParseException
 
SearchPhase - Interface in org.elasticsearch.search
 
searchPhaseController - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
SearchPhaseController - Class in org.elasticsearch.search.controller
 
SearchPhaseController(Settings, CacheRecycler, 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
 
SearchPhaseResult - Interface in org.elasticsearch.search
 
searchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
searchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
searchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
searchQuoteAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
searchQuoteAnalyzer() - Method in interface org.elasticsearch.index.mapper.FieldMapper
The analyzer that will be used for quoted search on the field.
searchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService
 
searchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
 
searchQuotedAnalyzer - Variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
searchQuotedAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
searchQuotedAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
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(Client) - 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(Scroll) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
An optional search scroll request to be able to continue and scroll the search operation.
searchScroll() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
An optional search scroll request to be able to continue and scroll the search operation.
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
 
searchScroll(SearchScrollRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
searchScroll(SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
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(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(Client) - Constructor for class org.elasticsearch.action.search.SearchScrollRequestBuilder
 
SearchScrollRequestBuilder(Client, String) - Constructor for class org.elasticsearch.action.search.SearchScrollRequestBuilder
 
searchService - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
searchService() - Method in class org.elasticsearch.index.shard.IndexShard
 
SearchService - Class in org.elasticsearch.search
 
SearchService(Settings, ClusterService, IndicesService, IndicesWarmer, ThreadPool, ScriptService, CacheRecycler, PageCacheRecycler, BigArrays, DfsPhase, QueryPhase, FetchPhase, IndicesQueryCache) - Constructor for class org.elasticsearch.search.SearchService
 
SearchServiceListener<T> - Interface in org.elasticsearch.search.action
 
SearchServiceTransportAction - Class in org.elasticsearch.search.action
An encapsulation of SearchService operations exposed through transport.
SearchServiceTransportAction(Settings, ThreadPool, TransportService, ClusterService, SearchService) - Constructor for class org.elasticsearch.search.action.SearchServiceTransportAction
 
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(ClusterSearchShardsRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
searchShards(ClusterSearchShardsRequest, ActionListener<ClusterSearchShardsResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
searchShards(ClusterState, String[], String[], Map<String, Set<String>>, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
searchShards(ClusterState, String[], String[], Map<String, Set<String>>, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
searchShardsCount(ClusterState, String[], String[], Map<String, Set<String>>, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
searchShardsCount(ClusterState, String[], String[], Map<String, Set<String>>, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
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
 
searchSize(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The number of documents to return, defaults to 10.
searchSize() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
searchSource(SearchSourceBuilder) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
An optional search source request allowing to control the search request for the more like this documents.
searchSource(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
An optional search source request allowing to control the search request for the more like this documents.
searchSource(Map) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
searchSource(XContentBuilder) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
searchSource(byte[]) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
An optional search source request allowing to control the search request for the more like this documents.
searchSource(byte[], int, int, boolean) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
An optional search source request allowing to control the search request for the more like this documents.
searchSource(BytesReference, boolean) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
An optional search source request allowing to control the search request for the more like this documents.
searchSource() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
An optional search source request allowing to control the search request for the more like this documents.
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
 
searchSourceUnsafe() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
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.mlt.MoreLikeThisRequest
The search type of the mlt search query.
searchType(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The search type of the mlt search query.
searchType() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The search type of the mlt search query.
searchType(SearchType) - Method in class org.elasticsearch.action.search.SearchRequest
The search type to execute, defaults to SearchType.DEFAULT.
searchType(String) - Method in class org.elasticsearch.action.search.SearchRequest
The a string representation search type to execute, defaults to SearchType.DEFAULT.
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
 
searchTypes(String...) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The types the resulting mlt query will run against.
searchTypes() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The types the resulting mlt query will run against.
SECOND - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
seconds() - Method in class org.elasticsearch.common.unit.TimeValue
 
seconds(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
secondsFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
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.AdapterStreamOutput
 
seek(long) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
seek(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
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
 
seekPositionSupported() - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
seekPositionSupported() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
seekPositionSupported() - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
seekTo(long) - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
seekTo(long) - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
Seek to the specified position in the translog stream
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(AtomicReader) - Static method in class org.elasticsearch.common.lucene.SegmentReaderUtils
Tries to extract a segment reader from the given index reader.
segmentReaderOrNull(AtomicReader) - Static method in class org.elasticsearch.common.lucene.SegmentReaderUtils
Tries to extract a segment reader from the given index reader and returns it, otherwise null is returned
SegmentReaderUtils - Class in org.elasticsearch.common.lucene
 
SegmentReaderUtils() - Constructor for class org.elasticsearch.common.lucene.SegmentReaderUtils
 
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(IndicesSegmentsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
segments(IndicesSegmentsRequest, ActionListener<IndicesSegmentResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
segments() - Method in class org.elasticsearch.index.engine.Engine
The list of segments in the engine.
segments() - Method in class org.elasticsearch.index.engine.InternalEngine
 
segments() - 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, FixedBitSet, FixedBitSet, 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, FixedBitSet, FixedBitSet, 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, FixedBitSet, FixedBitSet, 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, FixedBitSet, FixedBitSet) - 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.
selectedFields() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Return only term vectors for special selected fields.
selectedFields(String...) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Return only term vectors for special selected fields.
send(BytesReference) - Method in class org.elasticsearch.common.network.MulticastChannel
Send the data over the multicast channel.
sendClearAllScrollContexts(DiscoveryNode, ClearScrollRequest, ActionListener<Boolean>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteDfs(DiscoveryNode, ShardSearchTransportRequest, SearchServiceListener<DfsSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteFetch(DiscoveryNode, ShardSearchTransportRequest, SearchServiceListener<QueryFetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteFetch(DiscoveryNode, QuerySearchRequest, SearchServiceListener<QueryFetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteFetch(DiscoveryNode, InternalScrollSearchRequest, SearchServiceListener<QueryFetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteFetch(DiscoveryNode, ShardFetchSearchRequest, SearchServiceListener<FetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteFetchScroll(DiscoveryNode, ShardFetchRequest, SearchServiceListener<FetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteFirstPhase(DiscoveryNode, ShardSearchTransportRequest, SearchServiceListener<FirstResult>) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
sendExecuteQuery(DiscoveryNode, ShardSearchTransportRequest, SearchServiceListener<QuerySearchResultProvider>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteQuery(DiscoveryNode, QuerySearchRequest, SearchServiceListener<QuerySearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteQuery(DiscoveryNode, InternalScrollSearchRequest, SearchServiceListener<QuerySearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteScan(DiscoveryNode, ShardSearchTransportRequest, SearchServiceListener<QuerySearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteScan(DiscoveryNode, InternalScrollSearchRequest, SearchServiceListener<QueryFetchSearchResult>) - 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<Boolean>) - 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
 
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.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, 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
 
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
 
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_SEPERATORS - Static variable in class org.elasticsearch.search.suggest.completion.AnalyzingCompletionLookupProvider
 
SerialMergeSchedulerProvider - Class in org.elasticsearch.index.merge.scheduler
Deprecated.
This provider just provides ConcurrentMergeScheduler, and is removed in master.
SerialMergeSchedulerProvider(ShardId, Settings, ThreadPool) - Constructor for class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
Deprecated.
 
SerialMergeSchedulerProvider.CustomSerialMergeScheduler - Class in org.elasticsearch.index.merge.scheduler
Deprecated.
NOTE: subclasses TrackingCONCURRENTMergeScheduler, but we set max_merge_count = 2 and max_thread_count = 1, above
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
 
serverChannel - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
ServerChannelPipelineFactory(NettyTransport, String, Settings) - Constructor for class org.elasticsearch.transport.netty.NettyTransport.ServerChannelPipelineFactory
 
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
 
serverOpenChannels - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
serverOpenChannels - Variable in class org.elasticsearch.transport.netty.NettyTransport
 
services() - Method in class org.elasticsearch.plugins.AbstractPlugin
Defaults to return an empty list.
services() - Method in interface org.elasticsearch.plugins.Plugin
Node level services that will be automatically started/stopped/closed.
services() - Method in class org.elasticsearch.plugins.PluginsService
 
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.
setActiveOnly(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequestBuilder
 
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
setAllocationService(AllocationService) - Method in interface org.elasticsearch.discovery.Discovery
Another hack to solve dep injection problem..., note, this will be called before any start is called.
setAllocationService(AllocationService) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
setAllocationService(AllocationService) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
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(HighlighterContext) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
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.termvector.TermVectorResponse
 
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(float) - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
 
setBoost(boolean) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Sets whether to boost terms in query based on "score" or not.
setBoostFactor(float) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
Sets the boost factor to use when boosting terms
setBoostTerms(float) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
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
 
setBreakIterator(BreakIterator) - Method in class org.apache.lucene.search.postingshighlight.CustomPostingsHighlighter
 
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.
setChecksumOnMerge(boolean) - Method in class org.elasticsearch.index.engine.EngineConfig
Sets if checksums should be validated on merge
setChronology(Chronology) - Method in class org.joda.time.base.BaseDateTime
Sets the chronology of the datetime.
setClient(Client) - Method in class org.elasticsearch.script.ScriptService
 
setClusterService(ClusterService) - Method in class org.elasticsearch.index.cache.IndexCache
 
setClusterService(ClusterService) - Method in class org.elasticsearch.node.settings.NodeSettingsService
 
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.delete.DeleteRequestBuilder
Sets the consistency level.
setConsistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
 
setConsistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Sets the consistency level.
setConsistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequestBuilder
Sets the consistency level of write.
setConsistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequestBuilder
Sets the consistency level of write.
setConsistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Sets the consistency level of write.
SetConsoleCtrlHandler(StdCallLibrary.StdCallCallback, boolean) - Method in class org.elasticsearch.common.jna.Kernel32Library
Native call to the Kernel32 API to set a new Console Ctrl Handler.
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).
setContextQuery(List<ContextMapping.ContextQuery>) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
 
setCreate(boolean) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
Set to true to force only creation, not an update of an index template.
setCreate(boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Set to true to force this index to use IndexRequest.OpType.CREATE.
setCreate(boolean) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
Set to true to force this index to use IndexRequest.OpType.CREATE.
setCurrent(SearchContext) - Static method in class org.elasticsearch.search.internal.SearchContext
 
setCurrentReference(T) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
 
setDecay(double) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
 
setDefaultCompressor(Compressor) - Static method in class org.elasticsearch.common.compress.CompressorFactory
 
setDefaultFactory(ESLoggerFactory) - Static method in class org.elasticsearch.common.logging.ESLoggerFactory
Changes the default factory.
setDelay(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequestBuilder
The delay for the restart to occur.
setDelay(String) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequestBuilder
The delay for the restart to occur.
setDelay(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequestBuilder
The delay for the restart to occur.
setDelay(String) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequestBuilder
The delay for the restart to occur.
setDependency(Dependency) - Method in class org.elasticsearch.common.inject.internal.InternalContext
 
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.
setDistributor(Class<? extends Distributor>) - Method in class org.elasticsearch.index.store.StoreModule
 
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.termvector.TermVectorRequestBuilder
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.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
 
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.termvector.TermVectorResponse
 
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.
setDynamicSettings(NodeSettingsService, DynamicSettings) - Method in class org.elasticsearch.transport.TransportService
 
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.
setExecution(String) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
Sets the execution mode that controls how the range filter is executed.
setExists(boolean) - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
setExit(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequestBuilder
Should the JVM be exited as well or not.
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.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(BytesReference, boolean) - 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
 
setFacets(BytesReference) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Deprecated.
Facets are deprecated and will be removed in a future release. Please use aggregations instead.
setFacets(byte[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Deprecated.
Facets are deprecated and will be removed in a future release. Please use aggregations instead.
setFacets(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Deprecated.
Facets are deprecated and will be removed in a future release. Please use aggregations instead.
setFacets(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Deprecated.
Facets are deprecated and will be removed in a future release. Please use aggregations instead.
setFacets(Map) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Deprecated.
Facets are deprecated and will be removed in a future release. Please use aggregations instead.
setFailEngineOnCorruption(boolean) - Method in class org.elasticsearch.index.engine.EngineConfig
Sets if the engine should be failed in the case of a corrupted index.
setFailOnMergeFailure(boolean) - Method in class org.elasticsearch.index.engine.EngineConfig
Sets if the engine should be failed if a merge error is hit.
setFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
 
setFeatures(String...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
Deprecated.
use #setFeatures(Feature[]) instead
setFetchPhase(FetchPhase) - Method in class org.elasticsearch.search.fetch.innerhits.InnerHitsFetchSubPhase
 
setFetchService(ShapeFetchService) - Method in class org.elasticsearch.index.query.GeoShapeFilterParser
 
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.action.mlt.MoreLikeThisRequestBuilder
The fields of the document to use in order to find documents "like" this one.
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
 
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.get.GetRequestBuilder
Explicitly specify the fields that will be returned.
setFields(Fields, Set<String>, EnumSet<TermVectorRequest.Flag>, Fields) - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
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.termvector.TermVectorRequestBuilder
 
setFilterBuilder(FilterBuilder) - Method in class org.elasticsearch.action.percolate.PercolateSourceBuilder
Sets a filter to reduce the number of percolate queries to be evaluated.
setFilterCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
setFilterCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setFilterKeys(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
setFlush(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
Should flush be performed after the optimization.
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
 
setForce(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
Should the merge be forced even if there is a single segment with no deletions in the shard.
setForce(boolean) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
Deprecated.
unnecessary flag since 1.5.0
setFreq(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
 
setFreqCurrentDoc() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
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.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
 
setGatewayAllocator(Class<? extends GatewayAllocator>) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
setGcDeletesInMillis(long) - Method in class org.elasticsearch.index.engine.EngineConfig
Sets the GC deletes cycle in milliseconds.
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
 
setHeader(BytesReference) - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
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.termvector.TermVectorRequestBuilder
Sets the id of the document.
setId(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Sets the id of the indexed document.
setIdCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
setIdCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setIgnoreConflicts(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
If there is already a mapping definition registered against the type, then it will be merged.
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
setInclude(boolean) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
Whether to include the queried document.
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.analyze.AnalyzeRequestBuilder
Sets the index to use to analyzer the text (for example, if it holds specific analyzers registered).
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.ShardReplicationOperationRequestBuilder
 
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.termvector.TermVectorRequestBuilder
Sets the index where the document is located.
setIndex(String) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
 
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
setIndexService(IndexService) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
setIndexService(IndexService) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
setIndexService(IndexService) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
setIndexService(IndexService) - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
setIndexService(IndexService) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
 
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.get.ShardGetService
 
setIndexShard(IndexShard) - Method in class org.elasticsearch.index.termvectors.ShardTermVectorService
 
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

The list of indices supports multi-index syntax.

setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
Sets the list of indices that should be restored from snapshot

The list of indices supports multi-index syntax.

setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
When ClusterStateRequestBuilder.setMetaData(boolean) is set, which indices to return the IndexMetaData for.
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
Sets the indices to be closed
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
 
setIndices(String[]) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequestBuilder
Sets the indices the delete mapping will execute on
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.status.IndicesStatusRequestBuilder
Deprecated.
 
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
 
setIndices(String...) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequestBuilder
 
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.mapping.delete.DeleteMappingRequestBuilder
Specifies what type of requested indices to ignore and wildcard indices expressions.
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.status.IndicesStatusRequestBuilder
Deprecated.
 
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
 
setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequestBuilder
Specifies what type of requested indices to ignore and how to deal with wildcard indices expressions.
setIndicesTermsFilterCache(IndicesTermsFilterCache) - Method in class org.elasticsearch.index.query.TermsFilterParser
 
setIndicesWarmer(IndicesWarmer) - Method in class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache
 
setInnerHits(Tuple<String, SubSearchContext>) - 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.
setLang(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicBuilder
 
setLastAccessTime() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
sets the lasAccessTime flag to now
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 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
 
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.ActionRequestBuilder
 
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
 
setLockFactory(LockFactory) - Method in class org.elasticsearch.index.store.DistributorDirectory
 
setLowFreqMinimumNumberShouldMatch(String) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
 
setMappingsModified() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
setMappingsModified() - Method in class org.elasticsearch.index.mapper.ParseContext
 
setMappingsModified() - Method in class org.elasticsearch.index.mapper.ParsedDocument
latches the mapping to be marked as modified.
setMappingsModified(Tuple<DocumentMapper, Boolean>) - Method in class org.elasticsearch.index.mapper.ParsedDocument
Uses the value of get document or create to automatically set if mapping is modified or not.
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.mlt.MoreLikeThisRequestBuilder
The maximum frequency in which words may still appear.
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
 
setMaxNumSegments(int) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
Will optimize the index down to <= maxNumSegments.
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
 
setMaxWordLen(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The maximum word length above which words will be ignored.
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.
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.
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.mlt.MoreLikeThisRequestBuilder
The frequency at which words will be ignored which do not occur in at least this many docs.
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.action.mlt.MoreLikeThisRequestBuilder
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
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
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.mlt.MoreLikeThisRequestBuilder
The frequency below which terms will be ignored in the source doc.
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.action.mlt.MoreLikeThisRequestBuilder
The minimum word length below which words will be ignored.
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.
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.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.
setNeedsGlobalOrdinals(boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
setNeedsGlobalOrdinals(boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
 
setNestedFilter(FilterBuilder) - 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(FilterBuilder) - 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(FilterBuilder) - 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.
setNetwork(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
Should the node Network info be returned.
setNetwork(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
Should the node Network stats be returned.
setNext(ShapeBuilder.Edge) - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
 
setNextDoc(int) - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
 
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
 
setNextDocId(int) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setNextDocId(int) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
setNextDocId(int) - Method in interface org.elasticsearch.script.SearchScript
 
setNextDocId(int) - Method in class org.elasticsearch.search.lookup.DocLookup
 
setNextDocId(int) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
setNextDocId(int) - Method in class org.elasticsearch.search.lookup.IndexLookup
 
setNextDocId(int) - Method in class org.elasticsearch.search.lookup.SearchLookup
 
setNextDocId(int) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
setNextDocIdInFields() - Method in class org.elasticsearch.search.lookup.IndexLookup
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.Lucene.EarlyTerminatingCollector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.MultiCollector
 
setNextReader(AtomicReaderContext) - Method in interface org.elasticsearch.common.lucene.ReaderContextAware
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
Deprecated.
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.common.lucene.search.NoopCollector
 
setNextReader(IndexReaderContext) - Method in interface org.elasticsearch.common.lucene.TopReaderContextAware
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.index.search.child.ChildrenQuery.ParentCollector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.AggregationPhase.AggregationsCollector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.children.ParentToChildrenAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.LowCardinality
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.FilteringBucketCollector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.RecordingPerReaderBucketCollector
 
setNextReader(IndexReaderContext) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
 
setNextReader(IndexReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.ParentChild
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
setNextReader(IndexReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
 
setNextReader(IndexReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Collector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.internal.DocIdSetCollector
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.lookup.DocLookup
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.lookup.IndexLookup
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.lookup.SearchLookup
 
setNextReader(AtomicReaderContext) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
setNextSource(Map<String, Object>) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setNextSource(Map<String, Object>) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
setNextSource(Map<String, Object>) - Method in interface org.elasticsearch.script.SearchScript
 
setNextSource(BytesReference) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
setNextSource(Map<String, Object>) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
setNextSourceContentType(XContentType) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
setNextVar(String, Object) - Method in class org.elasticsearch.script.AbstractExecutableScript
 
setNextVar(String, Object) - Method in interface org.elasticsearch.script.ExecutableScript
 
setNextVar(String, Object) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
setNodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Should the cluster state result include the DiscoveryNodes.
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
 
setNodesIds(String...) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequestBuilder
The nodes ids to restart.
setNodesIds(String...) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
 
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.
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.termvector.TermVectorRequestBuilder
 
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.optimize.OptimizeRequestBuilder
Should the optimization only expunge deletes from the index, without full optimization.
setOperationThreaded(boolean) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequestBuilder
Controls if the operation will be executed on a separate thread when executed locally.
setOperationThreaded(boolean) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequestBuilder
Controls if the operation will be executed on a separate thread when executed locally.
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.
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.
setOut(StreamOutput) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
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.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicBuilder
 
setParams(Map<String, Object>) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
Sets parameters for the script.
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.termvector.TermVectorRequestBuilder
Sets the parent id of this document.
setParent(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
 
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.termvector.TermVectorRequestBuilder
 
setPercentTermsToMatch(float) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The percent of the terms to match for each field.
setPercolate(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setPercolateDoc(PercolateSourceBuilder.DocBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
setPercolateFilter(FilterBuilder) - 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.termvector.TermVectorRequestBuilder
 
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.
setPhraseSlop(int) - Method in class org.elasticsearch.index.search.MatchQuery
 
setPingContextProvider(PingContextProvider) - Method in class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
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.
setPositions(boolean) - Method in class org.elasticsearch.action.termvector.TermVectorRequestBuilder
 
setPostFilter(FilterBuilder) - 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 or facets).
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 facets 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 facets 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 facets 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 facets 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 facets 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 facets for example).
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
Sets the preference to execute the search.
setPreference(String) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
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.termvector.TermVectorRequestBuilder
Sets the preference to execute the search.
setPreferLocal(boolean) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequestBuilder
if this operation hits a node with a local relevant shard, should it be preferred to be executed on, or just do plain round robin.
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.
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
The query source to execute.
setQuery(BytesReference) - Method in class org.elasticsearch.action.count.CountRequestBuilder
The query binary to execute
setQuery(XContentBuilder) - Method in class org.elasticsearch.action.count.CountRequestBuilder
Constructs a new builder with a raw search query.
setQuery(QueryBuilder) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query to delete documents for.
setQuery(QueryBuilder) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
The query source to execute.
setQuery(BytesReference) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
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
 
setQueryCache(Boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Sets if this request should use the query cache or not, assuming that it can (for example, if "now" is used, it will never be cached).
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.
setReaderInFields() - Method in class org.elasticsearch.search.lookup.IndexLookup
 
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.termvector.TermVectorRequestBuilder
 
setRecovery(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setRecovery(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
Deprecated.
Should the status include recovery information.
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

See RestoreSnapshotRequestBuilder.setRenamePattern(String) for more information.

setReplicationType(ReplicationType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
Set the replication type for this operation.
setReplicationType(ReplicationType) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
Set the replication type for this operation.
setReplicationType(ReplicationType) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The replication type to use with this operation.
setReplicationType(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The replication type to use with this operation.
setReplicationType(ReplicationType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Set the replication type for this operation.
setReplicationType(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Set the replication type for this operation.
setReplicationType(ReplicationType) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequestBuilder
Sets the replication type.
setReplicationType(String) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequestBuilder
Sets the replication type.
setReplicationType(ReplicationType) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequestBuilder
Sets the replication type.
setReplicationType(String) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequestBuilder
Sets the replication type.
setReplicationType(ReplicationType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Sets the replication type.
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
 
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
Sets the rescore window for all rescorers that don't specify a window when added.
setResolveAddress(boolean) - Static method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
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.
setRewriteMethod(MultiTermQuery, MultiTermQuery.RewriteMethod) - Static method in class org.elasticsearch.index.query.support.QueryParsers
 
setRewriteMethod(MultiTermQuery, String) - Static method in class org.elasticsearch.index.query.support.QueryParsers
 
setRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.elasticsearch.index.search.MatchQuery
 
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
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
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.deletebyquery.DeleteByQueryRequestBuilder
A comma separated list of routing values to control the shards the action will be executed on.
setRouting(String...) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The routing values to control the shards that the action will be executed on.
setRouting(String) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
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
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.mlt.MoreLikeThisRequestBuilder
Sets the routing.
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.termvector.TermVectorRequestBuilder
Sets the routing.
setRouting(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Controls the shard routing of the request.
setRoutingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Should the cluster state result include teh RoutingTable.
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 class org.elasticsearch.common.lucene.MultiCollector
 
setScorer(Scorer) - Method in interface org.elasticsearch.common.lucene.ScorerAware
 
setScorer(Scorer) - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.common.lucene.search.NoopCollector
 
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
 
setScorer(Scorer) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setScorer(Scorer) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
setScorer(Scorer) - Method in class org.elasticsearch.search.aggregations.AggregationPhase.AggregationsCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
 
setScorer(Scorer) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.FacetExecutor.Collector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.nested.NestedFacetExecutor.Collector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.internal.DocIdSetCollector
 
setScript(String, ScriptService.ScriptType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
The script to execute.
setScript(String) - 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
setScriptFile(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicBuilder
 
setScriptId(String) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicBuilder
 
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.
setScriptLang(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
The language of the script to execute.
setScriptParams(Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Sets the script parameters to use with the script.
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
 
setSearchFrom(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
From which search result set to return.
setSearchIndices(String...) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The indices the resulting mlt query will run against.
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.
setSearchScroll(Scroll) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
An optional search scroll request to be able to continue and scroll the search operation.
setSearchSize(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The number of documents to return, defaults to 10.
setSearchSource(SearchSourceBuilder) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
An optional search source request allowing to control the search request for the more like this documents.
setSearchSource(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
An optional search source request allowing to control the search request for the more like this documents.
setSearchSource(Map) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
An optional search source request allowing to control the search request for the more like this documents.
setSearchSource(XContentBuilder) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
An optional search source request allowing to control the search request for the more like this documents.
setSearchSource(byte[]) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
An optional search source request allowing to control the search request for the more like this documents.
setSearchType(SearchType) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The search type of the mlt search query.
setSearchType(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The search type of the mlt search query.
setSearchType(SearchType) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
The search type to execute, defaults to SearchType.DEFAULT.
setSearchType(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
The a string representation search type to execute, defaults to SearchType.DEFAULT.
setSearchTypes(String...) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The types the resulting mlt query will run against.
setSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setSelectedFields(String...) - Method in class org.elasticsearch.action.termvector.TermVectorRequestBuilder
 
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

See repository documentation for more information.

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

See repository documentation for more information.

setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
Sets repository-specific restore settings

See repository documentation for more information.

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, Object>) - 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)
setShard(int) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
 
setShardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
setShardsAllocator(Class<? extends ShardsAllocator>) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
setShardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
 
setShardSize(int) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
 
setShortCircuitCutoff(int) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
Configures at what cut off point only to evaluate parent documents that contain the matching parent id terms instead of evaluating all parent docs.
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
 
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
 
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
setSnapshot(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
Deprecated.
Should the status include recovery information.
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
Similar as PercolateSourceBuilder.setTrackScores(boolean), but whether to sort by the score descending.
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, Object>) - 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(BytesReference, boolean) - 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
The source to execute.
setSource(BytesReference, boolean) - Method in class org.elasticsearch.action.count.CountRequestBuilder
The source to execute.
setSource(byte[]) - Method in class org.elasticsearch.action.count.CountRequestBuilder
The query source to execute.
setSource(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The source to execute.
setSource(Map<String, Object>) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The source to execute in the form of a map.
setSource(XContentBuilder) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The source to execute in the form of a builder.
setSource(byte[]) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The source to execute.
setSource(BytesReference) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The source to execute.
setSource(BytesReference, boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The source to execute.
setSource(byte[], int, int, boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The source to execute.
setSource(BytesReference) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
The source to execute.
setSource(BytesReference, boolean) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
The source to execute.
setSource(byte[]) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
The query source to execute.
setSource(BytesReference, boolean) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
Sets the full source of the explain request (for example, wrapping an actual query).
setSource(BytesReference, boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Sets the source.
setSource(BytesReference) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Sets the source.
setSource(Map<String, Object>) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Index the Map as a JSON.
setSource(Map<String, Object>, 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(byte[], int, int, boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Sets the document to index in bytes form.
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, boolean) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
Sets the source.
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(byte[], int, int, boolean) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequestBuilder
Sets the document to index in bytes form.
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(BytesReference, boolean) - 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(byte[], int, int, boolean) - 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(BytesReference, boolean) - 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
 
setSourceClassName(String) - Method in class org.elasticsearch.common.logging.jdk.ESLogRecord
 
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.
setStopWords(String...) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
Any word in this set is considered "uninteresting" and ignored.
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
 
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.
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.
setTemplateName(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
template stuff
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
 
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.termvector.TermVectorRequestBuilder
 
setTermVectorField(BytesStreamOutput) - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
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
 
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.IndicesReplicationOperationRequestBuilder
A timeout to wait if the index operation can't be performed immediately.
setTimeout(String) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequestBuilder
A timeout to wait if the index operation can't be performed immediately.
setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequestBuilder
A timeout to wait if the index operation can't be performed immediately.
setTimeout(String) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequestBuilder
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.
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.
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_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_CUSTOM_DATA_PATH_ENABLED - Static variable in class org.elasticsearch.env.NodeEnvironment
 
SETTING_DATA_PATH - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
 
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_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_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_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_PRIMARY_BALANCE_FACTOR - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
 
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_REJOIN_ON_MASTER_GONE - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
 
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_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_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
 
SETTING_VERSION_CREATED - 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

See repository documentation for more information.

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

See repository documentation for more information.

settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
Sets repository-specific restore settings

See repository documentation for more information.

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
Returns the Settings to update
settings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
Sets the Settings to update
settings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
Sets the settings to be updated
settings(Settings.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.FilterClient
 
settings() - Method in class org.elasticsearch.client.node.NodeClient
 
settings() - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
settings() - Method in class org.elasticsearch.client.transport.TransportClient
 
settings(Settings.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
settings(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
settings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
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 merges 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 - Interface in org.elasticsearch.common.settings
Immutable settings allowing to control the configuration.
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.internal.InternalNode
 
settings() - Method in interface 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 - Variable in class org.elasticsearch.river.AbstractRiverComponent
 
settings() - Method in class org.elasticsearch.river.RiverSettings
 
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 - Interface in org.elasticsearch.common.settings
A settings builder interface.
settingsBuilder() - Static method in class org.elasticsearch.common.settings.ImmutableSettings
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
 
settingsFilter(SettingsFilter) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
 
settingsFilter(SettingsFilter) - Method in class org.elasticsearch.cluster.ClusterState
 
SettingsFilter - Class in org.elasticsearch.common.settings
 
SettingsFilter(Settings) - Constructor for class org.elasticsearch.common.settings.SettingsFilter
 
SettingsFilter.Filter - Interface in org.elasticsearch.common.settings
 
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
 
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
 
setTTL(long) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
 
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.delete.DeleteMappingRequestBuilder
Sets the type of the mapping to remove
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.termvector.TermVectorRequestBuilder
Sets the type of the document.
setType(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Sets the type of the indexed document.
setType(String) - Method in class org.elasticsearch.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
The types of documents the query will run against.
setTypes(String...) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The types of documents the query will run against.
setTypes(String...) - Method in class org.elasticsearch.action.exists.ExistsRequestBuilder
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.
setup() - Static method in class org.elasticsearch.common.netty.NettyUtils
 
setUpgradeInProgress(boolean) - Method in class org.elasticsearch.index.merge.policy.ElasticsearchMergePolicy
When upgrade is true, running a force merge will upgrade any segments written with older versions.
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
 
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.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.compress.CompressedStreamOutput
 
setVersion(Version) - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
setVersion(Version) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
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.
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.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.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
 
setWithinNewMapper() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
setWithinNewMapper() - Method in class org.elasticsearch.index.mapper.ParseContext
 
setZeroTermsQuery(MatchQuery.ZeroTermsQuery) - Method in class org.elasticsearch.index.search.MatchQuery
 
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, Settings, IndexSettingsService, IndicesLifecycle, Store, MergeSchedulerProvider, Translog, ThreadPool, MapperService, IndexQueryParserService, IndexCache, IndexAliasesService, ShardIndexingService, ShardGetService, ShardSearchService, ShardIndexWarmerService, ShardFilterCache, ShardFieldData, PercolatorQueriesRegistry, ShardPercolateService, CodecService, ShardTermVectorService, IndexFieldDataService, IndexService, ShardSuggestService, ShardQueryCache, ShardFixedBitSetFilterCache, AnalysisService, IndicesWarmer, SnapshotDeletionPolicy, SimilarityService, MergePolicyProvider, EngineFactory, ClusterService) - 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.GeoShapeFilterParser.DEFAULTS
 
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
Enumeration that lists all ShapeBuilder.GeoShapeTypes that can be handled
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() - 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.query.IndicesQueryCache.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_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_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
 
shardAction - Variable in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
shardDataLocations(ShardId, Settings) - Method in class org.elasticsearch.env.NodeEnvironment
Deprecated.
use shardDataPaths instead
shardDataPaths(ShardId, Settings) - Method in class org.elasticsearch.env.NodeEnvironment
Returns all paths where lucene data will be stored, if a index.data_path setting is present, will return the custom data path to be used
ShardDeleteByQueryRequest - Class in org.elasticsearch.action.deletebyquery
Delete by query request to execute on a specific shard.
ShardDeleteByQueryResponse - Class in org.elasticsearch.action.deletebyquery
Delete by query response executed on a specific shard.
ShardDeleteByQueryResponse() - Constructor for class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryResponse
 
ShardDeleteRequest - Class in org.elasticsearch.action.delete
Delete by query request to execute on a specific shard.
ShardDeleteResponse - Class in org.elasticsearch.action.delete
Delete response executed on a specific shard.
ShardDeleteResponse() - Constructor for class org.elasticsearch.action.delete.ShardDeleteResponse
 
ShardDeleteResponse(long, boolean) - Constructor for class org.elasticsearch.action.delete.ShardDeleteResponse
 
shardDirectory() - Method in class org.elasticsearch.index.store.fs.DefaultFsIndexStore
 
shardDirectory() - Method in class org.elasticsearch.index.store.fs.MmapFsIndexStore
 
shardDirectory() - Method in class org.elasticsearch.index.store.fs.NioFsIndexStore
 
shardDirectory() - Method in class org.elasticsearch.index.store.fs.SimpleFsIndexStore
 
shardDirectory() - Method in interface org.elasticsearch.index.store.IndexStore
The shard store class that should be used for each shard.
shardDirectory() - Method in class org.elasticsearch.index.store.ram.RamIndexStore
 
shardFailed(ShardRouting, String, String) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
 
shardFailures() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
 
shardFailures(ImmutableList<SnapshotShardFailure>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets the list of individual shard failures
shardFailures() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns shard failures
shardFailures() - Method in interface 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(ShardId, Settings) - Constructor for class org.elasticsearch.index.fielddata.ShardFieldData
 
ShardFieldDataModule - Class in org.elasticsearch.index.fielddata
 
ShardFieldDataModule() - Constructor for class org.elasticsearch.index.fielddata.ShardFieldDataModule
 
ShardFilterCache - Class in org.elasticsearch.index.cache.filter
 
ShardFilterCache(ShardId, Settings) - Constructor for class org.elasticsearch.index.cache.filter.ShardFilterCache
 
ShardFilterCacheModule - Class in org.elasticsearch.index.cache.filter
 
ShardFilterCacheModule() - Constructor for class org.elasticsearch.index.cache.filter.ShardFilterCacheModule
 
ShardFixedBitSetFilterCache - Class in org.elasticsearch.index.cache.fixedbitset
 
ShardFixedBitSetFilterCache(ShardId, Settings) - Constructor for class org.elasticsearch.index.cache.fixedbitset.ShardFixedBitSetFilterCache
 
shardFixedBitSetFilterCache() - Method in class org.elasticsearch.index.shard.IndexShard
 
ShardFixedBitSetFilterCacheModule - Class in org.elasticsearch.index.cache.fixedbitset
 
ShardFixedBitSetFilterCacheModule() - Constructor for class org.elasticsearch.index.cache.fixedbitset.ShardFixedBitSetFilterCacheModule
 
shardGatewayClass() - Method in interface org.elasticsearch.index.gateway.IndexGateway
 
shardGatewayClass() - Method in class org.elasticsearch.index.gateway.local.LocalIndexGateway
 
shardGatewayClass() - Method in class org.elasticsearch.index.gateway.none.NoneIndexGateway
 
ShardGetModule - Class in org.elasticsearch.index.get
 
ShardGetModule() - Constructor for class org.elasticsearch.index.get.ShardGetModule
 
ShardGetService - Class in org.elasticsearch.index.get
 
ShardGetService(ShardId, Settings, ScriptService, MapperService, IndexFieldDataService) - 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.delete.ShardDeleteRequest
 
shardId() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
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 index the operation failed on.
shardId() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
shardId() - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
 
shardId - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryOperationRequest
 
shardId - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ReplicaOperationRequest
 
shardId() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.ShardSingleOperationRequest
 
shardId - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
shardId() - Method in class org.elasticsearch.action.termvector.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 - Variable in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
shardId() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
shardId() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Returns the shards id
shardId() - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
 
shardId() - Method in interface org.elasticsearch.cluster.routing.ShardIterator
The shard id this group relates to.
shardId() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
The shard id.
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() - Method in exception org.elasticsearch.index.shard.IndexShardException
 
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() - Method in class org.elasticsearch.index.store.Store.StoreDirectory
 
shardId() - Method in class org.elasticsearch.indices.IndicesWarmer.WarmerContext
 
shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
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.SnapshotShardFailure
Returns shard id where failure occurred
shardIdentifierFromRouting(ShardRouting) - Static method in class org.elasticsearch.cluster.InternalClusterInfoService
Method that incorporates the ShardId for the shard into a string that includes a 'p' or 'r' depending on whether the shard is a primary.
shardIds() - Method in class org.elasticsearch.index.IndexService
 
ShardIndexingModule - Class in org.elasticsearch.index.indexing
 
ShardIndexingModule() - Constructor for class org.elasticsearch.index.indexing.ShardIndexingModule
 
ShardIndexingService - Class in org.elasticsearch.index.indexing
 
ShardIndexingService(ShardId, Settings, ShardSlowLogIndexingService) - Constructor for class org.elasticsearch.index.indexing.ShardIndexingService
 
shardIndexLocations(ShardId) - Method in interface org.elasticsearch.index.store.IndexStore
Return an array of all index folder locations for a given shard
shardIndexLocations(ShardId) - Method in class org.elasticsearch.index.store.support.AbstractIndexStore
Return an array of all index folder locations for a given shard.
ShardIndexWarmerService - Class in org.elasticsearch.index.warmer
 
ShardIndexWarmerService(ShardId, Settings) - Constructor for class org.elasticsearch.index.warmer.ShardIndexWarmerService
 
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.
shardLocations(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
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() - Method in class org.elasticsearch.plugins.AbstractPlugin
Defaults to return an empty list.
shardModules(Settings) - Method in class org.elasticsearch.plugins.AbstractPlugin
Defaults to return an empty list.
shardModules() - Method in interface org.elasticsearch.plugins.Plugin
Per index shard module.
shardModules(Settings) - Method in interface org.elasticsearch.plugins.Plugin
Per index shard module.
shardModules() - Method in class org.elasticsearch.plugins.PluginsService
 
shardModules(Settings) - Method in class org.elasticsearch.plugins.PluginsService
 
shardOperation(AnalyzeRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
 
shardOperation(ShardClearIndicesCacheRequest) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
shardOperation(ShardFlushRequest) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
shardOperation(GetFieldMappingsIndexRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
 
shardOperation(ShardOptimizeRequest) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
shardOperation(TransportRecoveryAction.ShardRecoveryRequest) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
shardOperation(ShardRefreshRequest) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
shardOperation(TransportIndicesSegmentsAction.IndexShardSegmentRequest) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
shardOperation(TransportIndicesStatsAction.IndexShardStatsRequest) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
shardOperation(TransportIndicesStatusAction.IndexShardStatusRequest) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
shardOperation(ShardValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
shardOperation(ShardCountRequest) - Method in class org.elasticsearch.action.count.TransportCountAction
 
shardOperation(ShardExistsRequest) - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
shardOperation(ExplainRequest, ShardId) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
shardOperation(GetRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportGetAction
 
shardOperation(MultiGetShardRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
shardOperation(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(ShardRequest) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
shardOperation(Request, ShardId) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
Operation to be executed at the shard level.
shardOperation(TransportInstanceSingleOperationAction<Request, Response>.InternalRequest, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
shardOperation(Request, ShardId) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
shardOperation(MultiTermVectorsShardRequest, ShardId) - Method in class org.elasticsearch.action.termvector.TransportSingleShardMultiTermsVectorAction
 
shardOperation(TermVectorRequest, ShardId) - Method in class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
shardOperation(TransportInstanceSingleOperationAction<UpdateRequest, UpdateResponse>.InternalRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
shardOperation(TransportInstanceSingleOperationAction<UpdateRequest, UpdateResponse>.InternalRequest, 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(ClusterState, TransportShardReplicationOperationAction<BulkShardRequest, BulkShardRequest, BulkShardResponse>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
shardOperationOnPrimary(ClusterState, TransportShardReplicationOperationAction<DeleteRequest, DeleteRequest, DeleteResponse>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
shardOperationOnPrimary(ClusterState, TransportShardReplicationOperationAction<ShardDeleteRequest, ShardDeleteRequest, ShardDeleteResponse>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
shardOperationOnPrimary(ClusterState, TransportShardReplicationOperationAction<ShardDeleteByQueryRequest, ShardDeleteByQueryRequest, ShardDeleteByQueryResponse>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
shardOperationOnPrimary(ClusterState, TransportShardReplicationOperationAction<IndexRequest, IndexRequest, IndexResponse>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
shardOperationOnPrimary(ClusterState, TransportShardReplicationOperationAction<Request, ReplicaRequest, Response>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
shardOperationOnReplica(TransportShardReplicationOperationAction<BulkShardRequest, BulkShardRequest, BulkShardResponse>.ReplicaOperationRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
shardOperationOnReplica(TransportShardReplicationOperationAction<DeleteRequest, DeleteRequest, DeleteResponse>.ReplicaOperationRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
shardOperationOnReplica(TransportShardReplicationOperationAction<ShardDeleteRequest, ShardDeleteRequest, ShardDeleteResponse>.ReplicaOperationRequest) - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
shardOperationOnReplica(TransportShardReplicationOperationAction<ShardDeleteByQueryRequest, ShardDeleteByQueryRequest, ShardDeleteByQueryResponse>.ReplicaOperationRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
shardOperationOnReplica(TransportShardReplicationOperationAction<IndexRequest, IndexRequest, IndexResponse>.ReplicaOperationRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
shardOperationOnReplica(TransportShardReplicationOperationAction<Request, ReplicaRequest, Response>.ReplicaOperationRequest) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
shardPaths(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
Returns all shard paths excluding custom shard path
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, Settings) - Constructor for class org.elasticsearch.index.percolator.stats.ShardPercolateService
 
shardPercolateService() - Method in class org.elasticsearch.index.shard.IndexShard
 
ShardQueryCache - Class in org.elasticsearch.index.cache.query
 
ShardQueryCache(ShardId, Settings) - Constructor for class org.elasticsearch.index.cache.query.ShardQueryCache
 
ShardQueryCacheModule - Class in org.elasticsearch.index.cache.query
 
ShardQueryCacheModule() - Constructor for class org.elasticsearch.index.cache.query.ShardQueryCacheModule
 
ShardRecoveryResponse - Class in org.elasticsearch.action.admin.indices.recovery
Information regarding the recovery state of a shard.
ShardRecoveryResponse() - Constructor for class org.elasticsearch.action.admin.indices.recovery.ShardRecoveryResponse
 
ShardReplicationOperationRequest<T extends ShardReplicationOperationRequest> - Class in org.elasticsearch.action.support.replication
 
ShardReplicationOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
ShardReplicationOperationRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Creates a new request that inherits headers and context from the request provided as argument.
ShardReplicationOperationRequest(T) - Constructor for class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Copy constructor that creates a new request that is a copy of the one provided as an argument.
ShardReplicationOperationRequest(T, ActionRequest) - Constructor for class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Copy constructor that creates a new request that is a copy of the one provided as an argument.
ShardReplicationOperationRequestBuilder<Request extends ShardReplicationOperationRequest<Request>,Response extends ActionResponse,RequestBuilder extends ShardReplicationOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.replication
 
ShardReplicationOperationRequestBuilder(Client, Request) - Constructor for class org.elasticsearch.action.support.replication.ShardReplicationOperationRequestBuilder
 
shardResponses() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
 
ShardRestoreStatus(String) - Constructor for class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
Constructs a new shard restore status in initializing state on the given node
ShardRestoreStatus(String, RestoreMetaData.State) - Constructor for class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
Constructs a new shard restore status in with specified state on the given node
ShardRestoreStatus(String, RestoreMetaData.State, String) - Constructor for class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
Constructs a new shard restore status in with specified state on the given node with specified failure reason
ShardRouting - Interface in org.elasticsearch.cluster.routing
Shard routing represents the state of a shard instance allocated in the cluster.
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
 
ShardRoutingState - Enum in org.elasticsearch.cluster.routing
Represents the current state of a ShardRouting as defined by the cluster.
shards(ClusterState, TransportSingleCustomOperationAction<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, FlushRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
The refresh request works against *all* shards.
shards(ClusterState, TransportSingleCustomOperationAction<GetFieldMappingsIndexRequest, GetFieldMappingsResponse>.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
 
shards(ClusterState, OptimizeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
The refresh request works against *all* shards.
shards(ClusterState, RecoveryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
 
shards(ClusterState, RefreshRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
The refresh request works against *all* shards.
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 - Variable in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
Deprecated.
 
shards(ClusterState, IndicesStatusRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
Status goes across *all* shards.
shards(ClusterState, ValidateQueryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
shards(ClusterState, TransportShardReplicationOperationAction<BulkShardRequest, BulkShardRequest, BulkShardResponse>.InternalRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
shards(ClusterState, CountRequest, String[]) - Method in class org.elasticsearch.action.count.TransportCountAction
 
shards(ClusterState, TransportShardReplicationOperationAction<DeleteRequest, DeleteRequest, DeleteResponse>.InternalRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
shards(IndexDeleteRequest) - Method in class org.elasticsearch.action.delete.TransportIndexDeleteAction
 
shards(ClusterState, TransportShardReplicationOperationAction<ShardDeleteRequest, ShardDeleteRequest, ShardDeleteResponse>.InternalRequest) - Method in class org.elasticsearch.action.delete.TransportShardDeleteAction
 
shards(IndexDeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
shards(ClusterState, TransportShardReplicationOperationAction<ShardDeleteByQueryRequest, ShardDeleteByQueryRequest, ShardDeleteByQueryResponse>.InternalRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
shards(ClusterState, ExistsRequest, String[]) - Method in class org.elasticsearch.action.exists.TransportExistsAction
 
shards(ClusterState, TransportShardSingleOperationAction<ExplainRequest, ExplainResponse>.InternalRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
shards(ClusterState, TransportShardSingleOperationAction<GetRequest, GetResponse>.InternalRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
 
shards(ClusterState, TransportShardSingleOperationAction<MultiGetShardRequest, MultiGetShardResponse>.InternalRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
shards(ClusterState, TransportShardReplicationOperationAction<IndexRequest, IndexRequest, IndexResponse>.InternalRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
shards(ClusterState, PercolateRequest, String[]) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
shards(ClusterState, TransportShardSingleOperationAction<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.TransportBroadcastOperationAction
Determines the shards this operation will be executed on.
shards(Request) - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
shards(ClusterState, TransportShardReplicationOperationAction<Request, ReplicaRequest, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
shards(ClusterState, TransportSingleCustomOperationAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
Can return null to execute on this local node.
shards(ClusterState, TransportInstanceSingleOperationAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
Should return an iterator with a single shard!
shards(ClusterState, TransportShardSingleOperationAction<Request, Response>.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
shards(ClusterState, TransportShardSingleOperationAction<MultiTermVectorsShardRequest, MultiTermVectorsShardResponse>.InternalRequest) - Method in class org.elasticsearch.action.termvector.TransportSingleShardMultiTermsVectorAction
 
shards(ClusterState, TransportShardSingleOperationAction<TermVectorRequest, TermVectorResponse>.InternalRequest) - Method in class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
shards(ClusterState, TransportInstanceSingleOperationAction<UpdateRequest, UpdateResponse>.InternalRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
shards() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Entry
Returns list of shards that being restore and their status
shards() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Entry
 
shards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
shards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Returns a ImmutableList of shards
shards(ClusterState, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
shards(ClusterState, String, int) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
shards(Predicate<MutableShardRouting>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
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.
ShardsAllocatorModule - Class in org.elasticsearch.cluster.routing.allocation.allocator
 
ShardsAllocatorModule(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
ShardsAllocators - Class in org.elasticsearch.cluster.routing.allocation.allocator
The ShardsAllocator class offers methods for allocating shard within a cluster.
ShardsAllocators() - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
 
ShardsAllocators(Settings) - 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
 
ShardSearchModule - Class in org.elasticsearch.index.search.stats
 
ShardSearchModule() - Constructor for class org.elasticsearch.index.search.stats.ShardSearchModule
 
ShardSearchRequest - Interface in org.elasticsearch.search.internal
Shard level request that represents a search.
ShardSearchService - Class in org.elasticsearch.index.search.stats
 
ShardSearchService(ShardId, Settings, ShardSlowLogSearchService) - Constructor for class org.elasticsearch.index.search.stats.ShardSearchService
 
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, boolean, 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.AbstractPlugin
Defaults to return an empty list.
shardServices() - Method in interface 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
 
ShardSingleOperationRequest(Request, ShardId) - Constructor for class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.ShardSingleOperationRequest
 
shardsIt() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
shardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
shardsIt(int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
shardsIt() - Method in interface 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.
shardsIts - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
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.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(int) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
Sets the number of terms that will be returned from each shard.
shardSize(int) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
Sets the number of terms that will be returned from each shard.
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 basis.
ShardsLimitAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
 
ShardSlowLogIndexingService - Class in org.elasticsearch.index.indexing.slowlog
 
ShardSlowLogIndexingService(ShardId, Settings, IndexSettingsService) - Constructor for class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService
 
ShardSlowLogIndexingService.SlowLogParsedDocumentPrinter - Class in org.elasticsearch.index.indexing.slowlog
 
ShardSlowLogSearchService - Class in org.elasticsearch.index.search.slowlog
 
ShardSlowLogSearchService(ShardId, Settings, IndexSettingsService) - Constructor for class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
ShardSlowLogSearchService.SlowLogSearchContextPrinter - Class in org.elasticsearch.index.search.slowlog
 
ShardSnapshotStatus(String) - Constructor for class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
ShardSnapshotStatus(String, SnapshotMetaData.State) - Constructor for class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
ShardSnapshotStatus(String, SnapshotMetaData.State, String) - Constructor for class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
ShardsPluginsModule - Class in org.elasticsearch.plugins
 
ShardsPluginsModule(Settings, PluginsService) - Constructor for class org.elasticsearch.plugins.ShardsPluginsModule
 
shardsRandomIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
shardsStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
 
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.TransportShardReplicationOperationAction
 
ShardStateAction - Class in org.elasticsearch.cluster.action.shard
 
ShardStateAction(Settings, ClusterService, TransportService, AllocationService, RoutingService) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction
 
ShardStateInfo - Class in org.elasticsearch.gateway.local.state.shards
 
ShardStateInfo(long, Boolean) - Constructor for class org.elasticsearch.gateway.local.state.shards.ShardStateInfo
 
ShardStats() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
 
ShardStats - Class in org.elasticsearch.action.admin.indices.stats
 
ShardStats(IndexShard, ShardRouting, CommonStatsFlags) - Constructor for class org.elasticsearch.action.admin.indices.stats.ShardStats
 
ShardStatus - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
shardSuggestService() - Method in class org.elasticsearch.index.shard.IndexShard
 
ShardSuggestService - Class in org.elasticsearch.index.suggest.stats
 
ShardSuggestService(ShardId, Settings) - Constructor for class org.elasticsearch.index.suggest.stats.ShardSuggestService
 
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
 
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
 
ShardTermVectorModule - Class in org.elasticsearch.index.termvectors
 
ShardTermVectorModule() - Constructor for class org.elasticsearch.index.termvectors.ShardTermVectorModule
 
ShardTermVectorService - Class in org.elasticsearch.index.termvectors
 
ShardTermVectorService(ShardId, Settings, MappingUpdatedAction) - Constructor for class org.elasticsearch.index.termvectors.ShardTermVectorService
 
shardTranslogLocations(ShardId) - Method in interface org.elasticsearch.index.store.IndexStore
Return an array of all translog folder locations for a given shard
shardTranslogLocations(ShardId) - Method in class org.elasticsearch.index.store.support.AbstractIndexStore
Return an array of all translog folder locations for a given shard.
ShardUtils - Class in org.elasticsearch.index.shard
 
ShardUtils() - Constructor for class org.elasticsearch.index.shard.ShardUtils
 
share() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
shared() - Method in interface org.elasticsearch.search.facet.terms.strings.HashedAggregator.BytesRefCountIterator
 
SHARED_CHANNEL_NAME - Static variable in class org.elasticsearch.common.network.MulticastChannel
 
SharedFSEngine - Class in org.elasticsearch.index.engine
SharedFSEngine behaves similarly to InternalEngine, however, during recovery, it does not take a snapshot of the translog or index and it performs stage1 (file transfer) under the write lock.
SharedFSEngine(EngineConfig) - Constructor for class org.elasticsearch.index.engine.SharedFSEngine
 
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, ClusterService, IndicesService, MappingUpdatedAction, 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, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
 
ShingleTokenFilterFactory.Factory - Class in org.elasticsearch.index.analysis
 
shortCircuitParentDocSet - Variable in class org.elasticsearch.index.search.child.ChildrenQuery
 
shortField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
ShortFieldMapper - Class in org.elasticsearch.index.mapper.core
 
ShortFieldMapper(FieldMapper.Names, int, float, FieldType, Boolean, Short, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.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.ImmutableShardRouting
 
shortSummary() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
A short description of the shard.
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(FilterBuilder) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds a filter that should appear in the matching documents.
should(FilterBuilder...) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds multiple should filters.
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?
shouldCollect() - Method in class org.elasticsearch.search.aggregations.Aggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.bucket.filters.FiltersAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.bucket.SingleBucketAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.avg.AvgAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.CardinalityAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.max.MaxAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.min.MinAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.scripted.ScriptedMetricAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.tophits.TopHitsAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.ValueCountAggregator
 
shouldCollect() - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
 
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.Aggregator
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.terms.TermsAggregator
 
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?
shouldRetrieveOffsets() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
 
shouldRetrievePayloads() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
 
shouldRetrievePositions() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
 
shouldUseCustomQueryWrappingFilter(Query) - Static method in class org.elasticsearch.index.search.child.CustomQueryWrappingFilter
 
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
 
SHUTDOWN_NODE_ACTION_NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
shutdownNow() - Method in class org.elasticsearch.threadpool.ThreadPool
 
SHUTTING_DOWN_KEY - Static variable in class org.elasticsearch.common.util.concurrent.EsAbortPolicy
 
sigma(double) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.ExtendedStatsBuilder
 
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
Expert: set the SignificanceHeuristic to use.
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>) - 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, Collection<InternalSignificantTerms.Bucket>) - 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, long, TermsAggregator.BucketCountThresholds, AggregationContext, Aggregator, SignificantTermsAggregatorFactory, IncludeExclude.LongFilter) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTermsAggregator
 
significantlySmallerThanSinglePackedOrdinals(int, int, long, float) - Static method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
Return true if this impl is going to be smaller than SinglePackedOrdinals by at least 20%.
SignificantStringTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
 
SignificantStringTerms(long, long, String, int, long, SignificanceHeuristic, Collection<InternalSignificantTerms.Bucket>) - 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, long, TermsAggregator.BucketCountThresholds, IncludeExclude, AggregationContext, Aggregator, SignificantTermsAggregatorFactory) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTermsAggregator
 
significantTerms(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
Create a new SignificantTerms aggregation with the given name.
SignificantTerms - Interface in org.elasticsearch.search.aggregations.bucket.significant
An aggregation that collects significant terms in comparison to a background set.
SignificantTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.significant
 
SignificantTermsAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.significant
 
SignificantTermsAggregatorFactory(String, ValuesSourceConfig, TermsAggregator.BucketCountThresholds, IncludeExclude, String, Filter, 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.
SignificantTermsHeuristicModule - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
SignificantTermsHeuristicModule() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificantTermsHeuristicModule
 
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 - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
similarity(SimilarityProvider) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
similarity - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
similarity() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
similarity() - Method in interface org.elasticsearch.index.mapper.FieldMapper
Similarity used for scoring queries on the field
similarity(String) - Method in class org.elasticsearch.index.similarity.SimilarityLookupService
Returns the SimilarityProvider with the given name
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
Service for looking up configured SimilarityProvider implementations by name.
SimilarityLookupService(Index, Settings) - Constructor for class org.elasticsearch.index.similarity.SimilarityLookupService
 
SimilarityLookupService(Index, Settings, 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 is responsible gathering registered and configured SimilarityProvider implementations and making them available through the SimilarityLookupService and SimilarityService.
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
Factory for creating SimilarityProvider instances
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) - Constructor for class org.elasticsearch.index.similarity.SimilarityService
 
SimilarityService(Index, Settings) - Constructor for class org.elasticsearch.index.similarity.SimilarityService
 
SimilarityService(Index, Settings, 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, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SimpleAnalyzerProvider
 
SimpleDistanceBoundingCheck(GeoPoint, GeoPoint) - Constructor for class org.elasticsearch.common.geo.GeoDistance.SimpleDistanceBoundingCheck
 
SimpleDocSetCache - Class in org.elasticsearch.index.cache.docset.simple
 
SimpleDocSetCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.docset.simple.SimpleDocSetCache
 
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
 
SimpleFsDirectoryService - Class in org.elasticsearch.index.store.fs
 
SimpleFsDirectoryService(ShardId, Settings, IndexStore) - Constructor for class org.elasticsearch.index.store.fs.SimpleFsDirectoryService
 
SimpleFsIndexStore - Class in org.elasticsearch.index.store.fs
 
SimpleFsIndexStore(Index, Settings, IndexService, IndicesStore, NodeEnvironment) - Constructor for class org.elasticsearch.index.store.fs.SimpleFsIndexStore
 
SimpleFsIndexStoreModule - Class in org.elasticsearch.index.store.fs
 
SimpleFsIndexStoreModule() - Constructor for class org.elasticsearch.index.store.fs.SimpleFsIndexStoreModule
 
SimpleFsTranslogFile - Class in org.elasticsearch.index.translog.fs
 
SimpleFsTranslogFile(ShardId, long, RafReference) - Constructor for class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
SimpleHashFunction - Class in org.elasticsearch.cluster.routing.operation.hash.simple
This class implements a simple hash function based on Java Build-In Object.hashCode()
SimpleHashFunction() - Constructor for class org.elasticsearch.cluster.routing.operation.hash.simple.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
 
simpleMatchToFullName(String) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
Returns a list of the full names of a simple match regex like pattern against full name, name and index name.
simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
Returns a list of the index names of a simple match regex like pattern against full name, name and index name.
simpleMatchToIndexNames(String, String[]) - Method in class org.elasticsearch.index.mapper.MapperService
Returns all the fields that match the given pattern, with an optional narrowing based on a list of types.
simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns all the fields that match the given pattern.
simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.query.QueryParseContext
 
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
simpleQueryString(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
by simpleQueryStringQuery(String)
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(Settings) - 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.
simulate() - Method in class org.elasticsearch.index.mapper.DocumentMapper.MergeFlags
A simulation run, don't perform actual modifications to the mapping.
simulate(boolean) - Method in class org.elasticsearch.index.mapper.DocumentMapper.MergeFlags
 
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
Creates a new Decision.Single decision of a given type
Single(Decision.Type, String, String, Object...) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
Creates a new Decision.Single decision of a given type
single() - Method in class org.elasticsearch.common.cli.CliToolConfig
 
Single(GeoPointFieldMapper.Encoding, PagedMutable, PagedMutable, FixedBitSet) - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointCompressedAtomicFieldData.Single
 
Single(DoubleArray, DoubleArray, FixedBitSet) - Constructor for class org.elasticsearch.index.fielddata.plain.GeoPointDoubleArrayAtomicFieldData.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) - Constructor for class org.elasticsearch.search.aggregations.bucket.SingleBucketAggregator
 
SingleCustomOperationRequest<T extends SingleCustomOperationRequest> - Class in org.elasticsearch.action.support.single.custom
 
SingleCustomOperationRequest() - Constructor for class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
SingleCustomOperationRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
SingleCustomOperationRequestBuilder<Request extends SingleCustomOperationRequest<Request>,Response extends ActionResponse,RequestBuilder extends SingleCustomOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.single.custom
 
SingleCustomOperationRequestBuilder(IndicesAdminClient, Request) - Constructor for class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequestBuilder
 
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
 
SingleShardOperationRequest<T extends SingleShardOperationRequest> - Class in org.elasticsearch.action.support.single.shard
 
SingleShardOperationRequest() - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
SingleShardOperationRequest(String) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
SingleShardOperationRequest(ActionRequest) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
SingleShardOperationRequest(ActionRequest, String) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
SingleShardOperationRequestBuilder<Request extends SingleShardOperationRequest<Request>,Response extends ActionResponse,RequestBuilder extends SingleShardOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.single.shard
 
SingleShardOperationRequestBuilder(Client, Request) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardOperationRequestBuilder
 
SINGLETON - Static variable in class org.elasticsearch.common.inject.Scopes
One instance per Injector.
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
Returns a multi-valued view over the provided NumericDoubleValues.
singleton(GeoPointValues, Bits) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns a multi-valued view over the provided GeoPointValues.
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
 
SingleValue() - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
 
SingleValue(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
 
SingleValue(String, long, AggregationContext, Aggregator) - 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.termvector.TermVectorFields
 
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
 
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.IdentityHashSet
Returns the number of elements in this set (its cardinality).
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.ImmutableOpenLongMap.Builder
 
size() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
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 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() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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(int) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
The number of terms (and frequencies) to return.
size(int) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
Sets the size of the result.
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.DocLookup
 
size() - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
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.
SIZE_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Defaults
 
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
 
sizeFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
SizeFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
SizeFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
SizeFieldMapper(Settings) - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
SizeFieldMapper(EnabledAttributeMapper, FieldType, PostingsFormatProvider, DocValuesFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
SizeFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
SizeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
SizeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
SizeHeaderFrameDecoder - Class in org.elasticsearch.transport.netty
 
SizeHeaderFrameDecoder() - Constructor for class org.elasticsearch.transport.netty.SizeHeaderFrameDecoder
 
sizeInBytes(DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocIdSets
Return the size of the doc id set, plus a reference to it.
sizeInBytes - Variable in class org.elasticsearch.index.cache.filter.FilterCache.EntriesStats
 
sizeInBytes - Variable in class org.elasticsearch.index.engine.Segment
 
sizeInBytes() - Method in class org.elasticsearch.index.store.StoreStats
 
sizeOfRelocatingShards(RoutingNode, Map<String, Long>, boolean) - 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.AdapterStreamInput
 
skip(long) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
 
skip(long) - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
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.transport.netty.ChannelBufferStreamInput
 
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
 
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.HashedBytesArray
 
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.
 
SlicedInputStream - Class in org.elasticsearch.index.snapshots.blobstore
A SlicedInputStream is a logical concatenation one or more input streams.
SlicedInputStream(long) - Constructor for class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
Creates a new SlicedInputStream
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
 
SlowLogParsedDocumentPrinter(ParsedDocument, long, boolean) - Constructor for class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService.SlowLogParsedDocumentPrinter
 
SlowLogSearchContextPrinter(SearchContext, long, boolean) - Constructor for class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService.SlowLogSearchContextPrinter
 
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
smartFieldMappers(String) - Method in class org.elasticsearch.index.query.QueryParseContext
 
smartFieldMappers(String) - Method in class org.elasticsearch.percolator.PercolateContext
 
smartFieldMappers(String) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
smartFieldMappers(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
smartFieldMappers(String) - Method in class org.elasticsearch.search.internal.SearchContext
 
smartName(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
smartName(String) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
smartName(String, String[]) - Method in class org.elasticsearch.index.mapper.MapperService
 
smartName(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns smart field mappers based on a smart name.
smartNameFieldMapper(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
smartNameFieldMapper(String) - Method in class org.elasticsearch.index.mapper.FieldMappersLookup
Tries to find first based on FieldMappersLookup.fullName(String), then by FieldMappersLookup.indexName(String), and last by FieldMappersLookup.name(String) and return the first mapper for it (see FieldMappers.mapper()).
smartNameFieldMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
Same as MapperService.smartNameFieldMappers(String) but returns the first field mapper for it.
smartNameFieldMapper(String, String[]) - Method in class org.elasticsearch.index.mapper.MapperService
 
smartNameFieldMapper(String) - Method in class org.elasticsearch.percolator.PercolateContext
 
smartNameFieldMapper(String) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
smartNameFieldMapper(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
smartNameFieldMapper(String) - Method in class org.elasticsearch.search.internal.SearchContext
 
smartNameFieldMapperFromAnyType(String) - Method in class org.elasticsearch.percolator.PercolateContext
 
smartNameFieldMapperFromAnyType(String) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
smartNameFieldMapperFromAnyType(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
smartNameFieldMapperFromAnyType(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.
smartNameFieldMappers(String, String[]) - Method in class org.elasticsearch.index.mapper.MapperService
 
smartNameFieldMappers(String) - Method in class org.elasticsearch.index.mapper.MapperService
Same as MapperService.smartName(String), except it returns just the field mappers.
SmartNameFieldMappers(MapperService, FieldMappers, DocumentMapper, boolean) - Constructor for class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
 
smartNameFieldMappers(String) - Method in class org.elasticsearch.percolator.PercolateContext
 
smartNameFieldMappers(String) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
smartNameFieldMappers(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
smartNameFieldMappers(String) - Method in class org.elasticsearch.search.internal.SearchContext
 
smartNameObjectMapper(String, String[]) - Method in class org.elasticsearch.index.mapper.MapperService
 
smartNameObjectMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
SmartNameObjectMapper(ObjectMapper, DocumentMapper) - Constructor for class org.elasticsearch.index.mapper.MapperService.SmartNameObjectMapper
 
smartNameObjectMapper(String) - Method in class org.elasticsearch.percolator.PercolateContext
 
smartNameObjectMapper(String) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
smartNameObjectMapper(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
smartNameObjectMapper(String) - Method in class org.elasticsearch.search.internal.SearchContext
 
smartObjectMapper(String) - Method in class org.elasticsearch.index.query.QueryParseContext
 
smileBuilder() - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Returns a content builder using SMILE format (XContentType.SMILE.
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) - 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(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Deprecated.
Should the status include recovery information.
snapshot() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Deprecated.
 
snapshot(SnapshotId) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData
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.metadata.SnapshotMetaData
 
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(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(SnapshotId, IndexShardSnapshotStatus) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotAndRestoreService
Creates shard snapshot
snapshot() - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
snapshot() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
snapshot(Translog.Snapshot) - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
snapshot() - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
snapshot() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
Returns a snapshot on this file, null if it failed to snapshot.
snapshot() - Method in interface org.elasticsearch.index.translog.Translog
Snapshots the current transaction log allowing to safely iterate over the snapshot.
snapshot(Translog.Snapshot) - Method in interface org.elasticsearch.index.translog.Translog
Snapshots the delta between the current state of the translog, and the state defined by the provided snapshot.
snapshot(BlobStoreSnapshot) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Copies data from another snapshot into the builder
Snapshot - Interface in org.elasticsearch.snapshots
Represent information about 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
 
SnapshotCreationException - Exception in org.elasticsearch.snapshots
Thrown when snapshot creation fails completely
SnapshotCreationException(SnapshotId, String) - 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
 
SnapshotFailedEngineException - Exception in org.elasticsearch.index.engine
 
SnapshotFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.SnapshotFailedEngineException
 
snapshotId() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Entry
Returns snapshot id
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.metadata.SnapshotMetaData.Entry
 
snapshotId() - Method in class org.elasticsearch.cluster.routing.RestoreSource
 
snapshotIndex() - Method in class org.elasticsearch.index.engine.Engine
Snapshots the index and returns a handle to it.
snapshotIndex() - Method in class org.elasticsearch.index.engine.InternalEngine
 
snapshotIndex() - Method in class org.elasticsearch.index.engine.ShadowEngine
 
snapshotIndex() - 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
Creates a new SnapshotInProgressAllocationDecider instance from given settings
SnapshotInProgressAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
 
SnapshotMetaData - Class in org.elasticsearch.cluster.metadata
Meta data about snapshots that are currently executing
SnapshotMetaData(ImmutableList<SnapshotMetaData.Entry>) - Constructor for class org.elasticsearch.cluster.metadata.SnapshotMetaData
 
SnapshotMetaData(SnapshotMetaData.Entry...) - Constructor for class org.elasticsearch.cluster.metadata.SnapshotMetaData
 
SnapshotMetaData.Entry - Class in org.elasticsearch.cluster.metadata
 
SnapshotMetaData.Factory - Class in org.elasticsearch.cluster.metadata
 
SnapshotMetaData.ShardSnapshotStatus - Class in org.elasticsearch.cluster.metadata
 
SnapshotMetaData.State - Enum in org.elasticsearch.cluster.metadata
 
SnapshotMissingException - Exception in org.elasticsearch.snapshots
Thrown if requested snapshot doesn't exist
SnapshotMissingException(SnapshotId) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
 
SnapshotMissingException(SnapshotId, Throwable) - 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
 
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) - 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
SnapshotShardsStats - Class in org.elasticsearch.action.admin.cluster.snapshots.status
Status of a snapshot shards
SnapshotsService - Class in org.elasticsearch.snapshots
Service responsible for creating snapshots

A typical snapshot creating process looks like this: On the master node the SnapshotsService.createSnapshot(SnapshotRequest, CreateSnapshotListener) is called and makes sure that no snapshots is currently running and registers the new snapshot in cluster state When cluster state is updated the SnapshotsService.beginSnapshot(ClusterState, SnapshotMetaData.Entry, boolean, CreateSnapshotListener) method kicks in and initializes the snapshot in the repository and then populates list of shards that needs to be snapshotted in cluster state Each data node is watching for these shards and when new shards scheduled for snapshotting appear in the cluster state, data nodes start processing them through SnapshotsService.processIndexShardSnapshots(SnapshotMetaData) method Once shard snapshot is created data node updates state of the shard in the cluster state using the SnapshotsService.updateIndexShardSnapshotStatus(UpdateIndexShardSnapshotStatusRequest) method When last shard is completed master node in SnapshotsService.innerUpdateSnapshotState(org.elasticsearch.snapshots.SnapshotsService.UpdateIndexShardSnapshotStatusRequest) method marks the snapshot as completed After cluster state is updated, the SnapshotsService.endSnapshot(SnapshotMetaData.Entry) finalizes snapshot in the repository, notifies all SnapshotsService.snapshotCompletionListeners that snapshot is completed, and finally calls SnapshotsService.removeSnapshotFromClusterState(SnapshotId, SnapshotInfo, Throwable) to remove snapshot from cluster state

SnapshotsService(Settings, ClusterService, RepositoriesService, ThreadPool, IndicesService, TransportService) - 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.
snapshotsStatus(SnapshotsStatusRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
snapshotsStatus(SnapshotsStatusRequest, ActionListener<SnapshotsStatusResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
Constructs the new snapshotstatus request
SnapshotsStatusRequestBuilder(ClusterAdminClient, 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.gateway
 
SnapshotStatus() - Constructor for class org.elasticsearch.index.gateway.SnapshotStatus
 
snapshotStatus(SnapshotId, ShardId) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
Retrieve shard snapshot status for the stored snapshot
snapshotStatus(SnapshotId, ShardId) - Method in interface org.elasticsearch.index.snapshots.IndexShardRepository
Retrieve shard snapshot status for the stored snapshot
SnapshotStatus.Index - Class in org.elasticsearch.index.gateway
 
SnapshotStatus.Stage - Enum in org.elasticsearch.index.gateway
 
SnapshotStatus.Translog - Class in org.elasticsearch.index.gateway
 
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
 
SnowballAnalyzerProvider - Class in org.elasticsearch.index.analysis
Creates a SnowballAnalyzer initialized with stopwords and Snowball filter.
SnowballAnalyzerProvider(Index, Settings, 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, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SnowballTokenFilterFactory
 
soft(Recycler.Factory<T>) - Static method in enum org.elasticsearch.common.recycler.Recyclers
Create a recycler that is wrapped inside a soft reference, so that it cannot cause OutOfMemoryErrors.
Soft(ESLogger, IndexService, FieldMapper.Names, FieldDataType, IndicesFieldDataCacheListener) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataCache.Soft
 
softFactory(Recycler.Factory<T>) - Static method in enum org.elasticsearch.common.recycler.Recyclers
Create a recycler that wraps data in a SoftReference.
SOLARIS - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on SunOS.
SoraniAnalyzerProvider - Class in org.elasticsearch.index.analysis
Provider for SoraniAnalyzer
SoraniAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SoraniAnalyzerProvider
 
SoraniNormalizationFilterFactory - Class in org.elasticsearch.index.analysis
Factory for SoraniNormalizationFilter
SoraniNormalizationFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SoraniNormalizationFilterFactory
 
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 values that are stored between offsets 0 and SortingBinaryDocValues.count of SortingBinaryDocValues.values.
sort() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
Sort values that are stored between offsets 0 and SortingNumericDocValues.count of SortingNumericDocValues.values.
sort() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
Sort values that are stored between offsets 0 and SortingNumericDoubleValues.count of SortingNumericDoubleValues.values.
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).
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
A set of static factory methods for SortBuilders.
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 AtomicReader.getSortedNumericDocValues(String)
SortedNumericDVIndexFieldData(Index, FieldMapper.Names, IndexNumericFieldData.NumericType, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedNumericDVIndexFieldData
 
SortedSetDVBytesAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
An AtomicFieldData implementation that uses Lucene SortedSetDocValues.
SortedSetDVOrdinalsIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
 
SortedSetDVOrdinalsIndexFieldData(Index, IndexFieldDataCache, Settings, FieldMapper.Names, CircuitBreakerService, FieldDataType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetDVOrdinalsIndexFieldData
 
sortedShardList - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
sortFieldType() - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
 
SortingBinaryDocValues - Class in org.elasticsearch.index.fielddata
Base class for building SortedBinaryDocValues instances based on unsorted content.
SortingBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortingBinaryDocValues
 
SortingNumericDocValues - Class in org.elasticsearch.index.fielddata
Base class for building SortedNumericDocValues instances based on unsorted content.
SortingNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortingNumericDocValues
 
SortingNumericDoubleValues - Class in org.elasticsearch.index.fielddata
Base class for building SortedNumericDoubleValues instances based on unsorted content.
SortingNumericDoubleValues() - Constructor for class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
 
sortMissingFirst(Object) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
Whether missing values should be sorted first.
sortMissingLast(Object) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
Whether missing values should be sorted last, this is the default.
sortMode(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

JSON, YAML and properties formats are supported

source(byte[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
Parses restore definition

JSON, YAML and properties formats are supported

source(byte[], int, int) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
Parses restore definition

JSON, YAML and properties formats are supported

source(BytesReference) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
Parses restore definition

JSON, YAML and properties formats are supported

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, Object>) - 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.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, boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The source to validate.
source(BytesReference, boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The source to validate.
source() - Method in class org.elasticsearch.action.count.CountRequest
The source to execute.
source(QuerySourceBuilder) - Method in class org.elasticsearch.action.count.CountRequest
The source to execute.
source(Map) - Method in class org.elasticsearch.action.count.CountRequest
The source to execute in the form of a map.
source(XContentBuilder) - Method in class org.elasticsearch.action.count.CountRequest
 
source(String) - Method in class org.elasticsearch.action.count.CountRequest
The source to execute.
source(byte[]) - Method in class org.elasticsearch.action.count.CountRequest
The source to execute.
source(byte[], int, int, boolean) - Method in class org.elasticsearch.action.count.CountRequest
The source to execute.
source(BytesReference, boolean) - Method in class org.elasticsearch.action.count.CountRequest
 
source() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The source to execute.
source(QuerySourceBuilder) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The source to execute.
source(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The source to execute.
source(Map) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The source to execute in the form of a map.
source(XContentBuilder) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
source(byte[]) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The source to execute.
source(byte[], int, int, boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The source to execute.
source(BytesReference, boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
source() - Method in class org.elasticsearch.action.exists.ExistsRequest
The source to execute.
source(QuerySourceBuilder) - Method in class org.elasticsearch.action.exists.ExistsRequest
The source to execute.
source(Map) - Method in class org.elasticsearch.action.exists.ExistsRequest
The source to execute in the form of a map.
source(XContentBuilder) - Method in class org.elasticsearch.action.exists.ExistsRequest
 
source(String) - Method in class org.elasticsearch.action.exists.ExistsRequest
The source to execute.
source(byte[]) - Method in class org.elasticsearch.action.exists.ExistsRequest
The source to execute.
source(byte[], int, int, boolean) - Method in class org.elasticsearch.action.exists.ExistsRequest
The source to execute.
source(BytesReference, boolean) - Method in class org.elasticsearch.action.exists.ExistsRequest
 
source() - Method in class org.elasticsearch.action.explain.ExplainRequest
 
source(QuerySourceBuilder) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
source(BytesReference, boolean) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
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
Index the Map as a Requests.INDEX_CONTENT_TYPE.
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, boolean) - 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(byte[], int, int, boolean) - Method in class org.elasticsearch.action.index.IndexRequest
Sets the document to index in bytes form.
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
Index the Map as a Requests.INDEX_CONTENT_TYPE.
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, boolean) - 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(byte[], int, int, boolean) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
Sets the document to index in bytes form.
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(byte[], int, int, boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequest
source(BytesReference, boolean) - 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(byte[], int, int, boolean) - Method in class org.elasticsearch.action.search.SearchRequest
The search source to execute.
source(BytesReference, boolean) - 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() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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
 
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.river.cluster.RiverClusterChangedEvent
The source that caused this cluster event to be raised.
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.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(byte[], int, int) - 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
 
sourceAsMapAndType(byte[], int, int) - 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(Settings) - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
SourceFieldMapper(String, boolean, String, Boolean, long, String[], String[], Settings) - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
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
 
sourceNode() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
sourceNode() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
 
sourcePath(String) - Method in class org.elasticsearch.index.mapper.ContentPath
 
sourcePath() - Method in class org.elasticsearch.index.mapper.ContentPath
 
sourcePath() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The dot path notation to extract the value from source.
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(SourceToParse.Origin, XContentParser) - Constructor for class org.elasticsearch.index.mapper.SourceToParse
 
SourceToParse(SourceToParse.Origin, BytesReference) - Constructor for class org.elasticsearch.index.mapper.SourceToParse
 
SourceToParse.Origin - Enum in org.elasticsearch.index.mapper
 
sourceUnsafe() - Method in class org.elasticsearch.action.explain.ExplainRequest
 
SPACE - Static variable in class org.elasticsearch.common.logging.Loggers
 
spaceify(int, String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
 
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, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SpanishAnalyzerProvider
 
spanMultiTermQueryBuilder(MultiTermQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
Creates a SpanQueryBuilder which allows having a sub query which implements MultiTermQueryBuilder.
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 - Interface in org.elasticsearch.index.query
 
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
 
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
 
spawnModules() - Method in class org.elasticsearch.cache.recycler.PageCacheRecyclerModule
 
spawnModules() - Method in class org.elasticsearch.cluster.ClusterModule
 
spawnModules() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationModule
 
spawnModules() - Method in class org.elasticsearch.cluster.routing.operation.OperationRoutingModule
 
SpawnModules - Interface in org.elasticsearch.common.inject
 
spawnModules() - Method in interface org.elasticsearch.common.inject.SpawnModules
 
spawnModules() - Method in class org.elasticsearch.common.util.BigArraysModule
 
spawnModules() - Method in class org.elasticsearch.discovery.DiscoveryModule
 
spawnModules() - Method in class org.elasticsearch.gateway.GatewayModule
 
spawnModules() - Method in class org.elasticsearch.index.engine.IndexEngineModule
 
spawnModules() - Method in class org.elasticsearch.index.gateway.IndexGatewayModule
 
spawnModules() - Method in class org.elasticsearch.index.store.IndexStoreModule
 
spawnModules() - Method in class org.elasticsearch.indices.IndicesModule
 
spawnModules() - Method in class org.elasticsearch.plugins.IndexPluginsModule
 
spawnModules() - Method in class org.elasticsearch.plugins.PluginsModule
 
spawnModules() - Method in class org.elasticsearch.plugins.ShardsPluginsModule
 
spawnModules() - Method in class org.elasticsearch.repositories.RepositoryModule
Returns repository module.
spawnModules() - Method in class org.elasticsearch.river.RiverModule
 
spawnModules() - Method in class org.elasticsearch.search.aggregations.AggregationModule
 
spawnModules() - Method in class org.elasticsearch.search.aggregations.TransportAggregationModule
 
spawnModules() - Method in class org.elasticsearch.search.SearchModule
 
spawnModules() - Method in class org.elasticsearch.search.TransportSearchModule
 
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.gateway.SnapshotStatus
 
stage() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
Returns current snapshot stage
stage() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
STANDARD_ANALYZER - Static variable in class org.elasticsearch.common.lucene.Lucene
 
StandardAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
StandardAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardAnalyzerProvider
 
StandardHtmlStripAnalyzer - Class in org.elasticsearch.index.analysis
 
StandardHtmlStripAnalyzer(Version) - Constructor for class org.elasticsearch.index.analysis.StandardHtmlStripAnalyzer
StandardHtmlStripAnalyzer(Version, CharArraySet) - Constructor for class org.elasticsearch.index.analysis.StandardHtmlStripAnalyzer
 
StandardHtmlStripAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
StandardHtmlStripAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardHtmlStripAnalyzerProvider
 
StandardTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
StandardTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardTokenFilterFactory
 
StandardTokenizerFactory - Class in org.elasticsearch.index.analysis
 
StandardTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardTokenizerFactory
 
start() - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
start() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction.AsyncBroadcastAction
 
start() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.AsyncShardOperationAction
 
start() - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
start() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
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() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Start
 
start() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
 
start() - Method in class org.elasticsearch.node.internal.InternalNode
 
start() - Method in interface org.elasticsearch.node.Node
Start the node.
start() - Method in class org.elasticsearch.river.dummy.DummyRiver
 
start() - Method in interface org.elasticsearch.river.River
Called whenever the river is registered on a node, which can happen when: 1) the river _meta document gets indexed 2) an already registered river gets started on a node
START_RECOVERY - Static variable in class org.elasticsearch.indices.recovery.RecoverySource.Actions
 
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
 
startDouble() - Method in enum org.elasticsearch.search.MultiValueMode
Returns an initial value for the sort mode that is guaranteed to have no impact if passed to MultiValueMode.apply(double, double).
started() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
started(MutableShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
Mark a shard as started and adjusts internal statistics.
started() - Method in interface 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
This RoutingAllocation holds a list of started shards within a cluster
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
 
startLong() - Method in enum org.elasticsearch.search.MultiValueMode
Returns an initial value for the sort mode that is guaranteed to have no impact if passed to MultiValueMode.apply(long, long).
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(ShardId, DiscoveryNode, DiscoveryNode, boolean, Map<String, StoreFileMetaData>, RecoveryState.Type, long) - Constructor for class org.elasticsearch.indices.recovery.StartRecoveryRequest
Start recovery 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.search.type.AbstractAsyncAction
Return the time when the action started.
startTime() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
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 class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
startTime(long) - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
startTime() - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
startTime(long) - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
startTime() - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Translog
 
startTime(long) - Method in class org.elasticsearch.index.gateway.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
 
startTime() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
startTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
startTime(long) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets snapshot start time
startTime() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns time when snapshot started
startTime() - Method in interface 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.
startVerification() - Method in class org.elasticsearch.repositories.uri.URLRepository
 
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(ClusterStateRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
state(ClusterStateRequest, ActionListener<ClusterStateResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
state() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
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.metadata.IndexMetaData
 
state() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Entry
Returns current restore state
state() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
Returns current state
state() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Entry
 
state() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
state - Variable in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
state() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
state() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
The shard state.
state() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
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(SnapshotState) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets snapshot state
state() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns current snapshot state
state() - Method in class org.elasticsearch.river.cluster.RiverClusterChangedEvent
 
state() - Method in class org.elasticsearch.river.cluster.RiverClusterService
The current state.
state(RiverClusterState) - Method in class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
state() - Method in interface 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.local.state.meta.MetaDataStateFormat
 
STATE_FILE_EXTENSION - Static variable in class org.elasticsearch.gateway.local.state.meta.MetaDataStateFormat
 
STATE_NOT_RECOVERED_BLOCK - Static variable in class org.elasticsearch.gateway.GatewayService
 
states - Variable in class org.elasticsearch.search.aggregations.metrics.percentiles.AbstractPercentilesAggregator
 
StaticAggregatorValueProc(DoubleIntOpenHashMap) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetExecutor.StaticAggregatorValueProc
 
StaticAggregatorValueProc(LongIntOpenHashMap) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongFacetExecutor.StaticAggregatorValueProc
 
StaticInjectionRequest - Class in org.elasticsearch.common.inject.spi
A request to inject the static fields and methods of a type.
statisticalFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
StatisticalFacet - Interface in org.elasticsearch.search.facet.statistical
Numeric statistical information.
StatisticalFacetBuilder - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFacetBuilder
 
StatisticalFacetExecutor - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFacetExecutor(IndexNumericFieldData, SearchContext) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor
 
StatisticalFacetExecutor.StatsProc - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFacetParser - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFacetParser
 
StatisticalFieldsFacetExecutor - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFieldsFacetExecutor(IndexNumericFieldData[], SearchContext) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetExecutor
 
StatisticalFieldsFacetExecutor.StatsProc - Class in org.elasticsearch.search.facet.statistical
 
statisticalScriptFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
StatisticalScriptFacetBuilder - Class in org.elasticsearch.search.facet.statistical
 
StatisticalScriptFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
 
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(IndicesStatsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
stats(IndicesStatsRequest, ActionListener<IndicesStatsResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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.filter.ShardFilterCache
 
stats() - Method in class org.elasticsearch.index.cache.query.ShardQueryCache
 
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, 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() - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
stats() - Method in class org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
stats() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
Deprecated.
 
stats() - Method in class org.elasticsearch.index.percolator.stats.ShardPercolateService
 
Stats(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.ShardSearchService
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.ShardSuggestService
 
stats() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
stats() - Method in interface 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(CircuitBreaker.Name) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
 
stats() - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
stats(CircuitBreaker.Name) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
 
stats() - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
 
stats(CircuitBreaker.Name) - 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 interface org.elasticsearch.monitor.fs.FsProbe
 
stats() - Method in class org.elasticsearch.monitor.fs.FsService
 
stats() - Method in class org.elasticsearch.monitor.fs.JmxFsProbe
 
stats() - Method in class org.elasticsearch.monitor.jvm.JvmService
 
stats() - Method in class org.elasticsearch.monitor.network.NetworkService
 
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(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
 
StatsAggegator - Class in org.elasticsearch.search.aggregations.metrics.stats
 
StatsAggegator(String, long, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.stats.StatsAggegator
 
StatsAggegator.Factory - Class in org.elasticsearch.search.aggregations.metrics.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
 
StatsProc() - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor.StatsProc
 
StatsProc() - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetExecutor.StatsProc
 
status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
Returns HTTP status

RestStatus.ACCEPTED if snapshot is still in progress RestStatus.OK if snapshot was successful or partially successful RestStatus.INTERNAL_SERVER_ERROR if snapshot failed completely

status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
 
status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
 
status() - Method in class org.elasticsearch.action.count.CountResponse
 
status() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryResponse
 
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() - Method in exception org.elasticsearch.action.UnavailableShardsException
 
status(IndicesStatusRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deprecated.
status(IndicesStatusRequest, ActionListener<IndicesStatusResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Deprecated.
status(IndicesStatusRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
status(IndicesStatusRequest, ActionListener<IndicesStatusResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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.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.ElasticsearchIllegalArgumentException
 
status() - Method in exception org.elasticsearch.ElasticsearchParseException
 
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.IndexShardMissingException
 
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.IndexMissingException
 
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.rest.action.admin.indices.alias.delete.AliasesMissingException
 
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
 
status() - Method in exception org.elasticsearch.script.groovy.GroovyScriptExecutionException
 
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.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
StatusRef(RecoveryStatus) - Constructor for class org.elasticsearch.indices.recovery.RecoveriesCollection.StatusRef
Important: AbstractRefCounted.tryIncRef() should be *successfully* called on status before
StatusToXContent - Interface in org.elasticsearch.common.xcontent
 
StemmerOverrideTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
StemmerOverrideTokenFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StemmerOverrideTokenFilterFactory
 
StemmerTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
StemmerTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StemmerTokenFilterFactory
 
stolen() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
stop() - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
stop() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
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.node.internal.InternalNode
 
stop() - Method in interface org.elasticsearch.node.Node
Stops the node.
stop() - Method in class org.elasticsearch.watcher.WatcherHandle
 
STOP_WORDS - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryParser.Fields
 
StopAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
StopAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StopAnalyzerProvider
 
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
 
StopTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
StopTokenFilterFactory(Index, Settings, 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(String...) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Any word in this set is considered "uninteresting" and ignored.
stopWords() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Any word in this set is considered "uninteresting" and ignored.
stopWords() - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
 
stopWords(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Deprecated.
Set the set of stopwords.
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() - Method in class org.elasticsearch.index.IndexService
 
store(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
STORE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
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, Distributor, ShardLock) - Constructor for class org.elasticsearch.index.store.Store
 
Store(ShardId, Settings, DirectoryService, Distributor, 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.StoreDirectory - Class in org.elasticsearch.index.store
This exists so BloomFilterPostingsFormat can load its boolean setting; can we find a more straightforward way?
StoreException - Exception in org.elasticsearch.index.store
 
StoreException(ShardId, String) - Constructor for exception org.elasticsearch.index.store.StoreException
 
StoreException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.store.StoreException
 
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, Map<String, StoreFileMetaData>) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
StoreModule - Class in org.elasticsearch.index.store
 
StoreModule(Settings, IndexStore, ShardLock, Store.OnClose) - 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
 
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
 
storeTermVectorOffsets(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
storeTermVectorPayloads(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
storeTermVectorPositions(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
storeTermVectors(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
StoreUtils - Class in org.apache.lucene.store
 
strategy(String) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
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.GeoShapeFilterBuilder
Defines which spatial strategy will be used for building the geo shape filter.
strategy(SpatialStrategy) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
Defines which spatial strategy will be used for building the geo shape query.
stream() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
stream(BytesReference) - Static method in class org.elasticsearch.search.aggregations.AggregationStreams
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.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(String) - Static method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicStreams
Returns the stream that is registered for the given name
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.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.InternalPercentileRanks
 
STREAM - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
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(BytesReference) - Static method in class org.elasticsearch.search.facet.InternalFacet.Streams
 
Streamable - 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.HashedBytesArray
 
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.lzf.LZFCompressor
 
StreamInput - Class in org.elasticsearch.common.io.stream
 
StreamInput() - Constructor for class org.elasticsearch.common.io.stream.StreamInput
 
streamOutput(StreamOutput) - Method in interface org.elasticsearch.common.compress.Compressor
 
streamOutput(StreamOutput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
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
 
Streams() - Constructor for class org.elasticsearch.search.facet.InternalFacet.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
 
streamType() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
streamType() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
streamType() - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
streamType() - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
streamType() - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
streamType() - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
streamType() - Method in class org.elasticsearch.search.facet.InternalFacet
 
streamType() - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
streamType() - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
streamType() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
streamType() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
streamType() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
strict() - Static method in class org.elasticsearch.action.support.IndicesOptions
Deprecated.
in favor of IndicesOptions.strictExpandOpen() whose name makes it clearer what the method actually does.
StrictDynamicMappingException - Exception in org.elasticsearch.index.mapper
 
StrictDynamicMappingException(String, String) - 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
 
strictSingleIndexNoExpandForbidClosed() - Static method in class org.elasticsearch.action.support.IndicesOptions
 
string() - Method in class org.elasticsearch.common.compress.CompressedString
 
string() - Method in class org.elasticsearch.common.text.BytesText
 
string() - Method in class org.elasticsearch.common.text.StringAndBytesText
 
string() - Method in class org.elasticsearch.common.text.StringText
 
string() - Method in interface org.elasticsearch.common.text.Text
Returns the string representation of the text, might be converted to a string on the fly.
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
 
StringAndBytesText - Class in org.elasticsearch.common.text
Both String and BytesReference representation of the text.
StringAndBytesText(BytesReference) - Constructor for class org.elasticsearch.common.text.StringAndBytesText
 
StringAndBytesText(String) - Constructor for class org.elasticsearch.common.text.StringAndBytesText
 
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.
StringEntry(HashedBytesRef, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
StringEntry(Text, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
stringField(FieldInfo, String) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
stringField(FieldInfo, String) - Method in class org.elasticsearch.index.fieldvisitor.UidAndRoutingFieldsVisitor
 
stringField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
StringFieldMapper - Class in org.elasticsearch.index.mapper.core
 
StringFieldMapper(FieldMapper.Names, float, FieldType, FieldType, Boolean, String, NamedAnalyzer, NamedAnalyzer, NamedAnalyzer, int, int, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, AbstractFieldMapper.MultiFields, AbstractFieldMapper.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.TypeParser - Class in org.elasticsearch.index.mapper.core
 
StringFieldMapper.ValueAndBoost - Class in org.elasticsearch.index.mapper.core
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<InternalTerms.Bucket>, boolean, long, long) - 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, long, Terms.Order, TermsAggregator.BucketCountThresholds, IncludeExclude, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
 
StringText - Class in org.elasticsearch.common.text
A String only representation of the text.
StringText(String) - Constructor for class org.elasticsearch.common.text.StringText
 
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
 
subAggCollectMode - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
 
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
 
subAggregators - Variable in class org.elasticsearch.search.aggregations.Aggregator
 
subAggregators() - Method in class org.elasticsearch.search.aggregations.Aggregator
 
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, Priority, ClusterStateUpdateTask) - Method in interface org.elasticsearch.cluster.ClusterService
Submits a task that will update the cluster state.
submitStateUpdateTask(String, ClusterStateUpdateTask) - Method in interface org.elasticsearch.cluster.ClusterService
Submits a task that will update the cluster state (the task has a default priority of Priority.NORMAL).
submitStateUpdateTask(String, ClusterStateUpdateTask) - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
submitStateUpdateTask(String, Priority, ClusterStateUpdateTask) - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
submitStateUpdateTask(String, RiverClusterStateUpdateTask) - Method in class org.elasticsearch.river.cluster.RiverClusterService
 
subOne(long) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
 
subPath(int, int) - Method in class org.elasticsearch.search.aggregations.support.OrderPath
 
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.mlt.MoreLikeThisRequest
 
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.termvector.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() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Marks snapshot as successful
successfulOps - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
successfulShards(int) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets total number fo shards that were successfully snapshotted
successfulShards() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns total number of shards that were successfully snapshotted
successfulShards() - Method in class org.elasticsearch.snapshots.RestoreInfo
Number of successful shards
successfulShards() - Method in interface 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.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
set a new source using a SuggestBuilder.SuggestionBuilder for completion suggestion lookup
suggest(BytesReference, boolean) - 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(SuggestRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
suggest(SuggestRequest, ActionListener<SuggestResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
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
 
SuggestBuilderException - Exception in org.elasticsearch.search.suggest
Exception thrown when errors are encountered in building Suggest lookup queries via SuggestBuilder
SuggestBuilderException(String) - Constructor for exception org.elasticsearch.search.suggest.SuggestBuilderException
 
SuggestBuilderException(String, Throwable) - Constructor for exception org.elasticsearch.search.suggest.SuggestBuilderException
 
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(Set<Suggester>) - Constructor for class org.elasticsearch.search.suggest.Suggesters
 
suggestIndexGateway() - Method in interface org.elasticsearch.gateway.Gateway
 
suggestIndexGateway() - Method in class org.elasticsearch.gateway.local.LocalGateway
 
suggestIndexGateway() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
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.
SuggestModule - Class in org.elasticsearch.search.suggest
 
SuggestModule() - Constructor for class org.elasticsearch.search.suggest.SuggestModule
 
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(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(Client) - Constructor for class org.elasticsearch.action.suggest.SuggestRequestBuilder
 
SuggestResponse - Class in org.elasticsearch.action.suggest
The response of the suggest action.
SuggestShardModule - Class in org.elasticsearch.index.suggest
 
SuggestShardModule() - Constructor for class org.elasticsearch.index.suggest.SuggestShardModule
 
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 jsr166e.DoubleAdder
Returns the current sum.
sum() - Method in class jsr166e.LongAdder
Returns the current sum.
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, long, ValuesSource.Numeric, ValueFormatter, AggregationContext, Aggregator) - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumAggregator
 
SumAggregator.Factory - Class in org.elasticsearch.search.aggregations.metrics.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
 
sumOfSquares() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetExecutor.StatsProc
 
SumParser - Class in org.elasticsearch.search.aggregations.metrics.sum
 
SumParser() - Constructor for class org.elasticsearch.search.aggregations.metrics.sum.SumParser
 
sumThenReset() - Method in class jsr166e.DoubleAdder
Equivalent in effect to sum() followed by reset().
sumThenReset() - Method in class jsr166e.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().
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.
supportsNullValue() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
supportsNullValue() - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
supportsNullValue() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
SURVIVOR - Static variable in class org.elasticsearch.monitor.jvm.GcNames
 
swap() - Method in class org.elasticsearch.monitor.os.OsInfo
 
swap() - Method in class org.elasticsearch.monitor.os.OsStats
 
Swap() - Constructor for class org.elasticsearch.monitor.os.OsStats.Swap
 
swapPrimaryFlag(MutableShardRouting...) - 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, Settings, 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(Collection<String>) - Method in class org.elasticsearch.index.store.DistributorDirectory
 
sync() - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
sync() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
sync() - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
sync() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
sync() - Method in interface org.elasticsearch.index.translog.Translog
Sync's the translog.
syncNeeded() - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
syncNeeded() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
syncNeeded() - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
syncNeeded() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
syncNeeded() - Method in interface org.elasticsearch.index.translog.Translog
 
syncOnEachOperation(boolean) - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
syncOnEachOperation(boolean) - Method in interface org.elasticsearch.index.translog.Translog
 
SynonymTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
SynonymTokenFilterFactory(Index, Settings, Environment, IndicesAnalysisService, Map<String, TokenizerFactoryFactory>, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SynonymTokenFilterFactory
 
sys() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
sys() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu kernel time.
SYSTEM_ERR - Static variable in class org.elasticsearch.common.logging.log4j.ConsoleAppender
 
SYSTEM_OUT - Static variable in class org.elasticsearch.common.logging.log4j.ConsoleAppender
 
systemProperties() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 

T

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
 
targetRoutingIfRelocating() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
targetRoutingIfRelocating() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
If the shard is relocating, return a shard routing representing the target shard or null o.w.
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
 
taskCount() - Method in class org.elasticsearch.common.StopWatch
Return the number of tasks timed.
taskInfo() - Method in class org.elasticsearch.common.StopWatch
Return an array of the data for tasks performed.
tb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
tbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
tcp() - Method in class org.elasticsearch.monitor.network.NetworkStats
 
Tcp() - Constructor for class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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
 
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
 
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(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() - Method in class org.elasticsearch.index.query.TemplateQueryParser.TemplateContext
 
TemplateContext(ScriptService.ScriptType, String, Map<String, Object>) - Constructor for class org.elasticsearch.index.query.TemplateQueryParser.TemplateContext
 
templateName(String) - Method in class org.elasticsearch.action.search.SearchRequest
The name of the stored template
templateName() - Method in class org.elasticsearch.action.search.SearchRequest
The name of the stored template
templateName() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
 
templateName() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
 
templateName() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 
templateParams(Map<String, Object>) - Method in class org.elasticsearch.action.search.SearchRequest
Template parameters used for rendering
templateParams() - Method in class org.elasticsearch.action.search.SearchRequest
Template parameters used for rendering
templateParams() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
 
templateParams() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
 
templateParams() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 
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(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
 
TemplateQueryParser.TemplateContext - Class in org.elasticsearch.index.query
 
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, boolean) - 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
The name of the stored template
templateType() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
 
templateType() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
 
templateType() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 
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, String) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
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
 
TermEntry(String, int) - Constructor for class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.TermEntry
 
TermEntry(BytesRef, int) - Constructor for class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.TermEntry
 
TermEntry(Text, int) - Constructor for class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.TermEntry
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Numeric field level filter are basically range queries with same value and included.
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
termFilter(Object, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
termFilter(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
termFilter(String, String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter for a field based on a term.
termFilter(String, int) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter for a field based on a term.
termFilter(String, long) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter for a field based on a term.
termFilter(String, float) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter for a field based on a term.
termFilter(String, double) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter for a field based on a term.
termFilter(String, Object) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter for a field based on a term.
TermFilterBuilder - Class in org.elasticsearch.index.query
A filter for a field based on a term.
TermFilterBuilder(String, String) - Constructor for class org.elasticsearch.index.query.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, int) - Constructor for class org.elasticsearch.index.query.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, long) - Constructor for class org.elasticsearch.index.query.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, float) - Constructor for class org.elasticsearch.index.query.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, double) - Constructor for class org.elasticsearch.index.query.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.TermFilterBuilder
A filter for a field based on a term.
TermFilterParser - Class in org.elasticsearch.index.query
 
TermFilterParser() - Constructor for class org.elasticsearch.index.query.TermFilterParser
 
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
 
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
Upon reaching terminateAfter counts, the count request will early terminate
terminateAfter() - Method in class org.elasticsearch.action.count.CountRequest
 
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
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.core.AbstractFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Numeric field level query are basically range queries with same value and included.
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
termQuery(Object, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
termQuery(Object, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
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.
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.termvector.TermVectorFields
 
terms(String) - Method in class org.elasticsearch.index.codec.postingsformat.BloomFilterPostingsFormat.BloomFilteredFieldsProducer
Deprecated.
 
terms(TermsLookup, boolean, CacheKeyFilter.Key) - Method in class org.elasticsearch.indices.cache.filter.terms.IndicesTermsFilterCache
 
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, Aggregator.BucketAggregationMode, AggregatorFactories, long, AggregationContext, Aggregator, TermsAggregator.BucketCountThresholds, Terms.Order, Aggregator.SubAggCollectionMode) - 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.
TermsDoubleFacetExecutor - Class in org.elasticsearch.search.facet.terms.doubles
 
TermsDoubleFacetExecutor(IndexNumericFieldData, int, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<BytesRef>, SearchScript, CacheRecycler) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetExecutor
 
TermsDoubleFacetExecutor.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.doubles
 
TermsDoubleFacetExecutor.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.doubles
 
termsFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
TermsFacet - Interface in org.elasticsearch.search.facet.terms
Terms facet allows to return facets of the most popular terms within the search query.
TermsFacet.ComparatorType - Enum in org.elasticsearch.search.facet.terms
Controls how the terms facets are ordered.
TermsFacet.Entry - Interface in org.elasticsearch.search.facet.terms
 
TermsFacetBuilder - Class in org.elasticsearch.search.facet.terms
Term facets allow to collect frequency of terms within one (or more) field.
TermsFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.terms.TermsFacetBuilder
Construct a new term facet with the provided facet name.
TermsFacetParser - Class in org.elasticsearch.search.facet.terms
 
TermsFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.terms.TermsFacetParser
 
termsFilter(List, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
termsFilter(List, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
termsFilter(List, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
termsFilter(List, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
termsFilter(String, String...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
termsFilter(String, int...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
termsFilter(String, long...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
termsFilter(String, float...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
termsFilter(String, double...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
termsFilter(String, Object...) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
termsFilter(String, Iterable<?>) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder - Class in org.elasticsearch.index.query
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder(String, String...) - Constructor for class org.elasticsearch.index.query.TermsFilterBuilder
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder(String, int...) - Constructor for class org.elasticsearch.index.query.TermsFilterBuilder
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder(String, long...) - Constructor for class org.elasticsearch.index.query.TermsFilterBuilder
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder(String, float...) - Constructor for class org.elasticsearch.index.query.TermsFilterBuilder
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder(String, double...) - Constructor for class org.elasticsearch.index.query.TermsFilterBuilder
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder(String, Object...) - Constructor for class org.elasticsearch.index.query.TermsFilterBuilder
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder(String, Iterable) - Constructor for class org.elasticsearch.index.query.TermsFilterBuilder
A filer for a field based on several terms matching on any of them.
TermsFilterParser - Class in org.elasticsearch.index.query
 
TermsFilterParser() - Constructor for class org.elasticsearch.index.query.TermsFilterParser
 
TermsLongFacetExecutor - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLongFacetExecutor(IndexNumericFieldData, int, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<BytesRef>, SearchScript, CacheRecycler) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongFacetExecutor
 
TermsLongFacetExecutor.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLongFacetExecutor.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLookup - Class in org.elasticsearch.indices.cache.filter.terms
 
TermsLookup(String, String, String, String, String, QueryParseContext) - Constructor for class org.elasticsearch.indices.cache.filter.terms.TermsLookup
 
termsLookupFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A terms lookup filter for the provided field name.
TermsLookupFilterBuilder - Class in org.elasticsearch.index.query
A filer for a field based on several terms matching on any of them.
TermsLookupFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.TermsLookupFilterBuilder
 
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(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
 
TermsQueryBuilder(String, String...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
A query for a field based on several terms matching on any of them.
TermsQueryBuilder(String, int...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
A query for a field based on several terms matching on any of them.
TermsQueryBuilder(String, long...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
A query for a field based on several terms matching on any of them.
TermsQueryBuilder(String, float...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
A query for a field based on several terms matching on any of them.
TermsQueryBuilder(String, double...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
A query for a field based on several terms matching on any of them.
TermsQueryBuilder(String, Object...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
A query for a field based on several terms matching on any of them.
TermsQueryBuilder(String, Collection) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
A query for a field based on several terms matching on any of them.
TermsQueryParser - Class in org.elasticsearch.index.query
"terms" : { "field_name" : [ "value1", "value2" ] "minimum_match" : 1 }
TermsQueryParser() - Constructor for class org.elasticsearch.index.query.TermsQueryParser
 
termsStatistics(Term[], TermStatistics[]) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
TermsStatsDoubleFacetExecutor - Class in org.elasticsearch.search.facet.termsstats.doubles
 
TermsStatsDoubleFacetExecutor(IndexNumericFieldData, IndexNumericFieldData, SearchScript, int, int, TermsStatsFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor
 
TermsStatsDoubleFacetExecutor.Aggregator - Class in org.elasticsearch.search.facet.termsstats.doubles
 
TermsStatsDoubleFacetExecutor.Aggregator.ValueAggregator - Class in org.elasticsearch.search.facet.termsstats.doubles
 
TermsStatsDoubleFacetExecutor.ScriptAggregator - Class in org.elasticsearch.search.facet.termsstats.doubles
 
termsStatsFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
Deprecated.
 
TermsStatsFacet - Interface in org.elasticsearch.search.facet.termsstats
 
TermsStatsFacet.ComparatorType - Enum in org.elasticsearch.search.facet.termsstats
Controls how the terms facets are ordered.
TermsStatsFacet.Entry - Interface in org.elasticsearch.search.facet.termsstats
 
TermsStatsFacetBuilder - Class in org.elasticsearch.search.facet.termsstats
 
TermsStatsFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
Constructs a new terms stats facet builder under the provided facet name.
TermsStatsFacetParser - Class in org.elasticsearch.search.facet.termsstats
 
TermsStatsFacetParser(Settings) - Constructor for class org.elasticsearch.search.facet.termsstats.TermsStatsFacetParser
 
TermsStatsLongFacetExecutor - Class in org.elasticsearch.search.facet.termsstats.longs
 
TermsStatsLongFacetExecutor(IndexNumericFieldData, IndexNumericFieldData, SearchScript, int, int, TermsStatsFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor
 
TermsStatsLongFacetExecutor.Aggregator - Class in org.elasticsearch.search.facet.termsstats.longs
 
TermsStatsLongFacetExecutor.Aggregator.ValueAggregator - Class in org.elasticsearch.search.facet.termsstats.longs
 
TermsStatsLongFacetExecutor.ScriptAggregator - Class in org.elasticsearch.search.facet.termsstats.longs
 
TermsStatsStringFacetExecutor - Class in org.elasticsearch.search.facet.termsstats.strings
 
TermsStatsStringFacetExecutor(IndexFieldData, IndexNumericFieldData, SearchScript, int, int, TermsStatsFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor
 
TermsStatsStringFacetExecutor.Aggregator - Class in org.elasticsearch.search.facet.termsstats.strings
 
TermsStatsStringFacetExecutor.Aggregator.ValueAggregator - Class in org.elasticsearch.search.facet.termsstats.strings
 
TermsStatsStringFacetExecutor.ScriptAggregator - Class in org.elasticsearch.search.facet.termsstats.strings
 
TermsStringFacetExecutor - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringFacetExecutor(IndexFieldData, int, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<BytesRef>, Pattern, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringFacetExecutor
 
TermsStringOrdinalsFacetExecutor - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringOrdinalsFacetExecutor(IndexOrdinalsFieldData, int, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<BytesRef>, Pattern, int) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetExecutor
 
TermsStringOrdinalsFacetExecutor.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringOrdinalsFacetExecutor.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.strings
 
termStatistics() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
termStatistics(boolean) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Return the term statistics for each term in the shard or skip.
termStatistics() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
 
termStatistics(Term, TermContext) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
termStatistics() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
termStrategy() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
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(TermVectorRequest) - Method in interface org.elasticsearch.client.Client
An action that returns the term vectors for a specific document.
termVector(TermVectorRequest, ActionListener<TermVectorResponse>) - Method in interface org.elasticsearch.client.Client
An action that returns the term vectors for a specific document.
termVector(TermVectorRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
termVector(TermVectorRequest, ActionListener<TermVectorResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
termVector(TermVectorRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
termVector(TermVectorRequest, ActionListener<TermVectorResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
TermVectorAction - Class in org.elasticsearch.action.termvector
 
TermVectorFields - Class in org.elasticsearch.action.termvector
This class represents the result of a TermVectorRequest.
TermVectorFields(BytesReference, BytesReference) - Constructor for class org.elasticsearch.action.termvector.TermVectorFields
 
termVectorOptionsToString(FieldType) - Static method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
TermVectorRequest - Class in org.elasticsearch.action.termvector
Request returning the term vector (doc frequency, positions, offsets) for a document.
TermVectorRequest() - Constructor for class org.elasticsearch.action.termvector.TermVectorRequest
 
TermVectorRequest(String, String, String) - Constructor for class org.elasticsearch.action.termvector.TermVectorRequest
Constructs a new term vector request for a document that will be fetch from the provided index.
TermVectorRequest(TermVectorRequest) - Constructor for class org.elasticsearch.action.termvector.TermVectorRequest
Constructs a new term vector request for a document that will be fetch from the provided index.
TermVectorRequest(MultiGetRequest.Item) - Constructor for class org.elasticsearch.action.termvector.TermVectorRequest
 
TermVectorRequest.Flag - Enum in org.elasticsearch.action.termvector
 
TermVectorRequestBuilder - Class in org.elasticsearch.action.termvector
 
TermVectorRequestBuilder(Client) - Constructor for class org.elasticsearch.action.termvector.TermVectorRequestBuilder
 
TermVectorRequestBuilder(Client, String, String, String) - Constructor for class org.elasticsearch.action.termvector.TermVectorRequestBuilder
 
TermVectorResponse - Class in org.elasticsearch.action.termvector
 
TermVectorResponse(String, String, String) - Constructor for class org.elasticsearch.action.termvector.TermVectorResponse
 
termVectors() - Method in class org.elasticsearch.search.lookup.IndexLookup
 
termVectorService() - Method in class org.elasticsearch.index.shard.IndexShard
 
testBlobPrefix(String) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
 
text() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
 
Text - Interface in org.elasticsearch.common.text
Text represents a (usually) long text data.
text() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
text() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
text - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
text(String) - Method in class org.elasticsearch.search.suggest.SuggestBuilder.SuggestionBuilder
Same as in SuggestBuilder.setText(String), but in the suggestion scope.
TEXT_CONTENT_TYPE - Static variable in class org.elasticsearch.rest.BytesRestResponse
 
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
 
textPhrase(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
use QueryBuilders.textPhraseQuery(String, Object) instead Will be removed in elasticsearch 2.0.0
textPhrasePrefix(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
use QueryBuilders.textPhrasePrefixQuery(String, Object) instead Will be removed in elasticsearch 2.0.0
textPhrasePrefixQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated.
Use QueryBuilders.matchPhrasePrefixQuery(String, Object) Will be removed in elasticsearch 2.0.0
textPhraseQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
tf() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
 
ThaiAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ThaiAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ThaiAnalyzerProvider
 
ThaiTokenizerFactory - Class in org.elasticsearch.index.analysis
Factory for ThaiTokenizer
ThaiTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ThaiTokenizerFactory
 
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.
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.broadcast.TransportBroadcastOperationAction
 
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.FilterClient.ClusterAdmin
 
threadPool() - Method in class org.elasticsearch.client.FilterClient.IndicesAdmin
 
threadPool() - Method in class org.elasticsearch.client.FilterClient
 
threadPool() - Method in class org.elasticsearch.client.node.NodeClient
 
threadPool() - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
threadPool() - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
threadPool() - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
threadPool() - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
threadPool() - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
threadPool() - Method in class org.elasticsearch.client.transport.TransportClient
 
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, NodeSettingsService) - 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_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(Settings) - 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
 
threads() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
ThreadSafeInputStreamIndexInput - Class in org.elasticsearch.common.lucene.store
 
ThreadSafeInputStreamIndexInput(IndexInput, long) - Constructor for class org.elasticsearch.common.lucene.store.ThreadSafeInputStreamIndexInput
 
thresholdBytesFromWatermark(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.fs.FsDirectoryService
 
throttleTimeInNanos() - Method in class org.elasticsearch.index.store.ram.RamDirectoryService
 
throttlingActivated() - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
ThrottlingAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
ThrottlingAllocationDecider controls the recovery process per node in the cluster.
ThrottlingAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
 
throttlingDeactivated() - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
ThrowableObjectInputStream - Class in org.elasticsearch.common.io
 
ThrowableObjectInputStream(InputStream) - Constructor for class org.elasticsearch.common.io.ThrowableObjectInputStream
 
ThrowableObjectInputStream(InputStream, ClassLoader) - Constructor for class org.elasticsearch.common.io.ThrowableObjectInputStream
 
ThrowableObjectOutputStream - Class in org.elasticsearch.common.io
 
ThrowableObjectOutputStream(OutputStream) - Constructor for class org.elasticsearch.common.io.ThrowableObjectOutputStream
 
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
 
TieredMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
TieredMergePolicyProvider(Store, IndexSettingsService) - Constructor for class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
TIME - Static variable in interface org.elasticsearch.cluster.settings.Validator
 
time() - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
time(long) - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
time() - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
time(long) - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
time() - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Translog
 
time(long) - Method in class org.elasticsearch.index.gateway.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
 
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
 
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
 
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.NodesOperationRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
timeout(String) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
timeout() - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
timeout - Variable in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
timeout() - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
A timeout to wait if the delete by query operation can't be performed immediately.
timeout(String) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
A timeout to wait if the delete by query operation can't be performed immediately.
timeout - Variable in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
A timeout to wait if the index operation can't be performed immediately.
timeout(String) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
A timeout to wait if the index operation can't be performed immediately.
timeout() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
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(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Request
 
timeout() - Method in class org.elasticsearch.cluster.TimeoutClusterStateUpdateTask
If the cluster state update task wasn't processed by the provided timeout, call ClusterStateUpdateTask.onFailure(String, Throwable)
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.
TimeoutClusterStateUpdateTask - Class in org.elasticsearch.cluster
An extension interface to ClusterStateUpdateTask that allows to associate a timeout.
TimeoutClusterStateUpdateTask() - Constructor for class org.elasticsearch.cluster.TimeoutClusterStateUpdateTask
 
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
 
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() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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
 
timestamp() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
timestamp() - Method in class org.elasticsearch.monitor.network.NetworkStats
 
timestamp() - Method in class org.elasticsearch.monitor.os.OsStats
 
timestamp() - Method in class org.elasticsearch.monitor.process.ProcessStats
 
timestampFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
TimestampFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
TimestampFieldMapper(Settings) - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
TimestampFieldMapper(FieldType, Boolean, EnabledAttributeMapper, String, FormatDateTimeFormatter, String, boolean, Boolean, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, FieldMapper.Loading, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
TimestampFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
TimestampFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
TimestampFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
TimestampParsingException - Exception in org.elasticsearch.action
 
TimestampParsingException(String) - 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 - Variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
timeUnit(TimeUnit) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
timeUnit - Variable in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
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
 
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(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.RangeFilterBuilder
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 time zone in which to translate dates before computing buckets.
TimeZoneRounding - Class in org.elasticsearch.common.rounding
 
TimeZoneRounding() - Constructor for class org.elasticsearch.common.rounding.TimeZoneRounding
 
TimeZoneRounding.Builder - Class in org.elasticsearch.common.rounding
 
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.GeoDistanceRangeFilterBuilder
 
to(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
to(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
to(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
to(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
to(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
Deprecated.
The to part of the filter query.
to(Object) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
to(int) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
to(long) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
to(float) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
to(double) - Method in class org.elasticsearch.index.query.RangeFilterBuilder
The to part of the filter query.
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.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.HashedBytesArray
 
toBytes() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
 
toBytes(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
 
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.HashedBytesArray
 
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.HashedBytesArray
 
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
 
toCacheable(AtomicReader, DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocIdSets
Converts to a cacheable DocIdSet

Note, we don't use DocIdSet.isCacheable() because execution might be expensive even if its cacheable (i.e.

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.HashedBytesArray
 
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.ImmutableSettings
 
toDelimitedString(char) - Method in interface 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(BytesRef, TokenStreamToAutomaton) - Method in class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
 
toFiniteStrings(TokenStreamToAutomaton, 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
 
toFixedBitSet(DocIdSetIterator, int) - Static method in class org.elasticsearch.common.lucene.docset.DocIdSets
Creates a FixedBitSet from an iterator.
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
 
toIndexForm(Number, BytesRefBuilder) - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
 
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) - 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, String, String) - Constructor for class org.elasticsearch.search.aggregations.support.OrderPath.Token
 
token(String, XContentParser.Token, XContentParser) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceParser
 
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(FieldMapper.Names, int, float, FieldType, Boolean, Integer, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, SimilarityProvider, FieldMapper.Loading, Settings, Settings, NamedAnalyzer, AbstractFieldMapper.MultiFields, AbstractFieldMapper.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.index.analysis.CustomAnalyzer
 
TokenFiltersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.TokenFiltersBindings
 
tokenized(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
tokenized(boolean) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.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(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
 
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
 
tokens - Variable in class org.elasticsearch.search.aggregations.support.OrderPath
 
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.GeoBoundingBoxFilterParser
 
TOP_LEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
TOP_LEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
TOP_RIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
toPB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
 
topChildrenQuery(String, QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
Constructs a new scoring child query, with the child type and the query to run on the child documents.
TopChildrenQuery - Class in org.elasticsearch.index.search.child
A query that evaluates the top matching child documents (based on the score) in order to determine what parent documents to return.
TopChildrenQuery(IndexParentChildFieldData, Query, String, String, ScoreType, int, int, CacheRecycler, FixedBitSetFilter) - Constructor for class org.elasticsearch.index.search.child.TopChildrenQuery
 
TopChildrenQueryBuilder - Class in org.elasticsearch.index.query
 
TopChildrenQueryBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.index.query.TopChildrenQueryBuilder
 
TopChildrenQueryParser - Class in org.elasticsearch.index.query
 
TopChildrenQueryParser() - Constructor for class org.elasticsearch.index.query.TopChildrenQueryParser
 
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
 
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, long, AggregationContext, Aggregator) - 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) - 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.GeoBoundingBoxFilterBuilder
Adds top left point.
topLeft(GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
topLeft(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
TOPLEFT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
topLeft() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
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
 
toPolygon() - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
 
toPolygon(GeometryFactory) - Method in class org.elasticsearch.common.geo.builders.BasePolygonBuilder
 
TopReaderContextAware - Interface in org.elasticsearch.common.lucene
 
topRight(double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
Adds top right point.
topRight(GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
topRight(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
TOPRIGHT - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxFilterParser
 
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
 
toSafeBits(AtomicReader, DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocIdSets
Gets a set to bits.
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() - Method in class jsr166e.DoubleAdder
Returns the String representation of the sum().
toString() - Method in class jsr166e.DoubleMaxUpdater
Returns the String representation of the DoubleMaxUpdater.max().
toString() - Method in class jsr166e.LongAdder
Returns the String representation of the LongAdder.sum().
toString() - Method in class jsr166e.LongMaxUpdater
Returns the String representation of the LongMaxUpdater.max().
toString(String) - Method in class org.apache.lucene.queries.BlendedTermQuery
 
toString() - Method in class org.apache.lucene.store.RateLimitedFSDirectory
 
toString(Directory) - Static method in class org.apache.lucene.store.StoreUtils
 
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.info.PluginInfo
 
toString() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
 
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.optimize.OptimizeRequest
 
toString() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
 
toString() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
 
toString() - Method in class org.elasticsearch.action.count.CountRequest
 
toString() - Method in class org.elasticsearch.action.delete.DeleteRequest
 
toString() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
toString() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
toString() - Method in class org.elasticsearch.action.exists.ExistsRequest
 
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.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 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.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
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.ImmutableShardRouting
 
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.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.ImmutableOpenLongMap
 
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.CompressedString
 
toString() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder.Edge
 
toString() - Method in class org.elasticsearch.common.geo.builders.ShapeBuilder
 
toString(long) - Static method in class org.elasticsearch.common.geo.GeoHashUtils
Formats a geohash held as a long as a more conventional String-based geohash
toString() - Method in class org.elasticsearch.common.geo.GeoPoint
 
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 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.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.io.stream.AdapterStreamInput
 
toString() - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
toString() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
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.HashedBytesRef
 
toString() - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
toString() - Method in class org.elasticsearch.common.lucene.search.ApplyAcceptedDocsFilter
 
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() - Method in class org.elasticsearch.common.lucene.search.MatchAllDocsFilter
 
toString() - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsFilter
 
toString(String) - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsQuery
 
toString(String) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
toString(String) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
 
toString(String) - Method in class org.elasticsearch.common.lucene.search.NoCacheQuery
 
toString() - Method in class org.elasticsearch.common.lucene.search.NotFilter
 
toString() - Method in class org.elasticsearch.common.lucene.search.OrFilter
 
toString() - Method in class org.elasticsearch.common.lucene.search.RegexpFilter
 
toString() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
Prints a user-readable version of this Filter.
toString(String) - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery
Prints a user-readable version of this query.
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() - Method in class org.elasticsearch.common.text.BytesText
 
toString() - Method in class org.elasticsearch.common.text.StringAndBytesText
 
toString() - Method in class org.elasticsearch.common.text.StringText
 
toString() - Method in interface org.elasticsearch.common.text.Text
Returns the string representation of the text, might be converted to a string on the fly.
toString() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
 
toString() - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
toString() - Method in class org.elasticsearch.common.transport.LocalTransportAddress
 
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.Percent
 
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(Locale) - Static method in class org.elasticsearch.common.util.LocaleUtils
Return a string for a Locale object
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.discovery.zen.ping.ZenPing.PingResponse
 
toString() - Method in class org.elasticsearch.env.ShardLock
 
toString() - Method in class org.elasticsearch.gateway.local.state.shards.ShardStateInfo
 
toString() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
toString() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
 
toString() - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
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.gateway.local.LocalIndexGateway
 
toString() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
toString() - Method in class org.elasticsearch.index.gateway.none.NoneIndexGateway
 
toString() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
toString() - Method in class org.elasticsearch.index.Index
 
toString() - Method in class org.elasticsearch.index.indexing.slowlog.ShardSlowLogIndexingService.SlowLogParsedDocumentPrinter
 
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.merge.EnableMergeScheduler
 
toString() - Method in class org.elasticsearch.index.merge.policy.ElasticsearchMergePolicy
 
toString() - Method in class org.elasticsearch.index.query.BaseFilterBuilder
 
toString() - Method in class org.elasticsearch.index.query.BaseQueryBuilder
 
toString() - Method in class org.elasticsearch.index.query.ScriptFilterParser.ScriptFilter
 
toString() - Method in class org.elasticsearch.index.query.TemplateQueryParser.TemplateContext
 
toString() - Method in class org.elasticsearch.index.recovery.RecoveryStats
 
toString(String) - Method in class org.elasticsearch.index.search.child.ChildrenConstantScoreQuery
 
toString(String) - Method in class org.elasticsearch.index.search.child.ChildrenQuery
 
toString() - Method in class org.elasticsearch.index.search.child.CustomQueryWrappingFilter
 
toString(String) - Method in class org.elasticsearch.index.search.child.ParentConstantScoreQuery
 
toString(String) - Method in class org.elasticsearch.index.search.child.ParentQuery
 
toString(String) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
toString() - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.BytesFieldDataFilter
 
toString() - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.DoublesFieldDataFilter
 
toString() - Method in class org.elasticsearch.index.search.FieldDataTermsFilter.LongsFieldDataFilter
 
toString() - Method in class org.elasticsearch.index.search.FieldDataTermsFilter
 
toString() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
toString() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
toString() - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
toString() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
toString(String) - Method in class org.elasticsearch.index.search.nested.IncludeNestedDocsQuery
 
toString() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
toString() - Method in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService.SlowLogSearchContextPrinter
 
toString() - Method in class org.elasticsearch.index.search.stats.SearchStats
 
toString() - Method in class org.elasticsearch.index.shard.ShardId
 
toString() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
 
toString() - Method in class org.elasticsearch.index.store.distributor.AbstractDistributor
 
toString() - Method in class org.elasticsearch.index.store.DistributorDirectory
 
toString() - Method in class org.elasticsearch.index.store.Store.RecoveryDiff
 
toString() - Method in class org.elasticsearch.index.store.Store.StoreDirectory
 
toString() - Method in class org.elasticsearch.index.store.StoreFileMetaData
 
toString() - Method in class org.elasticsearch.index.store.VerifyingIndexOutput
 
toString() - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
toString() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
toString() - Method in class org.elasticsearch.index.translog.Translog.Location
 
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.filter.terms.TermsLookup
 
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.repositories.VerificationFailure
 
toString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
toString() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
 
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.OrderPath.Token
 
toString() - Method in class org.elasticsearch.search.aggregations.support.OrderPath
 
toString() - Method in enum org.elasticsearch.search.aggregations.support.ValueType
 
toString() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
toString() - Method in enum org.elasticsearch.search.facet.FacetBuilder.Mode
 
toString() - Method in class org.elasticsearch.search.highlight.HighlightField
 
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.SnapshotShardFailure
 
toString() - Method in class org.elasticsearch.transport.PlainTransportFuture
 
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.FsStats
 
total() - Method in class org.elasticsearch.monitor.os.OsInfo.Mem
 
total() - Method in class org.elasticsearch.monitor.os.OsInfo.Swap
 
total() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu time (sum of User and Sys).
total() - Method in class org.elasticsearch.search.facet.DoubleFacetAggregatorBase
 
total() - Method in class org.elasticsearch.search.facet.LongFacetAggregatorBase
 
total() - Method in class org.elasticsearch.search.facet.terms.strings.HashedAggregator
 
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
totalCapacity() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
totalChannels() - Method in class org.elasticsearch.common.netty.OpenChannelsHandler
 
totalCores() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
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() - Method in interface org.elasticsearch.search.SearchHits
The total number of hits that matches the search request.
totalMergeNumDocs() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
totalMerges() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
totalMergeSizeInBytes() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
totalMergeTime() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
totalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
totalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
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(int) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets total number of shards across all snapshot indices
totalShard() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns total number of shards that were snapshotted
totalShard() - Method in interface org.elasticsearch.snapshots.Snapshot
Returns total number of shards that were snapshotted
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.gateway.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
totalSizeInBytes() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
totalSizeWith1ForEmpty() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
Returns the total number of shards plus the number of empty groups
totalSockets() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
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.RecoveryFileChunkRequest
 
totalVirtual() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
toTB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
 
toTera(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
 
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.HashedBytesArray
 
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.admin.cluster.health.ClusterHealthResponse
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
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.PluginInfo
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsInfo
 
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.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.indices.analyze.AnalyzeResponse
 
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.recovery.ShardRecoveryResponse
 
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.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.status.IndicesStatusResponse
Deprecated.
 
toXContent(XContentBuilder, ToXContent.Params, SettingsFilter) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
Deprecated.
 
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.support.QuerySourceBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
toXContent(T, XContentBuilder, ToXContent.Params) - Method in interface org.elasticsearch.cluster.ClusterState.Custom.Factory
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.ClusterState
 
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(T, XContentBuilder, ToXContent.Params) - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom.Factory
 
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(T, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
toXContent(RepositoriesMetaData, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData.Factory
toXContent(RepositoryMetaData, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData.Factory
Serializes information about a single repository
toXContent(RestoreMetaData, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Factory
toXContent(RestoreMetaData.Entry, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Factory
Serializes single restore operation
toXContent(SnapshotMetaData, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Factory
 
toXContent(SnapshotMetaData.Entry, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Factory
 
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.ImmutableShardRouting
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RestoreSource
 
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.ImmutableSettings
 
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, T) - Method in class org.elasticsearch.gateway.local.state.meta.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.filter.FilterCacheStats
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
 
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(CommitPoint) - Static method in class org.elasticsearch.index.gateway.CommitPoints
 
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.AbstractFieldMapper.CopyTo
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
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.internal.AllFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
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.SizeFieldMapper
 
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.object.ObjectMapper
 
toXContent(XContentBuilder, ToXContent.Params, ToXContent, Mapper...) - 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.BaseFilterBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BaseQueryBuilder
 
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.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(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(BlobStoreIndexShardSnapshot, XContentBuilder, ToXContent.Params) - Static 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.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.Start
 
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.monitor.fs.FsStats.Info
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsStats
 
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.network.NetworkInfo
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.network.NetworkStats
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
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(BlobStoreSnapshot, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Serializes the snapshot
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
 
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) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare.ChiSquareBuilder
 
toXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND.GNDBuilder
 
toXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore.JLHScoreBuilder
 
toXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation.MutualInformationBuilder
 
toXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore.PercentageScoreBuilder
 
toXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic.ScriptHeuristicBuilder
 
toXContent(XContentBuilder) - Method in interface org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristicBuilder
 
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.builder.SearchSourceBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.filter.FilterFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.InternalFacets
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.query.QueryFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
 
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.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(IndexWarmersMetaData, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
toXContent(IndexWarmersMetaData.Entry, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.RestoreInfo
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.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.
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
 
TrackingConcurrentMergeScheduler - Class in org.apache.lucene.index
An extension to the ConcurrentMergeScheduler that provides tracking on merge times, total and current merges.
TrackingConcurrentMergeScheduler(ESLogger) - Constructor for class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
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
 
transactionBegin() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
 
transactionEnd(RoutingNodes.UnassignedShards) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
 
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.
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.gateway.SnapshotStatus
 
Translog() - Constructor for class org.elasticsearch.index.gateway.SnapshotStatus.Translog
 
translog() - Method in class org.elasticsearch.index.shard.IndexShard
 
Translog - Interface in org.elasticsearch.index.translog
 
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.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_CODEC - Static variable in class org.elasticsearch.index.translog.TranslogStreams
 
TRANSLOG_FOLDER_NAME - Static variable in class org.elasticsearch.index.store.support.AbstractIndexStore
 
TRANSLOG_ID_KEY - Static variable in interface org.elasticsearch.index.translog.Translog
 
TRANSLOG_OPS - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
 
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
 
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
 
translogFiles() - Method in class org.elasticsearch.index.gateway.CommitPoint
 
translogId() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
translogId - Variable in class org.elasticsearch.index.translog.Translog.Location
 
translogId() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
The id of the translog the snapshot was taken with.
translogLocation - Variable in class org.elasticsearch.index.translog.Translog.Location
 
TranslogModule - Class in org.elasticsearch.index.translog
 
TranslogModule(Settings) - Constructor for class org.elasticsearch.index.translog.TranslogModule
 
TranslogModule.TranslogSettings - Class in org.elasticsearch.index.translog
 
translogOps() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
 
TranslogService - Class in org.elasticsearch.index.translog
 
TranslogService(ShardId, Settings, IndexSettingsService, ThreadPool, IndexShard, Translog) - Constructor for class org.elasticsearch.index.translog.TranslogService
 
TranslogSettings() - Constructor for class org.elasticsearch.index.translog.TranslogModule.TranslogSettings
 
translogSize() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
 
translogSizeInBytes() - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
translogSizeInBytes() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
translogSizeInBytes() - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
translogSizeInBytes() - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
translogSizeInBytes() - Method in interface org.elasticsearch.index.translog.Translog
Returns the size in bytes of the translog.
translogSizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogStats
 
translogStats() - Method in class org.elasticsearch.index.shard.IndexShard
 
TranslogStats - Class in org.elasticsearch.index.translog
 
TranslogStats() - Constructor for class org.elasticsearch.index.translog.TranslogStats
 
TranslogStats(int, long) - Constructor for class org.elasticsearch.index.translog.TranslogStats
 
TranslogStream - Interface in org.elasticsearch.index.translog
A translog stream that will read and write operations in the version-specific format
translogStreamFor(File) - Static method in class org.elasticsearch.index.translog.TranslogStreams
Given a file, return a VersionedTranslogStream based on an optionally-existing header in the file.
TranslogStreams - Class in org.elasticsearch.index.translog
Encapsulating class used for operating on translog streams.
TranslogStreams() - Constructor for class org.elasticsearch.index.translog.TranslogStreams
 
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) - 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
Returns the current registered transport addresses to use (added using TransportClient.addTransportAddress(org.elasticsearch.common.transport.TransportAddress).
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
 
TransportAggregationModule - Class in org.elasticsearch.search.aggregations
A module that registers all the transport streams for the addAggregation
TransportAggregationModule() - Constructor for class org.elasticsearch.search.aggregations.TransportAggregationModule
 
TransportAliasesExistAction - Class in org.elasticsearch.action.admin.indices.alias.exists
 
TransportAliasesExistAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters) - 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) - Constructor for class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
 
TransportBroadcastOperationAction<Request extends BroadcastOperationRequest,Response extends BroadcastOperationResponse,ShardRequest extends BroadcastShardOperationRequest,ShardResponse extends BroadcastShardOperationResponse> - Class in org.elasticsearch.action.support.broadcast
 
TransportBroadcastOperationAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
TransportBroadcastOperationAction.AsyncBroadcastAction - Class in org.elasticsearch.action.support.broadcast
 
TransportBulkAction - Class in org.elasticsearch.action.bulk
 
TransportBulkAction(Settings, ThreadPool, TransportService, ClusterService, TransportShardBulkAction, TransportCreateIndexAction, ActionFilters) - Constructor for class org.elasticsearch.action.bulk.TransportBulkAction
 
TransportChannel - Interface in org.elasticsearch.transport
A transport channel allows to send a response to a request on the channel.
TransportClearIndicesCacheAction - Class in org.elasticsearch.action.admin.indices.cache.clear
Indices clear cache action.
TransportClearIndicesCacheAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, IndicesTermsFilterCache, IndicesQueryCache, ActionFilters) - 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) - Constructor for class org.elasticsearch.action.search.TransportClearScrollAction
 
TransportClient - Class in org.elasticsearch.client.transport
The transport client allows to create a client that is not part of the cluster, but simply connects to one or more nodes directly by adding their respective addresses using TransportClient.addTransportAddress(org.elasticsearch.common.transport.TransportAddress).
TransportClient() - Constructor for class org.elasticsearch.client.transport.TransportClient
Constructs a new transport client with settings loaded either from the classpath or the file system (the elasticsearch.(yml|json) files optionally prefixed with config/).
TransportClient(Settings) - Constructor for class org.elasticsearch.client.transport.TransportClient
Constructs a new transport client with explicit settings and settings loaded either from the classpath or the file system (the elasticsearch.(yml|json) files optionally prefixed with config/).
TransportClient(Settings.Builder) - Constructor for class org.elasticsearch.client.transport.TransportClient
Constructs a new transport client with explicit settings and settings loaded either from the classpath or the file system (the elasticsearch.(yml|json) files optionally prefixed with config/).
TransportClient(Settings.Builder, boolean) - Constructor for class org.elasticsearch.client.transport.TransportClient
Constructs a new transport client with the provided settings and the ability to control if settings will be loaded from the classpath / file system (the elasticsearch.(yml|json) files optionally prefixed with config/).
TransportClient(Settings, boolean) - Constructor for class org.elasticsearch.client.transport.TransportClient
Constructs a new transport client with the provided settings and the ability to control if settings will be loaded from the classpath / file system (the elasticsearch.(yml|json) files optionally prefixed with config/).
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) - 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) - 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) - 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) - 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) - 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) - 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) - Constructor for class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
 
TransportClusterUpdateSettingsAction - Class in org.elasticsearch.action.admin.cluster.settings
 
TransportClusterUpdateSettingsAction(Settings, TransportService, ClusterService, ThreadPool, AllocationService, DynamicSettings, ActionFilters) - 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.TransportNodesOperationAction
 
transportCompress() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
transportCompress() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
TransportConnectionListener - Interface in org.elasticsearch.transport
 
TransportCountAction - Class in org.elasticsearch.action.count
 
TransportCountAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ScriptService, CacheRecycler, PageCacheRecycler, BigArrays, ActionFilters) - Constructor for class org.elasticsearch.action.count.TransportCountAction
 
TransportCreateIndexAction - Class in org.elasticsearch.action.admin.indices.create
Create index action.
TransportCreateIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataCreateIndexService, ActionFilters) - 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) - 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, TransportIndexDeleteAction, ActionFilters) - Constructor for class org.elasticsearch.action.delete.TransportDeleteAction
 
TransportDeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
 
TransportDeleteByQueryAction(Settings, ClusterService, TransportService, ThreadPool, TransportIndexDeleteByQueryAction, NodeSettingsService, ActionFilters) - Constructor for class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
TransportDeleteIndexAction - Class in org.elasticsearch.action.admin.indices.delete
Delete index action.
TransportDeleteIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataDeleteIndexService, NodeSettingsService, ActionFilters) - 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) - 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) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
TransportDeleteMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.delete
Delete mapping action.
TransportDeleteMappingAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataMappingService, TransportDeleteByQueryAction, TransportRefreshAction, TransportFlushAction, NodeSettingsService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
TransportDeleteRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.delete
Transport action for unregister repository operation
TransportDeleteRepositoryAction(Settings, TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters) - 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) - 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) - Constructor for class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
 
TransportException - Exception in org.elasticsearch.transport
 
TransportException(String) - Constructor for exception org.elasticsearch.transport.TransportException
 
TransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.TransportException
 
TransportExistsAction - Class in org.elasticsearch.action.exists
 
TransportExistsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ScriptService, CacheRecycler, PageCacheRecycler, BigArrays, ActionFilters) - 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, CacheRecycler, PageCacheRecycler, BigArrays, ActionFilters) - Constructor for class org.elasticsearch.action.explain.TransportExplainAction
 
TransportFacetModule - Class in org.elasticsearch.search.facet
 
TransportFacetModule() - Constructor for class org.elasticsearch.search.facet.TransportFacetModule
 
TransportFlushAction - Class in org.elasticsearch.action.admin.indices.flush
Flush Action.
TransportFlushAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
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) - Constructor for class org.elasticsearch.action.get.TransportGetAction
 
TransportGetAliasesAction - Class in org.elasticsearch.action.admin.indices.alias.get
 
TransportGetAliasesAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - Constructor for class org.elasticsearch.action.index.TransportIndexAction
 
TransportIndexDeleteAction - Class in org.elasticsearch.action.delete
Internal transport action that broadcasts a delete request to all of the shards that belongs to an index.
TransportIndexDeleteAction(Settings, ClusterService, ThreadPool, TransportShardDeleteAction, ActionFilters) - Constructor for class org.elasticsearch.action.delete.TransportIndexDeleteAction
 
TransportIndexDeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
Internal transport action that broadcasts a delete by query request to all of the shards that belong to an index.
TransportIndexDeleteByQueryAction(Settings, ClusterService, ThreadPool, TransportShardDeleteByQueryAction, ActionFilters) - Constructor for class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
TransportIndexReplicationOperationAction<Request extends IndexReplicationOperationRequest,Response extends ActionResponse,ShardRequest extends ShardReplicationOperationRequest,ShardReplicaRequest extends ShardReplicationOperationRequest,ShardResponse extends ActionResponse> - Class in org.elasticsearch.action.support.replication
Internal transport action that executes on multiple shards, doesn't register any transport handler as it is always executed locally.
TransportIndexReplicationOperationAction(Settings, String, ClusterService, ThreadPool, TransportShardReplicationOperationAction<ShardRequest, ShardReplicaRequest, ShardResponse>, ActionFilters) - Constructor for class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
TransportIndicesAliasesAction - Class in org.elasticsearch.action.admin.indices.alias
Add/remove aliases action
TransportIndicesAliasesAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexAliasesService, ActionFilters) - 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) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
 
TransportIndicesReplicationOperationAction<Request extends IndicesReplicationOperationRequest,Response extends ActionResponse,IndexRequest extends IndexReplicationOperationRequest,IndexResponse extends ActionResponse,ShardRequest extends ShardReplicationOperationRequest,ShardReplicaRequest extends ShardReplicationOperationRequest,ShardResponse extends ActionResponse> - Class in org.elasticsearch.action.support.replication
 
TransportIndicesReplicationOperationAction(Settings, String, TransportService, ClusterService, ThreadPool, TransportIndexReplicationOperationAction<IndexRequest, IndexResponse, ShardRequest, ShardReplicaRequest, ShardResponse>, ActionFilters) - Constructor for class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
TransportIndicesSegmentsAction - Class in org.elasticsearch.action.admin.indices.segments
 
TransportIndicesSegmentsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
TransportIndicesStatsAction - Class in org.elasticsearch.action.admin.indices.stats
 
TransportIndicesStatsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
TransportIndicesStatusAction - Class in org.elasticsearch.action.admin.indices.status
Deprecated.
TransportIndicesStatusAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Deprecated.
 
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) - Constructor for class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
TransportInstanceSingleOperationAction.InternalRequest - Class in org.elasticsearch.action.support.single.instance
Internal request class that gets built on each node.
TransportMasterNodeOperationAction<Request extends MasterNodeOperationRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.master
A base class for operations that needs to be performed on the master node.
TransportMasterNodeOperationAction(Settings, String, TransportService, ClusterService, ThreadPool, ActionFilters) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
TransportMasterNodeReadOperationAction<Request extends MasterNodeReadOperationRequest,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.
TransportMasterNodeReadOperationAction(Settings, String, TransportService, ClusterService, ThreadPool, ActionFilters) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeReadOperationAction
 
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) - Constructor for class org.elasticsearch.transport.TransportModule
 
TransportMoreLikeThisAction - Class in org.elasticsearch.action.mlt
The more like this action.
TransportMoreLikeThisAction(Settings, ThreadPool, TransportSearchAction, TransportGetAction, ClusterService, IndicesService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.mlt.TransportMoreLikeThisAction
 
TransportMultiGetAction - Class in org.elasticsearch.action.get
 
TransportMultiGetAction(Settings, ThreadPool, TransportService, ClusterService, TransportShardMultiGetAction, ActionFilters) - Constructor for class org.elasticsearch.action.get.TransportMultiGetAction
 
TransportMultiPercolateAction - Class in org.elasticsearch.action.percolate
 
TransportMultiPercolateAction(Settings, ThreadPool, TransportShardMultiPercolateAction, ClusterService, TransportService, PercolatorService, TransportMultiGetAction, ActionFilters) - Constructor for class org.elasticsearch.action.percolate.TransportMultiPercolateAction
 
TransportMultiSearchAction - Class in org.elasticsearch.action.search
 
TransportMultiSearchAction(Settings, ThreadPool, TransportService, ClusterService, TransportSearchAction, ActionFilters) - Constructor for class org.elasticsearch.action.search.TransportMultiSearchAction
 
TransportMultiTermVectorsAction - Class in org.elasticsearch.action.termvector
 
TransportMultiTermVectorsAction(Settings, ThreadPool, TransportService, ClusterService, TransportSingleShardMultiTermsVectorAction, ActionFilters) - Constructor for class org.elasticsearch.action.termvector.TransportMultiTermVectorsAction
 
TransportNodesHotThreadsAction - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
 
TransportNodesHotThreadsAction(Settings, ClusterName, ThreadPool, ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
TransportNodesInfoAction - Class in org.elasticsearch.action.admin.cluster.node.info
 
TransportNodesInfoAction(Settings, ClusterName, ThreadPool, ClusterService, TransportService, NodeService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
TransportNodesListGatewayMetaState - Class in org.elasticsearch.gateway.local.state.meta
 
TransportNodesListGatewayMetaState(Settings, ClusterName, ThreadPool, ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState - Class in org.elasticsearch.gateway.local.state.meta
 
TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState - Class in org.elasticsearch.gateway.local.state.meta
 
TransportNodesListGatewayStartedShards - Class in org.elasticsearch.gateway.local.state.shards
 
TransportNodesListGatewayStartedShards(Settings, ClusterName, ThreadPool, ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards - Class in org.elasticsearch.gateway.local.state.shards
 
TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards - Class in org.elasticsearch.gateway.local.state.shards
 
TransportNodesListShardStoreMetaData - Class in org.elasticsearch.indices.store
 
TransportNodesListShardStoreMetaData(Settings, ClusterName, ThreadPool, ClusterService, TransportService, IndicesService, NodeEnvironment, ActionFilters) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData - Class in org.elasticsearch.indices.store
 
TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData - Class in org.elasticsearch.indices.store
 
TransportNodesListShardStoreMetaData.StoreFilesMetaData - Class in org.elasticsearch.indices.store
 
TransportNodesOperationAction<Request extends NodesOperationRequest,Response extends NodesOperationResponse,NodeRequest extends NodeOperationRequest,NodeResponse extends NodeOperationResponse> - Class in org.elasticsearch.action.support.nodes
 
TransportNodesOperationAction(Settings, String, ClusterName, ThreadPool, ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
TransportNodesRestartAction - Class in org.elasticsearch.action.admin.cluster.node.restart
 
TransportNodesRestartAction(Settings, ClusterName, ThreadPool, ClusterService, TransportService, Node, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
TransportNodesRestartAction.NodeRestartRequest - Class in org.elasticsearch.action.admin.cluster.node.restart
 
TransportNodesShutdownAction - Class in org.elasticsearch.action.admin.cluster.node.shutdown
 
TransportNodesShutdownAction(Settings, TransportService, ClusterService, ThreadPool, Node, ClusterName, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
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, SnapshotsService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
 
TransportNodesSnapshotsStatus.NodeSnapshotStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
 
TransportNodesSnapshotsStatus.NodesSnapshotStatus - 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) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
TransportOpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
Open index action
TransportOpenIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexStateService, NodeSettingsService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
 
TransportOptimizeAction - Class in org.elasticsearch.action.admin.indices.optimize
Optimize index/indices action.
TransportOptimizeAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
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.TransportShardReplicationOperationAction
 
transportOptions() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
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) - 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) - Constructor for class org.elasticsearch.action.percolate.TransportPercolateAction
 
TransportPutIndexedScriptAction - Class in org.elasticsearch.action.indexedscripts.put
Performs the put indexed script operation.
TransportPutIndexedScriptAction(Settings, ThreadPool, ScriptService, TransportService, ActionFilters) - 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) - 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) - 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) - 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) - 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) - 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, IndicesService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
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> - Interface in org.elasticsearch.transport
 
TransportRequestOptions - Class in org.elasticsearch.transport
 
TransportRequestOptions() - Constructor for class org.elasticsearch.transport.TransportRequestOptions
 
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() - Constructor for class org.elasticsearch.transport.TransportResponseOptions
 
TransportRestoreSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
Transport action for restore snapshot operation
TransportRestoreSnapshotAction(Settings, TransportService, ClusterService, ThreadPool, RestoreService, ActionFilters) - 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, TransportService, ClusterService, TransportSearchDfsQueryThenFetchAction, TransportSearchQueryThenFetchAction, TransportSearchDfsQueryAndFetchAction, TransportSearchQueryAndFetchAction, TransportSearchScanAction, TransportSearchCountAction, ActionFilters) - Constructor for class org.elasticsearch.action.search.TransportSearchAction
 
TransportSearchCountAction - Class in org.elasticsearch.action.search.type
 
TransportSearchCountAction(Settings, ThreadPool, ClusterService, SearchServiceTransportAction, SearchPhaseController, ActionFilters) - Constructor for class org.elasticsearch.action.search.type.TransportSearchCountAction
 
TransportSearchDfsQueryAndFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchDfsQueryAndFetchAction(Settings, ThreadPool, ClusterService, SearchServiceTransportAction, SearchPhaseController, ActionFilters) - Constructor for class org.elasticsearch.action.search.type.TransportSearchDfsQueryAndFetchAction
 
TransportSearchDfsQueryThenFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchDfsQueryThenFetchAction(Settings, ThreadPool, ClusterService, SearchServiceTransportAction, SearchPhaseController, ActionFilters) - Constructor for class org.elasticsearch.action.search.type.TransportSearchDfsQueryThenFetchAction
 
TransportSearchHelper - Class in org.elasticsearch.action.search.type
 
TransportSearchModule - Class in org.elasticsearch.search
 
TransportSearchModule() - Constructor for class org.elasticsearch.search.TransportSearchModule
 
TransportSearchQueryAndFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchQueryAndFetchAction(Settings, ThreadPool, ClusterService, SearchServiceTransportAction, SearchPhaseController, ActionFilters) - Constructor for class org.elasticsearch.action.search.type.TransportSearchQueryAndFetchAction
 
TransportSearchQueryThenFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchQueryThenFetchAction(Settings, ThreadPool, ClusterService, SearchServiceTransportAction, SearchPhaseController, ActionFilters) - Constructor for class org.elasticsearch.action.search.type.TransportSearchQueryThenFetchAction
 
TransportSearchScanAction - Class in org.elasticsearch.action.search.type
 
TransportSearchScanAction(Settings, ThreadPool, ClusterService, SearchServiceTransportAction, SearchPhaseController, ActionFilters) - Constructor for class org.elasticsearch.action.search.type.TransportSearchScanAction
 
TransportSearchScrollAction - Class in org.elasticsearch.action.search
 
TransportSearchScrollAction(Settings, ThreadPool, TransportService, TransportSearchScrollQueryThenFetchAction, TransportSearchScrollQueryAndFetchAction, TransportSearchScrollScanAction, ActionFilters) - Constructor for class org.elasticsearch.action.search.TransportSearchScrollAction
 
TransportSearchScrollQueryAndFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchScrollQueryAndFetchAction(Settings, ClusterService, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchScrollQueryAndFetchAction
 
TransportSearchScrollQueryThenFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchScrollQueryThenFetchAction(Settings, ClusterService, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchScrollQueryThenFetchAction
 
TransportSearchScrollScanAction - Class in org.elasticsearch.action.search.type
 
TransportSearchScrollScanAction(Settings, ClusterService, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchScrollScanAction
 
TransportSearchTypeAction - Class in org.elasticsearch.action.search.type
 
TransportSearchTypeAction(Settings, ThreadPool, ClusterService, SearchServiceTransportAction, SearchPhaseController, ActionFilters) - Constructor for class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
TransportSearchTypeAction.BaseAsyncAction<FirstResult extends SearchPhaseResult> - Class in org.elasticsearch.action.search.type
 
TransportSerializationException - Exception in org.elasticsearch.transport
 
TransportSerializationException(String) - 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.TransportBroadcastOperationAction
 
transportService - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
transportService - Variable in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
transportService - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
transportService - Variable in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
transportService - Variable in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
transportService - Variable in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
transportService - Variable in class org.elasticsearch.action.TransportActionNodeProxy
 
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) - Constructor for class org.elasticsearch.action.bulk.TransportShardBulkAction
 
TransportShardDeleteAction - Class in org.elasticsearch.action.delete
 
TransportShardDeleteAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters) - Constructor for class org.elasticsearch.action.delete.TransportShardDeleteAction
 
TransportShardDeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
 
TransportShardDeleteByQueryAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ScriptService, CacheRecycler, PageCacheRecycler, BigArrays, ActionFilters) - Constructor for class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
TransportShardMultiGetAction - Class in org.elasticsearch.action.get
 
TransportShardMultiGetAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters) - Constructor for class org.elasticsearch.action.get.TransportShardMultiGetAction
 
TransportShardMultiPercolateAction - Class in org.elasticsearch.action.percolate
 
TransportShardMultiPercolateAction(Settings, ThreadPool, ClusterService, TransportService, PercolatorService, ActionFilters) - 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
 
TransportShardReplicationOperationAction<Request extends ShardReplicationOperationRequest,ReplicaRequest extends ShardReplicationOperationRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction(Settings, String, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters) - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
TransportShardReplicationOperationAction.AsyncShardOperationAction - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction.InternalRequest - Class in org.elasticsearch.action.support.replication
Internal request class that gets built on each node.
TransportShardReplicationOperationAction.PrimaryOperationRequest - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction.PrimaryResponse<Response,ReplicaRequest> - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction.ReplicaOperationRequest - Class in org.elasticsearch.action.support.replication
 
TransportShardSingleOperationAction<Request extends SingleShardOperationRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.shard
A base class for single shard read operations.
TransportShardSingleOperationAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
TransportShardSingleOperationAction.InternalRequest - Class in org.elasticsearch.action.support.single.shard
Internal request class that gets built on each node.
TransportSignificantTermsHeuristicModule - Class in org.elasticsearch.search.aggregations.bucket.significant.heuristics
 
TransportSignificantTermsHeuristicModule() - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.heuristics.TransportSignificantTermsHeuristicModule
 
TransportSingleCustomOperationAction<Request extends SingleCustomOperationRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.custom
Transport action used to send a read request to one of the shards that belong to an index.
TransportSingleCustomOperationAction(Settings, String, ThreadPool, ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
TransportSingleCustomOperationAction.InternalRequest - Class in org.elasticsearch.action.support.single.custom
Internal request class that gets built on each node.
TransportSingleCustomOperationAction.ShardSingleOperationRequest - Class in org.elasticsearch.action.support.single.custom
 
TransportSingleShardMultiTermsVectorAction - Class in org.elasticsearch.action.termvector
 
TransportSingleShardMultiTermsVectorAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters) - Constructor for class org.elasticsearch.action.termvector.TransportSingleShardMultiTermsVectorAction
 
TransportSingleShardTermVectorAction - Class in org.elasticsearch.action.termvector
Performs the get operation.
TransportSingleShardTermVectorAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters) - Constructor for class org.elasticsearch.action.termvector.TransportSingleShardTermVectorAction
 
TransportSnapshotsStatusAction - Class in org.elasticsearch.action.admin.cluster.snapshots.status
 
TransportSnapshotsStatusAction(Settings, TransportService, ClusterService, ThreadPool, SnapshotsService, TransportNodesSnapshotsStatus, ActionFilters) - 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) - Constructor for class org.elasticsearch.action.suggest.TransportSuggestAction
 
TransportTypesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.types
Types exists transport action.
TransportTypesExistsAction(Settings, TransportService, ClusterService, ThreadPool, ActionFilters) - 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, IndicesService) - 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) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
 
TransportValidateQueryAction - Class in org.elasticsearch.action.admin.indices.validate.query
 
TransportValidateQueryAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ScriptService, CacheRecycler, PageCacheRecycler, BigArrays, ActionFilters) - 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) - 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
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.MultiFields
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
traverse(ObjectMapperListener) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
traverse(ObjectMapperListener) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
traverse(ObjectMapperListener) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
traverse(ObjectMapperListener) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
traverse(FieldMapperListener) - Method in interface org.elasticsearch.index.mapper.Mapper
 
traverse(ObjectMapperListener) - Method in interface org.elasticsearch.index.mapper.Mapper
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
traverse(ObjectMapperListener) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
tree(String) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
TREE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
 
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(int) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
treeLevelsByDistance(double) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
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 occurences 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, Settings, 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) - Constructor for exception org.elasticsearch.index.translog.TruncatedTranslogException
 
TruncatedTranslogException(String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TruncatedTranslogException
 
TruncateTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
TruncateTokenFilterFactory(Index, Settings, 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
 
tryMlockall() - Static method in class org.elasticsearch.common.jna.Natives
 
ttf() - Method in class org.elasticsearch.search.lookup.IndexFieldTerm
 
ttl(Long) - Method in class org.elasticsearch.action.index.IndexRequest
Sets the relative ttl value.
ttl() - Method in class org.elasticsearch.action.index.IndexRequest
 
ttl - Variable in class org.elasticsearch.common.network.MulticastChannel.Config
 
ttl() - Method in exception org.elasticsearch.index.AlreadyExpiredException
 
ttl() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
ttl() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
ttl() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
ttl() - 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(Settings) - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
TTLFieldMapper(FieldType, EnabledAttributeMapper, long, Explicit<Boolean>, Explicit<Boolean>, PostingsFormatProvider, DocValuesFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
TTLFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
TTLFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
TTLFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
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, Settings, 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 class org.elasticsearch.action.delete.ShardDeleteRequest
 
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() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The type of document to load from which the "like" query will run with.
type(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The type of document to load from which the "like" query will execute with.
type() - Method in exception org.elasticsearch.action.RoutingMissingException
 
type(String) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
Sets the type of document to get the term vector for.
type() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
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 class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
type() - Method in interface org.elasticsearch.cluster.ClusterState.Custom.Factory
 
type() - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom.Factory
 
type() - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom
 
type() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
 
type() - Method in class org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
type() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData.Factory
TYPE - Static variable in class org.elasticsearch.cluster.metadata.RepositoriesMetaData
 
type() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
Returns repository type
type() - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Factory
TYPE - Static variable in class org.elasticsearch.cluster.metadata.RestoreMetaData
 
type() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Factory
 
TYPE - Static variable in class org.elasticsearch.cluster.metadata.SnapshotMetaData
 
type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
 
type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
 
type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
Get the Decision.Type of this decision
type() - Method in enum org.elasticsearch.cluster.routing.operation.plain.Preference
 
type() - Method in interface org.elasticsearch.common.compress.Compressor
 
TYPE - Static variable in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
type() - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
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() - Method in interface org.elasticsearch.gateway.Gateway
 
type() - Method in class org.elasticsearch.gateway.local.LocalGateway
 
TYPE - Static variable in class org.elasticsearch.gateway.none.NoneGateway
 
type() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
type() - Method in exception org.elasticsearch.index.AlreadyExpiredException
 
type() - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
type() - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
type() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
TYPE - Static variable in class org.elasticsearch.index.deletionpolicy.DeletionPolicyModule.DeletionPolicySettings
 
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() - Method in class org.elasticsearch.index.gateway.CommitPoint
 
type() - Method in interface org.elasticsearch.index.gateway.IndexGateway
 
type() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
 
type() - Method in class org.elasticsearch.index.gateway.local.LocalIndexGateway
 
type() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
type() - Method in class org.elasticsearch.index.gateway.none.NoneIndexGateway
 
type() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
TYPE - Static variable in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.CustomBinaryDocValuesField
 
TYPE - Static variable in class org.elasticsearch.index.mapper.core.CompletionFieldMapper.Fields
 
TYPE - Static variable in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericDocValuesField
 
TYPE - Static variable in class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericDocValuesField
 
TYPE - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomLongNumericDocValuesField
 
TYPE - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericDocValuesField
 
type() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.CustomGeoPointDocValuesField
 
type(String) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
 
type() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
type() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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.GeoBoundingBoxFilterBuilder
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(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.translog.Translog.Create
 
type() - Method in class org.elasticsearch.index.translog.Translog.Index
 
TYPE - Static variable in class org.elasticsearch.index.translog.TranslogModule.TranslogSettings
 
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(String) - Method in class org.elasticsearch.repositories.RepositoryTypesRegistry
Returns repository module class for the given type
TYPE - Static variable in class org.elasticsearch.repositories.uri.URLRepository
 
type() - Method in class org.elasticsearch.river.RiverName
 
type(String) - Method in class org.elasticsearch.river.RiversTypesRegistry
 
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.InternalDateHistogram
 
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 - 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 - 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 - 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.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 - 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.InternalPercentileRanks
 
type() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentileRanks
 
TYPE - Static variable in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
type() - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
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.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 - Static variable in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet
The type of the filter facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.filter.FilterFacet
The type of the filter facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.geodistance.GeoDistanceFacet
The type of the filter facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.histogram.HistogramFacet
The type of the filter facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.query.QueryFacet
The type of the filter facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.range.RangeFacet
The type of the filter facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The type of the filter facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.terms.TermsFacet
The type of the filter facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet
 
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() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
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.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
TYPE_NAME - Static variable in class org.elasticsearch.percolator.PercolatorService
 
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() - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
TypeFieldMapper(String, String) - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
TypeFieldMapper(String, String, float, FieldType, PostingsFormatProvider, DocValuesFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
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
 
typeFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter based on doc/mapping type.
TypeFilterBuilder - Class in org.elasticsearch.index.query
 
TypeFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.TypeFilterBuilder
 
TypeFilterParser - Class in org.elasticsearch.index.query
 
TypeFilterParser() - Constructor for class org.elasticsearch.index.query.TypeFilterParser
 
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(Index, String[], String) - Constructor for exception org.elasticsearch.indices.TypeMissingException
 
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.Murmur3FieldMapper.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.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.AnalyzerMapper.TypeParser
 
TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper.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.SizeFieldMapper.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
 
typePrefixAsBytes(BytesRef) - Static method in class org.elasticsearch.index.mapper.Uid
 
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.delete.DeleteMappingClusterStateUpdateRequest
Returns the type to be removed
types(String[]) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingClusterStateUpdateRequest
Sets the type to be removed
types() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
The mapping types.
types(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
The type of the mappings to remove.
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.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
The types of documents the query will run against.
types(String...) - Method in class org.elasticsearch.action.count.CountRequest
The types of documents the query will run against.
types() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The types of documents the query will run against.
types(String...) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The types of documents the query will run against.
types() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
types() - Method in class org.elasticsearch.action.exists.ExistsRequest
The types of documents the query will run against.
types(String...) - Method in class org.elasticsearch.action.exists.ExistsRequest
The types of documents the query will run against.
types() - Method in class org.elasticsearch.action.search.SearchRequest
The document types to execute the search against.
types(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.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
 
types() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
types() - Method in class org.elasticsearch.percolator.PercolateContext
 
types(String[]) - Method in class org.elasticsearch.percolator.PercolateContext
 
types() - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
types() - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
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.facet.datehistogram.DateHistogramFacetParser
 
types() - Method in interface org.elasticsearch.search.facet.FacetParser
The type of the facet, for example, terms.
types() - Method in class org.elasticsearch.search.facet.filter.FilterFacetParser
 
types() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetParser
 
types() - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetParser
 
types() - Method in class org.elasticsearch.search.facet.query.QueryFacetParser
 
types() - Method in class org.elasticsearch.search.facet.range.RangeFacetParser
 
types() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetParser
 
types() - Method in class org.elasticsearch.search.facet.terms.TermsFacetParser
 
types() - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetParser
 
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
typesExists(TypesExistsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
typesExists(TypesExistsRequest, ActionListener<TypesExistsResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
TypesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.types
 
TypesExistsRequest - Class in org.elasticsearch.action.admin.indices.exists.types
 
TypesExistsRequest(String[], String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
 
TypesExistsRequestBuilder - Class in org.elasticsearch.action.admin.indices.exists.types
A builder for TypesExistsRequest.
TypesExistsRequestBuilder(IndicesAdminClient, 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
 

U

UAX29URLEmailTokenizerFactory - Class in org.elasticsearch.index.analysis
 
UAX29URLEmailTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.UAX29URLEmailTokenizerFactory
 
uid() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
uid() - Method in class org.elasticsearch.index.engine.Engine.Get
 
uid() - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
uid - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
uid() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
 
uid() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
uid() - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
 
uid(Field) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
Really, just the uid mapper should set this.
uid() - Method in class org.elasticsearch.index.mapper.ParseContext
 
uid(Field) - Method in class org.elasticsearch.index.mapper.ParseContext
Really, just the uid mapper should set this.
uid() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
Uid - Class in org.elasticsearch.index.mapper
 
Uid(String, String) - Constructor for class org.elasticsearch.index.mapper.Uid
 
uid() - Method in class org.elasticsearch.index.translog.Translog.Delete
 
UidAndRoutingFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
 
UidAndRoutingFieldsVisitor() - Constructor for class org.elasticsearch.index.fieldvisitor.UidAndRoutingFieldsVisitor
 
UidAndSourceFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
 
UidAndSourceFieldsVisitor() - Constructor for class org.elasticsearch.index.fieldvisitor.UidAndSourceFieldsVisitor
 
UidFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
UidFieldMapper() - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
UidFieldMapper(String) - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
UidFieldMapper(String, String, Boolean, PostingsFormatProvider, DocValuesFormatProvider, Settings, Settings) - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
UidFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
UidFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
UidFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
uidMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
ulp(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
ulp(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
unassigned() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
unassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
unassigned() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
The shard is unassigned (not allocated to any node).
UnassignedShards(RoutingNodes.UnassignedShards) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
 
UnassignedShards() - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
 
UnavailableShardsException - Exception in org.elasticsearch.action
 
UnavailableShardsException(ShardId, String) - Constructor for exception org.elasticsearch.action.UnavailableShardsException
 
UnboxedMathUtils - Class in org.elasticsearch.common.math
 
UnboxedMathUtils() - Constructor for class org.elasticsearch.common.math.UnboxedMathUtils
 
UncategorizedExecutionException - Exception in org.elasticsearch.common.util.concurrent
 
UncategorizedExecutionException(String) - Constructor for exception org.elasticsearch.common.util.concurrent.UncategorizedExecutionException
 
UncategorizedExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.common.util.concurrent.UncategorizedExecutionException
 
uncompress(IndexInput, byte[]) - Method in class org.elasticsearch.common.compress.CompressedIndexInput
Deprecated.
Uncompress the data into the out array, returning the size uncompressed
uncompress(StreamInput, byte[]) - Method in class org.elasticsearch.common.compress.CompressedStreamInput
Uncompress the data into the out array, returning the size uncompressed
uncompress(byte[], int, int) - Method in interface org.elasticsearch.common.compress.Compressor
Uncompress the provided data, data can be detected as compressed using Compressor.isCompressed(byte[], int, int).
uncompress(IndexInput, byte[]) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
Deprecated.
 
uncompress(StreamInput, byte[]) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedStreamInput
 
uncompress(byte[], int, int) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
uncompressed - Variable in class org.elasticsearch.common.compress.CompressedIndexInput
Deprecated.
 
uncompressed - Variable in class org.elasticsearch.common.compress.CompressedStreamInput
 
uncompressed - Variable in class org.elasticsearch.common.compress.CompressedStreamOutput
 
uncompressed() - Method in class org.elasticsearch.common.compress.CompressedString
 
uncompressedLength - Variable in class org.elasticsearch.common.compress.CompressedIndexInput
Deprecated.
 
uncompressedLength - Variable in class org.elasticsearch.common.compress.CompressedStreamOutput
 
uncompressIfNeeded(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
Uncompress the provided data, data can be detected as compressed using CompressorFactory.isCompressed(byte[], int, int).
underlyingBuffer() - Method in class org.elasticsearch.common.io.stream.BytesStreamInput
 
underscore() - Method in class org.elasticsearch.common.xcontent.XContentBuilderString
 
UnicastHostsProvider - Interface in org.elasticsearch.discovery.zen.ping.unicast
A pluggable provider of the list of unicast hosts to use for unicast discovery.
UnicastZenPing - Class in org.elasticsearch.discovery.zen.ping.unicast
 
UnicastZenPing(Settings, ThreadPool, TransportService, ClusterName, Version, ElectMasterService, Set<UnicastHostsProvider>) - Constructor for class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
UNICODE_CHARACTER_CLASS - Static variable in class org.elasticsearch.common.regex.Regex
This Regex / Pattern flag is supported from Java 7 on.
unique() - Method in enum org.elasticsearch.search.aggregations.support.ValuesSource.MetaData.Uniqueness
 
uniqueAddressTypeId() - Method in class org.elasticsearch.common.transport.DummyTransportAddress
 
uniqueAddressTypeId() - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
uniqueAddressTypeId() - Method in class org.elasticsearch.common.transport.LocalTransportAddress
 
uniqueAddressTypeId() - Method in interface org.elasticsearch.common.transport.TransportAddress
 
UniqueAnnotations - Class in org.elasticsearch.common.inject.internal
 
uniqueness(ValuesSource.MetaData.Uniqueness) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData.Builder
 
uniqueness() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData
 
UniqueTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
A token filter that generates unique tokens.
UniqueTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.UniqueTokenFilter
 
UniqueTokenFilter(TokenStream, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.UniqueTokenFilter
 
UniqueTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
UniqueTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.UniqueTokenFilterFactory
 
unit - Variable in class org.elasticsearch.common.geo.GeoDistance.FixedSourceDistanceBase
 
unit - Variable in class org.elasticsearch.common.unit.DistanceUnit.Distance
 
unit(DistanceUnit) - Method in class org.elasticsearch.search.aggregations.bucket.range.geodistance.GeoDistanceBuilder
Set the unit to use for distances, default is kilometers.
unit(DistanceUnit) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The distance unit to use.
unit(DistanceUnit) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
The distance unit to use.
UNIT_SEPARATOR - Static variable in class org.elasticsearch.search.suggest.completion.Completion090PostingsFormat.CompletionLookupProvider
 
UNKNOWN - Static variable in class org.elasticsearch.indices.recovery.RecoveryState.Index
 
UNKNOWN - Static variable in class org.elasticsearch.indices.recovery.RecoveryState.Translog
 
UNKNOWN - Static variable in class org.elasticsearch.search.aggregations.support.ValuesSource.MetaData
 
UNKNOWN_SOURCE - Static variable in class org.elasticsearch.common.inject.internal.SourceProvider
Indicates that the source is unknown.
UNKNOWN_VERSION - Static variable in class org.elasticsearch.cluster.ClusterState
 
unlock() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
 
Unmapped(String, List<RangeAggregator.Range>, boolean, ValueFormat, AggregationContext, Aggregator, InternalRange.Factory) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Unmapped
 
unmapped() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
 
unmapped(boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
 
UNMAPPED_TYPE - Static variable in class org.elasticsearch.search.sort.SortParseElement
 
UnmappedFieldExecutor - Class in org.elasticsearch.search.facet.terms.unmapped
A facet executor that only aggregates the missing count for unmapped fields and builds a terms facet over it
UnmappedFieldExecutor(int, TermsFacet.ComparatorType) - Constructor for class org.elasticsearch.search.facet.terms.unmapped.UnmappedFieldExecutor
 
unmappedFieldMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
Given a type (eg.
UnmappedSignificantTerms - Class in org.elasticsearch.search.aggregations.bucket.significant
 
UnmappedSignificantTerms(String, int, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
 
UnmappedTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
 
UnmappedTerms(String, Terms.Order, int, int, long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
 
unmappedType(String) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
Set the type to use in case the current field is not mapped in an index.
unqualify(String, char) - Static method in class org.elasticsearch.common.Strings
Unqualify a string qualified by a separator character.
unregisterRepository(RepositoriesService.UnregisterRepositoryRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
Unregisters repository in the cluster

This method can be only called on the master node.

UnregisterRepositoryRequest(String, String) - Constructor for class org.elasticsearch.repositories.RepositoriesService.UnregisterRepositoryRequest
Creates a new unregister repository request
unsafeCharArray() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Returns the underlying char array.
UNSCOPED - Static variable in class org.elasticsearch.common.inject.internal.Scoping
No scoping annotation has been applied.
unset() - Method in enum org.elasticsearch.index.mapper.internal.EnabledAttributeMapper
 
unsetIncludeInAll() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
unsetIncludeInAll() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
unsetIncludeInAll() - Method in interface org.elasticsearch.index.mapper.internal.AllFieldMapper.IncludeInAll
 
unsetIncludeInAll() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
UntargettedBinding<T> - Interface in org.elasticsearch.common.inject.spi
An untargetted binding.
UntargettedBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
 
UntargettedBindingImpl(Injector, Key<T>, Object) - Constructor for class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
 
UntargettedBindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
 
unwrap(DocIdSet) - Static method in class org.elasticsearch.common.lucene.search.ApplyAcceptedDocsFilter
 
unwrap(Throwable, Class<T>) - Static method in class org.elasticsearch.ExceptionsHelper
 
unwrap(Object) - Method in class org.elasticsearch.script.AbstractExecutableScript
 
unwrap(Object) - Method in interface org.elasticsearch.script.ExecutableScript
Unwraps a possible script value.
unwrap(Object) - Method in class org.elasticsearch.script.expression.ExpressionScriptEngineService
 
unwrap(Object) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService.GroovyScript
 
unwrap(Object) - Method in class org.elasticsearch.script.groovy.GroovyScriptEngineService
 
unwrap(Object) - Method in class org.elasticsearch.script.mustache.MustacheScriptEngineService
 
unwrap(Object) - Method in class org.elasticsearch.script.NativeScriptEngineService
 
unwrap(Object) - Method in interface org.elasticsearch.script.ScriptEngineService
 
unwrapCause() - Method in exception org.elasticsearch.ElasticsearchException
Unwraps the actual cause from the exception for cases when the exception is a ElasticsearchWrapperException.
unwrapCause(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
 
unwrapCorruption(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
 
unwrapSingleton(SortedNumericDoubleValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns a single-valued view of the SortedNumericDoubleValues, if it was previously wrapped with #singleton(NumericDocValues, Bits), or null.
unwrapSingleton(MultiGeoPointValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns a single-valued view of the MultiGeoPointValues, if it was previously wrapped with FieldData.singleton(GeoPointValues, Bits), or null.
unwrapSingleton(SortedBinaryDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns a single-valued view of the SortedBinaryDocValues, if it was previously wrapped with FieldData.singleton(BinaryDocValues, Bits), or null.
unwrapSingletonBits(SortedNumericDoubleValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns the documents with a value for the SortedNumericDoubleValues, if it was previously wrapped with FieldData.singleton(NumericDoubleValues, Bits), or null.
unwrapSingletonBits(MultiGeoPointValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns the documents with a value for the MultiGeoPointValues, if it was previously wrapped with FieldData.singleton(GeoPointValues, Bits), or null.
unwrapSingletonBits(SortedBinaryDocValues) - Static method in enum org.elasticsearch.index.fielddata.FieldData
Returns the documents with a value for the SortedBinaryDocValues, if it was previously wrapped with FieldData.singleton(BinaryDocValues, Bits), or null.
update(double) - Method in class jsr166e.DoubleMaxUpdater
Updates the maximum to be at least the given value.
update(long) - Method in class jsr166e.LongMaxUpdater
Updates the maximum to be at least the given value.
update(UpdateRequest) - Method in interface org.elasticsearch.client.Client
Updates a document based on a script.
update(UpdateRequest, ActionListener<UpdateResponse>) - Method in interface org.elasticsearch.client.Client
Updates a document based on a script.
update(UpdateRequest) - Method in class org.elasticsearch.client.support.AbstractClient
 
update(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
 
update(UpdateRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
update(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
update(long) - Method in class org.elasticsearch.common.metrics.EWMA
Update the moving average with a new value.
update(Map<String, Object>, Map<String, Object>, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
Updates the provided changes into the source.
UPDATE_RESTORE_ACTION_NAME - Static variable in class org.elasticsearch.snapshots.RestoreService
 
UPDATE_SNAPSHOT_ACTION_NAME - Static variable in class org.elasticsearch.snapshots.SnapshotsService
 
UPDATE_THREAD_NAME - Static variable in class org.elasticsearch.cluster.service.InternalClusterService
 
UpdateAction - Class in org.elasticsearch.action.update
 
updateBuffer(ByteSizeValue) - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
updateBuffer(ByteSizeValue) - Method in interface org.elasticsearch.index.translog.Translog
 
updateBufferSize(ByteSizeValue, ByteSizeValue) - Method in class org.elasticsearch.index.shard.IndexShard
 
updateBufferSize(int) - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
updateBufferSize(int) - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
updateBufferSize(int) - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
updatedSettings() - Method in class org.elasticsearch.plugins.PluginsService
 
updatedSourceAsMap() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
 
UpdateHelper - Class in org.elasticsearch.action.update
Helper for translating an update request to an index, delete request or update response.
UpdateHelper(Settings, ScriptService) - Constructor for class org.elasticsearch.action.update.UpdateHelper
 
UpdateHelper.Operation - Enum in org.elasticsearch.action.update
 
UpdateHelper.Result - Class in org.elasticsearch.action.update
 
updateIndicesStats(ActionListener<IndicesStatsResponse>) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
Retrieve the latest indices stats, calling the listener when complete
updateKeyWithNamedWildcard(String) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
 
updateMapping(String, String, String, CompressedString, long, String, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
 
updateMappingOnMaster(String, DocumentMapper, String) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
updateMappingOnMaster(String, DocumentMapper, String, MappingUpdatedAction.MappingUpdateListener) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
updateNodes(RoutingNodes) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
updateNodesAndPing(ClusterState) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
make sure that nodes in clusterState are pinged.
updateNodeStats(ActionListener<NodesStatsResponse>) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
Retrieve the latest nodes stats, calling the listener when complete
updateNumberOfReplicas(int, String...) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
updateNumberOfReplicas(int, String...) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
UpdateRequest - Class in org.elasticsearch.action.update
 
UpdateRequest() - Constructor for class org.elasticsearch.action.update.UpdateRequest
 
UpdateRequest(String, String, String) - Constructor for class org.elasticsearch.action.update.UpdateRequest
 
UpdateRequestBuilder - Class in org.elasticsearch.action.update
 
UpdateRequestBuilder(Client) - Constructor for class org.elasticsearch.action.update.UpdateRequestBuilder
 
UpdateRequestBuilder(Client, String, String, String) - Constructor for class org.elasticsearch.action.update.UpdateRequestBuilder
 
UpdateResponse - Class in org.elasticsearch.action.update
 
UpdateResponse() - Constructor for class org.elasticsearch.action.update.UpdateResponse
 
UpdateResponse(String, String, String, long, boolean) - Constructor for class org.elasticsearch.action.update.UpdateResponse
 
updateRewriteQuery(Query) - Method in class org.elasticsearch.percolator.PercolateContext
 
updateRewriteQuery(Query) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
Rewrites the query and updates it.
updateRewriteQuery(Query) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
updateRewriteQuery(Query) - Method in class org.elasticsearch.search.internal.SearchContext
Rewrites the query and updates it.
updateRewriteQuery(Query) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
updateRiverClusterState(String, RiverClusterState, ClusterState, CountDown) - Method in class org.elasticsearch.river.routing.RiversRouter
 
updateScore(SignificanceHeuristic) - Method in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
 
updateSettings(ClusterUpdateSettingsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
Updates settings in the cluster.
updateSettings(ClusterUpdateSettingsRequest, ActionListener<ClusterUpdateSettingsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
Update settings in the cluster.
updateSettings(UpdateSettingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Updates settings of one or more indices.
updateSettings(UpdateSettingsRequest, ActionListener<UpdateSettingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Updates settings of one or more indices.
updateSettings(ClusterUpdateSettingsRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
updateSettings(ClusterUpdateSettingsRequest, ActionListener<ClusterUpdateSettingsResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
updateSettings(UpdateSettingsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
updateSettings(UpdateSettingsRequest, ActionListener<UpdateSettingsResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
updateSettings(Settings, String...) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
updateSettings(UpdateSettingsClusterStateUpdateRequest, ActionListener<ClusterStateUpdateResponse>) - Method in class org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService
 
updateSettings(Settings) - Method in class org.elasticsearch.threadpool.ThreadPool
 
UpdateSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.put
 
UpdateSettingsClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.settings.put
Cluster state update request that allows to update settings for some indices
UpdateSettingsClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
 
UpdateSettingsRequest - Class in org.elasticsearch.action.admin.indices.settings.put
Request for an update index settings action
UpdateSettingsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
Constructs a new request to update settings for one or more indices
UpdateSettingsRequest(Settings, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
Constructs a new request to update settings for one or more indices
updateSettingsRequest(String...) - Static method in class org.elasticsearch.client.Requests
A request to update indices settings.
UpdateSettingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.settings.put
Builder for an update index settings request
UpdateSettingsRequestBuilder(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
 
UpdateSettingsResponse - Class in org.elasticsearch.action.admin.indices.settings.put
A response for an update index settings action
updateSourceContentType() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
 
updateStage(SnapshotStatus.Stage) - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
updateStage(IndexShardSnapshotStatus.Stage) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
Sets new snapshot stage
updateTookInMillis(long) - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
updateVersion(long, boolean) - Method in class org.elasticsearch.index.engine.Engine.Delete
 
updateVersion(long) - Method in class org.elasticsearch.index.engine.Engine.IndexingOperation
 
updateVersion(long, long) - Method in enum org.elasticsearch.index.VersionType
Returns the new version for a document, based on its current one and the specified in the request
updateVersion(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
 
UPGRADE - Static variable in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
upgrade() - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should the merge upgrade all old segments to the current index format.
upgrade(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
upgrade3xSegments(Store) - Method in class org.elasticsearch.index.engine.InternalEngine
 
upgradeLucene3xSegmentsMetadata(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
Upgrades the segments metadata of the index to match a lucene 4.x index format.
UpperCaseTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
UpperCaseTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.UpperCaseTokenFilterFactory
 
upsert(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the index request to be used if the document does not exists.
upsert(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc source of the update request to be used when the document does not exists.
upsert(Map) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc source of the update request to be used when the document does not exists.
upsert(Map, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc source of the update request to be used when the document does not exists.
upsert(String) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc source of the update request to be used when the document does not exists.
upsert(byte[]) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc source of the update request to be used when the document does not exists.
upsert(byte[], int, int) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc source of the update request to be used when the document does not exists.
upsert(Object...) - Method in class org.elasticsearch.action.update.UpdateRequest
Sets the doc source of the update request to be used when the document does not exists.
upsertRequest() - Method in class org.elasticsearch.action.update.UpdateRequest
 
uptime() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
uptime() - Method in class org.elasticsearch.monitor.os.OsStats
 
URGENT - Static variable in class org.elasticsearch.common.Priority
 
uri() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
uri() - Method in class org.elasticsearch.rest.RestRequest
The uri of the rest request, with the query string.
url() - Method in class org.elasticsearch.common.blobstore.url.URLBlobContainer
Returns URL for this container
URLBlobContainer - Class in org.elasticsearch.common.blobstore.url
URL blob implementation of BlobContainer
URLBlobContainer(URLBlobStore, BlobPath, URL) - Constructor for class org.elasticsearch.common.blobstore.url.URLBlobContainer
Constructs new URLBlobContainer
URLBlobStore - Class in org.elasticsearch.common.blobstore.url
Read-only URL-based blob store
URLBlobStore(Settings, URL) - Constructor for class org.elasticsearch.common.blobstore.url.URLBlobStore
Constructs new read-only URL-based blob store

The following settings are supported buffer_size - size of the read buffer, defaults to 100KB

URLIndexShardRepository - Class in org.elasticsearch.repositories.uri
 
URLRepository - Class in org.elasticsearch.repositories.uri
Read-only URL-based implementation of the BlobStoreRepository

This repository supports the following settings urlURL to the root of repository.

URLRepository(RepositoryName, RepositorySettings, IndexShardRepository) - Constructor for class org.elasticsearch.repositories.uri.URLRepository
Constructs new read-only URL-based repository
URLRepositoryModule - Class in org.elasticsearch.repositories.uri
URL repository module
URLRepositoryModule() - Constructor for class org.elasticsearch.repositories.uri.URLRepositoryModule
 
useCompoundFile(SegmentInfos, SegmentCommitInfo, IndexWriter) - Method in class org.elasticsearch.index.merge.policy.ElasticsearchMergePolicy
 
used(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
 
used() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
used() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
used() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
used() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
 
useDisMax() - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
useDisMax(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserSettings
 
useDisMax(boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
Deprecated.
use a tieBreaker of 1.0f to disable "dis-max" query or select the appropriate MultiMatchQueryBuilder.Type
useDisMax(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
When more than one field is used with the query string, should queries be combined using dis max, or boolean query.
usedPercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
useExplicitFieldOrder(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
Send the fields to be highlighted using a syntax that is specific about the order in which they should be highlighted.
useOrSupress(T, T) - Static method in class org.elasticsearch.ExceptionsHelper
 
usePrettyPrint() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
usePrettyPrint() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
usePrintLineFeedAtEnd() - Method in class org.elasticsearch.common.xcontent.cbor.CborXContentGenerator
 
usePrintLineFeedAtEnd() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
usePrintLineFeedAtEnd() - Method in class org.elasticsearch.common.xcontent.smile.SmileXContentGenerator
 
usePrintLineFeedAtEnd() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
usePrintLineFeedAtEnd() - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContentGenerator
 
user() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
user() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu user time.
useRandomAccess(Bits, int) - Method in class org.elasticsearch.common.lucene.search.XFilteredQuery.CustomRandomAccessFilterStrategy
Expert: decides if a filter should be executed as "random-access" or not.
userInput - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
 
useShadowEngine() - Method in class org.elasticsearch.index.shard.IndexShardModule
Return true if a shadow engine should be used
useSlowScroll - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
useSlowScroll() - Method in class org.elasticsearch.percolator.PercolateContext
 
useSlowScroll(boolean) - Method in class org.elasticsearch.percolator.PercolateContext
 
useSlowScroll() - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
useSlowScroll(boolean) - Method in class org.elasticsearch.search.internal.DefaultSearchContext
 
useSlowScroll() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
useSlowScroll(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
 
useSlowScroll() - Method in class org.elasticsearch.search.internal.SearchContext
 
useSlowScroll(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
 
useSlowScroll() - Method in class org.elasticsearch.search.internal.ShardSearchLocalRequest
 
useSlowScroll() - Method in interface org.elasticsearch.search.internal.ShardSearchRequest
This setting is internal and will be enabled when at least one node is on versions 1.0.x and 1.1.x to enable scrolling that those versions support.
useSlowScroll() - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 
useSlowScroll(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
 
useSortedNumericDocValues - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper
True if index version is 1.4+
useTermQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
useTermQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
useTermQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Use the field query created here when matching on numbers.
useTermQueryWithQueryString() - Method in interface org.elasticsearch.index.mapper.FieldMapper
Should the field query FieldMapper.termQuery(Object, org.elasticsearch.index.query.QueryParseContext) be used when detecting this field in query string.
useTermQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
useTermQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
useTermQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
We don't need to analyzer the text, and we need to convert it to UID...
useTermQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
utf8Bytes() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
utf8Bytes() - Method in interface org.elasticsearch.common.xcontent.XContentParser
Returns a BytesRef holding UTF-8 bytes.
utf8BytesOrNull() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
utf8BytesOrNull() - Method in interface org.elasticsearch.common.xcontent.XContentParser
Returns a BytesRef holding UTF-8 bytes or null if a null value is XContentParser.Token.VALUE_NULL.
utf8Field(String, BytesRef) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
Writes the binary content of the given BytesRef as UTF-8 bytes Use XContentParser.utf8Bytes() to read the value back
utf8Field(XContentBuilderString, BytesRef) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
Writes the binary content of the given BytesRef as UTF-8 bytes Use XContentParser.utf8Bytes() to read the value back
UTF8SortedAsUnicodeComparator - Class in org.elasticsearch.common.text
 
utf8SortedAsUnicodeSortOrder - Static variable in class org.elasticsearch.common.text.UTF8SortedAsUnicodeComparator
 
UTF8StreamWriter - Class in org.elasticsearch.common.io
 
UTF8StreamWriter() - Constructor for class org.elasticsearch.common.io.UTF8StreamWriter
Creates a UTF-8 writer having a byte buffer of moderate capacity (2048).
UTF8StreamWriter(int) - Constructor for class org.elasticsearch.common.io.UTF8StreamWriter
Creates a UTF-8 writer having a byte buffer of specified capacity.
UTF_8 - Static variable in class org.apache.lucene.util.XIOUtils
UTF-8 charset string.
uuid() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
uuid() - Method in class org.elasticsearch.cluster.metadata.MetaData
 

V

v() - Method in class org.elasticsearch.common.recycler.NoneRecycler.NV
 
v() - Method in interface org.elasticsearch.common.recycler.Recycler.V
Reference to the value.
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_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
 
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.shutdown.NodesShutdownRequest
 
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.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.delete.DeleteMappingRequest
 
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.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.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.count.CountRequest
 
validate() - Method in class org.elasticsearch.action.delete.DeleteRequest
 
validate() - Method in class org.elasticsearch.action.delete.ShardDeleteRequest
 
validate() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
validate() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
validate() - Method in class org.elasticsearch.action.exists.ExistsRequest
 
validate() - Method in class org.elasticsearch.action.explain.ExplainRequest
 
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.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.mlt.MoreLikeThisRequest
 
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.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.BroadcastOperationRequest
 
validate() - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
validate() - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
validate() - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
validate() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
validate() - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
validate() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
validate() - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
validate() - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
validate() - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
validate() - Method in class org.elasticsearch.action.update.UpdateRequest
 
validate() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
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) - 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(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.OrderPath
Validates this path over the given aggregator as a point of reference.
VALIDATE_LAT - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
VALIDATE_LON - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
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
Validates an alias filter by parsing it using the provided IndexQueryParserService
validateAliasFilter(String, byte[], IndexQueryParserService) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
Validates an alias filter by parsing it using the provided IndexQueryParserService
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) - 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
 
validateMultiPointNode(ShapeBuilder.CoordinateNode) - Static method in enum org.elasticsearch.common.geo.builders.ShapeBuilder.GeoShapeType
 
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.
validateQuery(ValidateQueryRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
validateQuery(ValidateQueryRequest, ActionListener<ValidateQueryResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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(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(IndicesAdminClient) - 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.action.ActionRequestValidationException
 
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) - 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.health.ClusterHealthStatus
 
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.status.GatewayRecoveryStatus.Stage
Deprecated.
 
value() - Method in enum org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus.Stage
Deprecated.
 
value() - Method in enum org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus.Stage
Deprecated.
 
value() - Method in class org.elasticsearch.cluster.ClusterName
 
value() - Method in enum org.elasticsearch.cluster.metadata.AliasAction.Type
 
value() - Method in enum org.elasticsearch.cluster.metadata.RestoreMetaData.State
Returns state code
value() - Method in enum org.elasticsearch.cluster.metadata.SnapshotMetaData.State
 
value() - Method in enum org.elasticsearch.cluster.routing.ShardRoutingState
Byte value of this ShardRoutingState
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() - Method in class org.elasticsearch.common.unit.Percent
 
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
Writes the binary content of the given BytesRef Use XContentParser.binaryValue() to read the value back
value(BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
Writes the binary content of the given BytesReference Use XContentParser.binaryValue() to read the value back
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() - Method in class org.elasticsearch.index.cache.filter.support.FilterCacheValue
 
Value(FixedBitSet, ShardId) - Constructor for class org.elasticsearch.index.cache.fixedbitset.FixedBitSetFilterCache.Value
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.CompletionFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
value() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.ValueAndBoost
Value of string field.
value(Object) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the actual value of the field.
value(Object) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.FieldNamesFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
value(Object) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
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.query.IndicesQueryCache.Key
 
Value(BytesReference, long) - Constructor for class org.elasticsearch.indices.cache.query.IndicesQueryCache.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.InternalPercentileRanks
 
value(double) - Method in class org.elasticsearch.search.aggregations.metrics.percentiles.InternalPercentiles
 
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.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
 
VALUE_SCRIPT_FILE - Static variable in class org.elasticsearch.script.ScriptService
 
VALUE_SCRIPT_ID - Static variable in class org.elasticsearch.script.ScriptService
 
VALUE_SCRIPT_INLINE - Static variable in class org.elasticsearch.script.ScriptService
 
ValueAggregator() - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetExecutor.DateHistogramProc.ValueAggregator
 
ValueAggregator() - Constructor for class org.elasticsearch.search.facet.histogram.ValueHistogramFacetExecutor.HistogramProc.ValueAggregator
 
ValueAggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetExecutor.Aggregator.ValueAggregator
 
ValueAggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetExecutor.Aggregator.ValueAggregator
 
ValueAggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetExecutor.Aggregator.ValueAggregator
 
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
 
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, long, ValuesSource, ValueFormatter, AggregationContext, Aggregator) - 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
Builder for the ValueCount aggregation.
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
 
ValueDateHistogramFacetExecutor - Class in org.elasticsearch.search.facet.datehistogram
A histogram facet collector that uses different fields for the key and the value.
ValueDateHistogramFacetExecutor(IndexNumericFieldData, IndexNumericFieldData, Rounding, DateHistogramFacet.ComparatorType, CacheRecycler) - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetExecutor
 
ValueDateHistogramFacetExecutor.DateHistogramProc - Class in org.elasticsearch.search.facet.datehistogram
 
ValueDateHistogramFacetExecutor.DateHistogramProc.ValueAggregator - Class in org.elasticsearch.search.facet.datehistogram
 
valueField(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
The field name to use as the value of the hit to compute data based on values within the interval (for example, total).
valueField(String) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
A custom value field (numeric) that will be used to provide aggregated data for each facet (for example, total).
valueField(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
The field name to use as the value of the hit to compute data based on values within the interval (for example, total).
valueField(String) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
The field name to use as the value of the hit to compute data based on values within the interval (for example, total).
valueField(String) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
 
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.PrePostRounding
 
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.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.AbstractFieldMapper
 
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
Dates should return as a string.
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Override the default behavior (to return the string, and return the actual Number instance).
valueForSearch(Object) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the value that will be used as a result for search.
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
Override the default behavior to return a timestamp
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
valueForSearch(long) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
IPs should return as a string.
ValueGeoDistanceFacetExecutor - Class in org.elasticsearch.search.facet.geodistance
 
ValueGeoDistanceFacetExecutor(IndexGeoPointFieldData, double, double, DistanceUnit, GeoDistance, GeoDistanceFacet.Entry[], SearchContext, IndexNumericFieldData) - Constructor for class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetExecutor
 
ValueGeoDistanceFacetExecutor.Aggregator - Class in org.elasticsearch.search.facet.geodistance
 
ValueHistogramFacetExecutor - Class in org.elasticsearch.search.facet.histogram
A histogram facet collector that uses different fields for the key and the value.
ValueHistogramFacetExecutor(IndexNumericFieldData, IndexNumericFieldData, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.ValueHistogramFacetExecutor
 
ValueHistogramFacetExecutor.HistogramProc - Class in org.elasticsearch.search.facet.histogram
 
ValueHistogramFacetExecutor.HistogramProc.ValueAggregator - Class in org.elasticsearch.search.facet.histogram
 
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.health.ClusterHealthStatus
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.stats.CommonStatsFlags.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus.Stage
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus.Stage
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus.Stage
Deprecated.
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.support.replication.ReplicationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.action.termvector.TermVectorRequest.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.CacheRecycler.Type
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.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.metadata.RestoreMetaData.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.cluster.metadata.SnapshotMetaData.State
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.routing.allocation.allocator.BalancedShardsAllocator.Operation
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.operation.plain.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.common.breaker.CircuitBreaker.Name
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.collect.Iterators2
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.network.NetworkUtils.StackType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.common.ParseField.Flag
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.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.gateway.CommitPoint.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.gateway.SnapshotStatus.Stage
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.FieldMapper.Loading
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.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.IndexShardState
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.fs.FsTranslogFile.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.translog.Translog.Operation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.VersionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.indices.analysis.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.ScriptService.ScriptType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.aggregations.Aggregator.BucketAggregationMode
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.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.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.support.ValuesSource.MetaData.Uniqueness
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.facet.datehistogram.DateHistogramFacet.ComparatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.facet.FacetBuilder.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.facet.FacetExecutor.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.facet.histogram.HistogramFacet.ComparatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.facet.terms.TermsFacet.ComparatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.facet.termsstats.TermsStatsFacet.ComparatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.internal.ContextIndexSearcher.Stage
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.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.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.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.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.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.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.admin.indices.status.GatewayRecoveryStatus.Stage
Deprecated.
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.status.GatewaySnapshotStatus.Stage
Deprecated.
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.status.PeerRecoveryStatus.Stage
Deprecated.
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.support.replication.ReplicationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.action.termvector.TermVectorRequest.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.CacheRecycler.Type
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.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.metadata.RestoreMetaData.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.SnapshotMetaData.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.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.routing.allocation.allocator.BalancedShardsAllocator.Operation
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.operation.plain.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.common.breaker.CircuitBreaker.Name
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.ImmutableOpenLongMap.Builder
 
values() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
 
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.collect.Iterators2
Returns an array containing the constants of this enum type, in the order they are declared.
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 enum org.elasticsearch.common.network.NetworkUtils.StackType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.common.ParseField.Flag
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.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.gateway.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.gateway.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.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.FieldMapper.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.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.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
 
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.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.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.fs.FsTranslogFile.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.Operation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.index.VersionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.indices.analysis.PreBuiltAnalyzers
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.indices.analysis.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.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.BucketAggregationMode
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.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.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.support.ValuesSource.MetaData.Uniqueness
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.aggregations.support.ValueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.ComparatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.facet.FacetBuilder.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.facet.FacetExecutor.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.facet.histogram.HistogramFacet.ComparatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.facet.terms.TermsFacet.ComparatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.facet.termsstats.TermsStatsFacet.ComparatorType
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.ContextIndexSearcher.Stage
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.DocLookup
 
values() - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
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() - 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.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.
valueScript(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
 
valueScript - Variable in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetExecutor.DateHistogramProc
 
valueScript(String) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
A custom value script (result is numeric) that will be used to provide aggregated data for each facet (for example, total).
valueScript(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
 
valueScript(String) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
 
valueScript(String) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetBuilder
A value script to be executed (instead of value field) which results (numeric) will be used to compute the totals.
ValueScriptDateHistogramFacetExecutor - Class in org.elasticsearch.search.facet.datehistogram
A histogram facet collector that uses the same field as the key as well as the value.
ValueScriptDateHistogramFacetExecutor(IndexNumericFieldData, SearchScript, Rounding, DateHistogramFacet.ComparatorType, CacheRecycler) - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetExecutor
 
ValueScriptDateHistogramFacetExecutor.DateHistogramProc - Class in org.elasticsearch.search.facet.datehistogram
 
ValueScriptHistogramFacetExecutor - Class in org.elasticsearch.search.facet.histogram
A histogram facet collector that uses the same field as the key as well as the value.
ValueScriptHistogramFacetExecutor(IndexNumericFieldData, String, String, ScriptService.ScriptType, Map<String, Object>, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.ValueScriptHistogramFacetExecutor
 
ValueScriptHistogramFacetExecutor.HistogramProc - Class in org.elasticsearch.search.facet.histogram
 
valuesIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
Returns a direct iterator over the keys.
valuesIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenLongMap
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.AbstractPercentilesAggregator
 
valuesSource(ValuesSourceConfig<VS>, int) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
Get a value source given its configuration and the depth of the aggregator in the aggregation tree.
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.MetaData - Class in org.elasticsearch.search.aggregations.support
 
ValuesSource.MetaData.Builder - Class in org.elasticsearch.search.aggregations.support
 
ValuesSource.MetaData.Uniqueness - Enum 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
 
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
 
vendor() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
VerboseProgress(PrintStream) - Constructor for class org.elasticsearch.common.http.client.HttpDownloadHelper.VerboseProgress
Construct a verbose progress reporter.
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, String) - 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
 
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
 
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(VerifyRepositoryRequest) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
verifyRepository(VerifyRepositoryRequest, ActionListener<VerifyRepositoryResponse>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
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(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(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequestBuilder
Constructs unregister repository request builder
VerifyRepositoryRequestBuilder(ClusterAdminClient, 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(long) - Method in class org.elasticsearch.action.delete.ShardDeleteRequest
 
version() - Method in class org.elasticsearch.action.delete.ShardDeleteRequest
 
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(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() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
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 - Variable in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
version() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
version(long) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
version() - Method in class org.elasticsearch.cluster.routing.RoutingTable
Returns the version of the RoutingTable.
version() - Method in interface 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 - Variable in class org.elasticsearch.gateway.local.state.shards.ShardStateInfo
 
version() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards
 
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.gateway.CommitPoint
 
version() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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 class org.elasticsearch.index.translog.ChecksummedTranslogStream
 
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() - 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(Version) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot.Builder
Sets version of Elasticsearch that created this snapshot
version() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreSnapshot
Returns version of Elasticsearch that was used to create this snapshot
version() - Method in class org.elasticsearch.river.cluster.RiverClusterState
 
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 interface org.elasticsearch.snapshots.Snapshot
Returns version of Elasticsearch that was used to create this snapshot
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_NOT_AVAILABLE - Static variable in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
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
 
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() - Constructor for class org.elasticsearch.index.mapper.internal.VersionFieldMapper
 
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 - 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 AtomicReaderContext, 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(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.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 occured.
visit(PrivateElements) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
Visit a collection of configuration elements for a private binder.
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
 
vmName() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
vmVendor() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
vmVersion() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
vocabluarySize - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
 
voidProviderMethod() - Method in class org.elasticsearch.common.inject.internal.Errors
 

W

waitForActiveShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
If set to true the operation should wait for the snapshot completion before returning.
waitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
Returns true if the request should wait for the snapshot completion before returning
waitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
If this parameter is set to true the operation will wait for completion of restore process before returning.
waitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
Returns wait for completion setting
waitForEvents(Priority) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForEvents() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForGreenStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForIndex(Directory, long) - Static method in class org.elasticsearch.common.lucene.Lucene
Wait for an index to exist for up to timeLimitMillis.
waitForInitialState() - Method in class org.elasticsearch.discovery.DiscoveryService
 
waitForNextChange(ClusterStateObserver.Listener) - Method in class org.elasticsearch.cluster.ClusterStateObserver
 
waitForNextChange(ClusterStateObserver.Listener, TimeValue) - Method in class org.elasticsearch.cluster.ClusterStateObserver
 
waitForNextChange(ClusterStateObserver.Listener, ClusterStateObserver.ChangePredicate) - Method in class org.elasticsearch.cluster.ClusterStateObserver
 
waitForNextChange(ClusterStateObserver.Listener, ClusterStateObserver.ChangePredicate, TimeValue) - Method in class org.elasticsearch.cluster.ClusterStateObserver
Wait for the next cluster state which satisfies changePredicate
waitForNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForNodes(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
Waits for N number of nodes.
waitForRelocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForRelocatingShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForStatus(ClusterHealthStatus) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForYellowStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitIfOngoing() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
Returns true iff a flush should block if a another flush operation is already running.
waitIfOngoing(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
if set to true the flush will block if a another flush operation is already running until the flush can be performed.
waitingIndices() - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Entry
 
warmer - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
warmer(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
warmer() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
WARMER - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
WarmerContext(ShardId, Engine.Searcher) - Constructor for class org.elasticsearch.indices.IndicesWarmer.WarmerContext
 
warmers() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
 
warmers(String[]) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequest
 
warmers() - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequest
 
warmers() - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersResponse
 
warmerService() - Method in class org.elasticsearch.index.shard.IndexShard
 
warmerStats() - Method in class org.elasticsearch.index.shard.IndexShard
 
WarmerStats - Class in org.elasticsearch.index.warmer
 
WarmerStats() - Constructor for class org.elasticsearch.index.warmer.WarmerStats
 
WarmerStats(long, long, long) - Constructor for class org.elasticsearch.index.warmer.WarmerStats
 
warmNewReaders(IndexShard, IndexMetaData, IndicesWarmer.WarmerContext, ThreadPool) - Method in class org.elasticsearch.indices.IndicesWarmer.Listener
Queue tasks to warm-up the given segments and return handles that allow to wait for termination of the execution of those tasks.
warmNewReaders(IndicesWarmer.WarmerContext) - Method in class org.elasticsearch.indices.IndicesWarmer
 
warmTopReader(IndexShard, IndexMetaData, IndicesWarmer.WarmerContext, ThreadPool) - Method in class org.elasticsearch.indices.IndicesWarmer.Listener
 
warmTopReader(IndicesWarmer.WarmerContext) - Method in class org.elasticsearch.indices.IndicesWarmer
 
warn(String, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
Logs a WARN level message.
warn(String, Throwable, Object...) - Method in interface org.elasticsearch.common.logging.ESLogger
Logs a WARN level message.
warn(String, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
 
warn(String, Throwable, Object...) - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
 
warn(String) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
warn(String, Throwable) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
watcher() - Method in class org.elasticsearch.watcher.WatcherHandle
 
WatcherHandle<W extends ResourceWatcher> - Class in org.elasticsearch.watcher
 
WEEK - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
weeks(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
weigh(WeightedFilterCache.FilterCacheKey, DocIdSet) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheValueWeigher
 
weigh(IndicesFieldDataCache.Key, Accountable) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.FieldDataWeigher
 
WEIGHT - Static variable in class org.elasticsearch.cache.recycler.PageCacheRecycler
 
weight(BalancedShardsAllocator.Operation, BalancedShardsAllocator.Balancer, BalancedShardsAllocator.ModelNode, String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.WeightFunction
 
WEIGHT_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryParser
 
WeightBuilder - Class in org.elasticsearch.index.query.functionscore.weight
A query that multiplies the weight to the score.
WeightBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.weight.WeightBuilder
 
WeightedFilterCache - Class in org.elasticsearch.index.cache.filter.weighted
 
WeightedFilterCache(Index, Settings, IndicesFilterCache) - Constructor for class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
WeightedFilterCache.FilterCacheKey - Class in org.elasticsearch.index.cache.filter.weighted
 
WeightedFilterCache.FilterCacheValueWeigher - Class in org.elasticsearch.index.cache.filter.weighted
A weigher for the Guava filter cache that uses a minimum entry size
WeightFactorFunction - Class in org.elasticsearch.common.lucene.search.function
 
WeightFactorFunction(float, ScoreFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
 
WeightFactorFunction(float) - Constructor for class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
 
weightFactorFunction(float) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
 
WeightFunction(float, float, float) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.WeightFunction
 
WhitespaceAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
WhitespaceAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.WhitespaceAnalyzerProvider
 
WhitespaceTokenizerFactory - Class in org.elasticsearch.index.analysis
 
WhitespaceTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.WhitespaceTokenizerFactory
 
wildcardQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
Implements the wildcard search query.
WildcardQueryBuilder - Class in org.elasticsearch.index.query
Implements the wildcard search query.
WildcardQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.WildcardQueryBuilder
Implements the wildcard search query.
WildcardQueryParser - Class in org.elasticsearch.index.query
 
WildcardQueryParser() - Constructor for class org.elasticsearch.index.query.WildcardQueryParser
 
WildcardTypeImpl(Type[], Type[]) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
 
window() - Method in class org.elasticsearch.search.rescore.RescoreSearchContext
 
WINDOWS - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on Windows.
windowSize(int) - Method in class org.elasticsearch.search.rescore.RescoreBuilder
 
windowSize() - Method in class org.elasticsearch.search.rescore.RescoreBuilder
 
with(Module...) - Method in interface org.elasticsearch.common.inject.util.Modules.OverriddenModuleBuilder
See the EDSL example at override().
with(Iterable<? extends Module>) - Method in interface org.elasticsearch.common.inject.util.Modules.OverriddenModuleBuilder
See the EDSL example at override().
withAllDeprecated(String) - Method in class org.elasticsearch.common.ParseField
Return a new ParseField where all field names are deprecated and replaced with allReplacedWith.
withCircuitBreaking() - Method in class org.elasticsearch.common.util.BigArrays
Return a new instance of this BigArrays class with circuit breaking explicitly enabled, instead of only accounting enabled
withCompress(boolean) - Method in class org.elasticsearch.transport.TransportRequestOptions
 
withCompress(boolean) - Method in class org.elasticsearch.transport.TransportResponseOptions
 
withDeprecation(String...) - Method in class org.elasticsearch.common.ParseField
 
WithHash(String, AggregatorFactories, ValuesSource.Bytes.WithOrdinals.FieldData, long, TermsAggregator.BucketCountThresholds, IncludeExclude, AggregationContext, Aggregator, SignificantTermsAggregatorFactory) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.GlobalOrdinalsSignificantTermsAggregator.WithHash
 
WithHash(String, AggregatorFactories, ValuesSource.Bytes.WithOrdinals.FieldData, long, long, Terms.Order, TermsAggregator.BucketCountThresholds, IncludeExclude, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.WithHash
 
withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
 
WithOrdinals() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
 
withPartialValue(Object) - Method in exception org.elasticsearch.common.inject.ConfigurationException
Returns a copy of this configuration exception with the specified partial value.
WithRestHeaders(String, Tuple<String, String[]>...) - Constructor for exception org.elasticsearch.ElasticsearchException.WithRestHeaders
 
WithRestHeaders(String, ImmutableMap<String, List<String>>) - Constructor for exception org.elasticsearch.ElasticsearchException.WithRestHeaders
 
WithRestHeaders(String, Throwable, Tuple<String, String[]>...) - Constructor for exception org.elasticsearch.ElasticsearchException.WithRestHeaders
 
WithRestHeaders(String, Throwable, ImmutableMap<String, List<String>>) - Constructor for exception org.elasticsearch.ElasticsearchException.WithRestHeaders
 
withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
 
WithScript(ValuesSource.Numeric, SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
 
WithScript(ValuesSource, SearchScript) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.WithScript
 
withSource(Object) - Method in interface org.elasticsearch.common.inject.Binder
Returns a binder that uses source as the reference location for configuration errors.
withSource(Object) - Method in class org.elasticsearch.common.inject.internal.Errors
Returns an instance that uses source as a reference point for newly added errors.
withSource(Object) - Method in interface org.elasticsearch.common.inject.PrivateBinder
 
withTimeout(long) - Method in class org.elasticsearch.transport.TransportRequestOptions
 
withTimeout(TimeValue) - Method in class org.elasticsearch.transport.TransportRequestOptions
 
withType(TransportRequestOptions.Type) - Method in class org.elasticsearch.transport.TransportRequestOptions
 
WordDelimiterTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
WordDelimiterTokenFilterFactory(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.WordDelimiterTokenFilterFactory
 
wordList - Variable in class org.elasticsearch.index.analysis.compound.AbstractCompoundWordTokenFilterFactory
 
WordScorer - Class in org.elasticsearch.search.suggest.phrase
 
WordScorer(IndexReader, String, double, BytesRef) - Constructor for class org.elasticsearch.search.suggest.phrase.WordScorer
 
WordScorer(IndexReader, Terms, String, double, BytesRef) - Constructor for class org.elasticsearch.search.suggest.phrase.WordScorer
 
WordScorer.WordScorerFactory - Interface in org.elasticsearch.search.suggest.phrase
 
WORKER_COUNT - Static variable in class org.elasticsearch.transport.netty.NettyTransport
 
workerCount - Variable in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
workerCount - Variable in class org.elasticsearch.transport.netty.NettyTransport
 
workFile() - Method in class org.elasticsearch.env.Environment
The work location, path to temp files.
workWithClusterFile() - Method in class org.elasticsearch.env.Environment
The work location with the cluster name as a sub directory.
wrap(Iterable<Releasable>) - Static method in enum org.elasticsearch.common.lease.Releasables
Wrap several releasables into a single one.
wrap(Releasable...) - Static method in enum org.elasticsearch.common.lease.Releasables
 
wrap(Filter) - Static method in class org.elasticsearch.common.lucene.search.NoCacheFilter
Wraps a filter in a NoCacheFilter or returns it if it already is a NoCacheFilter.
wrap(Query, QueryParseContext) - Static method in class org.elasticsearch.common.lucene.search.Queries
Wraps a query in a filter.
wrap(Callable<T>, Priority) - Static method in class org.elasticsearch.common.util.concurrent.PrioritizedCallable
 
wrap(Runnable, Priority) - Static method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
 
wrap(Iterable<? extends BucketCollector>) - Static method in class org.elasticsearch.search.aggregations.BucketCollector
Wrap the given collectors into a single instance.
wrapCountBasedEarlyTerminatingCollector(Collector, int) - Static method in class org.elasticsearch.common.lucene.Lucene
Wraps delegate with count based early termination collector with a threshold of maxCountHits
wrapdateline - Variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
We're expecting some geometries might cross the dateline.
wrapIfClosed(Throwable) - Method in class org.elasticsearch.index.engine.Engine
Wrap a Throwable in an EngineClosedException if the engine is already closed
wrapLongitude(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.GeoBoundsBuilder
Set whether to wrap longitudes.
wrapNumeric32Bit(TermsEnum) - Static method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
A TermsEnum that iterates only full precision prefix coded 32 bit values.
wrapNumeric64Bit(TermsEnum) - Static method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
A TermsEnum that iterates only full precision prefix coded 64 bit values.
wrappedFilter() - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
wrappedOut() - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
Wrapper(Filter, CacheKeyFilter.Key) - Constructor for class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
wrapperFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
wrapperFilter(byte[], int, int) - Static method in class org.elasticsearch.index.query.FilterBuilders
 
WrapperFilterBuilder - Class in org.elasticsearch.index.query
A Filter builder which allows building a filter thanks to a JSON string or binary data.
WrapperFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.WrapperFilterBuilder
 
WrapperFilterBuilder(byte[], int, int) - Constructor for class org.elasticsearch.index.query.WrapperFilterBuilder
 
WrapperFilterParser - Class in org.elasticsearch.index.query
Filter parser for embedded filter.
WrapperFilterParser() - Constructor for class org.elasticsearch.index.query.WrapperFilterParser
 
wrapperQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
A Query builder which allows building a query thanks to a JSON string or binary data.
wrapperQuery(byte[], int, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
A Query builder which allows building a query thanks to a JSON string or binary data.
WrapperQueryBuilder - Class in org.elasticsearch.index.query
A Query builder which allows building a query thanks to a JSON string or binary data.
WrapperQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
Builds a JSONQueryBuilder using the provided JSON query string.
WrapperQueryBuilder(byte[], int, int) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
 
WrapperQueryParser - Class in org.elasticsearch.index.query
Query parser for JSON Queries.
WrapperQueryParser() - Constructor for class org.elasticsearch.index.query.WrapperQueryParser
 
wrapSmartNameFilter(Filter, MapperService.SmartNameFieldMappers, QueryParseContext) - Static method in class org.elasticsearch.index.query.support.QueryParsers
 
wrapSmartNameQuery(Query, MapperService.SmartNameFieldMappers, QueryParseContext) - Static method in class org.elasticsearch.index.query.support.QueryParsers
 
wrapTermsEnum(TermsEnum) - Method in enum org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
 
wrapTimeLimitingCollector(Collector, Counter, long) - Static method in class org.elasticsearch.common.lucene.Lucene
Wraps delegate with a time limited collector with a timeout of timeoutInMillis
wrapTokenStream(TokenStream) - Method in class org.elasticsearch.search.suggest.context.ContextMapping.Context
Wrap the TokenStream according to the provided informations of ContextMapping.ContextConfig and a related ParseContext.Document.
wrapTokenStream(ParseContext.Document, TokenStream) - Method in class org.elasticsearch.search.suggest.context.ContextMapping.ContextConfig
Wrap a TokenStream for building suggestions to use context informations provided by a document or a ContextMapping
write(int) - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
write(int) - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Writes a character to the buffer.
write(char[], int, int) - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Writes characters to the buffer.
write(String, int, int) - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Write a portion of a string to the buffer.
write(int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
write(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
write(byte[]) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
write(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
write(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
write(char) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
Writes a single character.
write(int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
Writes a character given its 31-bits Unicode.
write(char[], int, int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
Writes a portion of an array of characters.
write(String, int, int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
Writes a portion of a string.
write(CharSequence) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
Writes the specified character sequence.
write(int) - Method in class org.elasticsearch.common.lucene.store.OutputStreamIndexOutput
 
write(byte[]) - Method in class org.elasticsearch.common.lucene.store.OutputStreamIndexOutput
 
write(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.OutputStreamIndexOutput
 
write(Rounding, StreamOutput) - Static method in class org.elasticsearch.common.rounding.Rounding.Streams
 
write(T, long, File...) - Method in class org.elasticsearch.gateway.local.state.meta.MetaDataStateFormat
Writes the given state to the given directories.
write(Store) - Method in class org.elasticsearch.index.store.Store.LegacyChecksums
 
write(StreamOutput, Translog.Operation) - Method in class org.elasticsearch.index.translog.ChecksummedTranslogStream
 
write(StreamOutput, Translog.Operation) - Method in class org.elasticsearch.index.translog.LegacyTranslogStream
 
write(StreamOutput, Translog.Operation) - Method in interface org.elasticsearch.index.translog.TranslogStream
Write the given translog operation to the output stream
write(TDigestState, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.metrics.percentiles.tdigest.TDigestState
 
write(ValueFormatter, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueFormatterStreams
 
writeAcknowledged(StreamOutput) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
Writes the timeout value
writeArrayFieldStart(String) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeArrayFieldStart(XContentString) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeArrayFieldStart(String) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeArrayFieldStart(String) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeArrayFieldStart(XContentString) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeBinary(byte[], int, int) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeBinary(byte[]) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeBinary(byte[], int, int) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeBinary(byte[]) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeBinaryField(String, byte[]) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeBinaryField(XContentString, byte[]) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeBinaryField(String, byte[]) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeBinaryField(String, byte[]) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeBinaryField(XContentString, byte[]) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeBoolean(boolean) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeBoolean(boolean) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes a boolean.
writeBoolean(boolean) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeBoolean(boolean) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeBooleanField(String, boolean) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeBooleanField(XContentString, boolean) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeBooleanField(String, boolean) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeBooleanField(String, boolean) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeBooleanField(XContentString, boolean) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeBuild(Build, StreamOutput) - Static method in class org.elasticsearch.Build
 
writeByte(byte) - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.common.io.stream.NoopStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes a single byte.
writeByte(byte) - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
 
writeByte(byte) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeBytes(byte[]) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeBytes(byte[], int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.NoopStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
 
writeBytes(byte[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes an array of bytes.
writeBytes(byte[], int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes an array of bytes.
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes an array of bytes.
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
 
writeBytesRef(BytesRef) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeBytesReference(BytesReference) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeBytesReference(BytesReference) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes the bytes reference, including a length header.
writeClassDescriptor(ObjectStreamClass) - Method in class org.elasticsearch.common.io.ThrowableObjectOutputStream
 
writeClusterBlocks(ClusterBlocks, StreamOutput) - Static method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
writeComplete(ChannelHandlerContext, WriteCompletionEvent) - Method in class org.elasticsearch.transport.netty.MessageChannelHandler
 
WriteConsistencyLevel - Enum in org.elasticsearch.action
Write Consistency Level control how many replicas should be active for a write operation to occur (a write operation can be index, or delete).
writeDirect(BytesReference, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
Directly writes the source to the output builder
writeDistanceUnit(StreamOutput, DistanceUnit) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
writeDouble(double) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeDouble(double) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeDoubleArray(double[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeDoubleLE(double, byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
Write a double in little-endian format.
writeEndArray() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeEndArray() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeEndObject() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeEndObject() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeExplanation(StreamOutput, Explanation) - Static method in class org.elasticsearch.common.lucene.Lucene
 
WriteFailureException - Exception in org.elasticsearch.action
 
WriteFailureException(Throwable, String) - Constructor for exception org.elasticsearch.action.WriteFailureException
 
writeFieldDoc(StreamOutput, FieldDoc) - Static method in class org.elasticsearch.common.lucene.Lucene
 
writeFieldName(String) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeFieldName(XContentString) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeFieldName(String) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeFieldName(XContentString) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeFieldStats(StreamOutput, ObjectObjectOpenHashMap<String, CollectionStatistics>) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
 
writeFloat(float) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeFloat(float) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeFloatArray(float[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeFloatLE(float, byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
Write a float in little-endian format.
writeGenericValue(Object) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeHeader(StreamOutput) - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
writeHeader(StreamOutput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedStreamOutput
 
writeHeader(FileChannel) - Method in class org.elasticsearch.index.translog.ChecksummedTranslogStream
 
writeHeader(FileChannel) - Method in class org.elasticsearch.index.translog.LegacyTranslogStream
 
writeHeader(FileChannel) - Method in interface org.elasticsearch.index.translog.TranslogStream
Optionally write a header identifying the translog version to the file channel
writeHeader(ChannelBuffer, long, byte, Version) - Static method in class org.elasticsearch.transport.netty.NettyHeader
 
writeIndex(StreamOutput) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
writeIndicesOptions(StreamOutput) - Method in class org.elasticsearch.action.support.IndicesOptions
 
writeInt(int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeInt(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes an int as four bytes.
writeIntArray(int[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeIntLE(int, byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
Write an int in little-endian format.
writeLocal(StreamOutput) - Method in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequest
writes the local flag
writeLocal(StreamOutput, Version) - Method in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequest
writes the local flag if on or after the specified min version or if the version is null.
writeLock - Variable in class org.elasticsearch.index.engine.Engine
 
writeLong(long) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeLong(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes a long as eight bytes.
writeLongArray(long[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeLongLE(long, byte[], int) - Static method in enum org.elasticsearch.common.util.ByteUtils
Write a long in little-endian format.
writeMap(Map<String, Object>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeNull() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNull() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNullField(String) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNullField(XContentString) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNullField(String) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeNullField(String) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNullField(XContentString) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumber(int) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumber(long) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumber(double) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumber(float) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumber(int) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumber(long) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumber(double) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumber(float) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumberField(String, int) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumberField(XContentString, int) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumberField(String, long) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumberField(XContentString, long) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumberField(String, double) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumberField(XContentString, double) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumberField(String, float) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumberField(XContentString, float) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeNumberField(String, int) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeNumberField(String, long) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeNumberField(String, double) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeNumberField(String, float) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeNumberField(String, int) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumberField(XContentString, int) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumberField(String, long) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumberField(XContentString, long) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumberField(String, double) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumberField(XContentString, double) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumberField(String, float) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeNumberField(XContentString, float) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeObjectFieldStart(String) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeObjectFieldStart(XContentString) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeObjectFieldStart(String) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeObjectFieldStart(String) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeObjectFieldStart(XContentString) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeObjectRaw(String, BytesReference, OutputStream) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContentGenerator
 
writeObjectRaw(String, BytesReference, OutputStream) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeObjectRaw(String, BytesReference, OutputStream) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContentGenerator
 
writeObjectRaw(String, BytesReference, OutputStream) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContentGenerator
 
writeOptional(ValueFormatter, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.support.format.ValueFormatterStreams
 
writeOptionalBoolean(Boolean) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeOptionalOriginalIndices(OriginalIndices, StreamOutput) - Static method in class org.elasticsearch.action.OriginalIndices
 
writeOptionalSharedString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeOptionalStreamable(Streamable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Serializes a potential null value.
writeOptionalString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeOptionalText(Text) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeOriginalIndices(OriginalIndices, StreamOutput) - Static method in class org.elasticsearch.action.OriginalIndices
 
writeOtherStatsTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.extended.InternalExtendedStats
 
writeOtherStatsTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
writer() - Method in class org.elasticsearch.common.cli.Terminal
 
writeRawField(String, InputStream, OutputStream) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContentGenerator
 
writeRawField(String, byte[], OutputStream) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContentGenerator
 
writeRawField(String, byte[], int, int, OutputStream) - Method in class org.elasticsearch.common.xcontent.cbor.CborXContentGenerator
 
writeRawField(String, byte[], OutputStream) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeRawField(String, byte[], int, int, OutputStream) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeRawField(String, InputStream, OutputStream) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeRawField(String, BytesReference, OutputStream) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeRawField(String, InputStream, OutputStream) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContentGenerator
 
writeRawField(String, byte[], OutputStream) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContentGenerator
 
writeRawField(String, byte[], int, int, OutputStream) - Method in class org.elasticsearch.common.xcontent.smile.SmileXContentGenerator
 
writeRawField(String, byte[], OutputStream) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeRawField(String, byte[], int, int, OutputStream) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeRawField(String, InputStream, OutputStream) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeRawField(String, BytesReference, OutputStream) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeRawField(String, BytesReference, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
Writes a "raw" (bytes) field, handling cases where the bytes are compressed, and tries to optimize writing using XContentBuilder.rawField(String, org.elasticsearch.common.bytes.BytesReference).
writeRawField(String, InputStream, OutputStream) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContentGenerator
 
writeRawField(String, byte[], OutputStream) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContentGenerator
 
writeRawField(String, byte[], int, int, OutputStream) - Method in class org.elasticsearch.common.xcontent.yaml.YamlXContentGenerator
 
writerSegmentStats(SegmentsStats) - Method in class org.elasticsearch.index.engine.Engine
 
writerSegmentStats(SegmentsStats) - Method in class org.elasticsearch.index.engine.InternalEngine
 
writeScoreDoc(StreamOutput, ScoreDoc) - Static method in class org.elasticsearch.common.lucene.Lucene
 
writeSettingsToStream(Settings, StreamOutput) - Static method in class org.elasticsearch.common.settings.ImmutableSettings
 
writeSharedString(String) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeSharedString(String) - Method in class org.elasticsearch.common.io.stream.HandlesStreamOutput
 
writeSharedString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeSharedText(Text) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeSharedText(Text) - Method in class org.elasticsearch.common.io.stream.HandlesStreamOutput
 
writeSharedText(Text) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeShort(short) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeSingleTermStats(StreamOutput, TermStatistics) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
 
writeSize(int, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation
Write a size under the assumption that a value of 0 means unlimited.
writeSnapshot(BlobStoreIndexShardSnapshot, OutputStream) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardRepository
Serializes snapshot to JSON
writeSnapshotList(ImmutableList<SnapshotId>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
Writes snapshot index file

This file can be used by read-only repositories that are unable to list files in the repository

writeSortType(StreamOutput, SortField.Type) - Static method in class org.elasticsearch.common.lucene.Lucene
 
writeStartArray() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeStartArray() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeStartObject() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeStartObject() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeStreamHeader() - Method in class org.elasticsearch.common.io.ThrowableObjectOutputStream
 
writeString(String) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeString(String) - Method in class org.elasticsearch.common.io.stream.HandlesStreamOutput
 
writeString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeString(String) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeString(char[], int, int) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeString(String) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeString(char[], int, int) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeStringArray(String[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeStringArrayNullable(String[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes a string array, for nullable string, writes it as 0 (empty string).
writeStringField(String, String) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeStringField(XContentString, String) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeStringField(String, String) - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentGenerator
 
writeStringField(String, String) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeStringField(XContentString, String) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeTermStats(StreamOutput, TermStatistics[]) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
 
writeText(Text) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeText(Text) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeTextArray(Text[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeThin(StreamOutput) - Method in class org.elasticsearch.transport.BytesTransportRequest
Writes the data in a "thin" manner, without the actual bytes, assumes the actual bytes will be appended right after this content.
writeTimeout(StreamOutput) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
writes the timeout value
writeTo(StreamOutput) - Method in class org.elasticsearch.action.ActionRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.ActionResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction.NodeRestartRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmVersion
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.flush.FlushResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.recovery.ShardRecoveryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Deprecated.
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
Deprecated.
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Deprecated.
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.warmer.get.GetWarmersResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkShardRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkShardResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.count.CountRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.count.CountResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.DeleteRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.DeleteResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.IndexDeleteResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.ShardDeleteRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.ShardDeleteResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.exists.ExistsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.exists.ExistsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.explain.ExplainResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.GetRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.GetResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetItemResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.index.IndexRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.index.IndexResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.indexedscripts.delete.DeleteIndexedScriptResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.indexedscripts.get.GetIndexedScriptResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.indexedscripts.put.PutIndexedScriptResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.MultiPercolateRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse.Item
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.MultiPercolateResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.PercolateRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.PercolateResponse.Match
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.PercolateResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.PercolateShardRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.PercolateShardResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Request
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.TransportShardMultiPercolateAction.Response
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ClearScrollRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ClearScrollResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchScrollRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ShardSearchFailure
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.suggest.SuggestRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.suggest.SuggestResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.NodeOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.NodeOperationResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ReplicaOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.ShardSingleOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsItemResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse.Failure
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsShardRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvector.MultiTermVectorsShardResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvector.TermVectorRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvector.TermVectorResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.update.UpdateRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.update.UpdateResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterName
 
writeTo(ClusterState, StreamOutput) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
 
writeTo(T, StreamOutput) - Method in interface org.elasticsearch.cluster.ClusterState.Custom.Factory
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
writeTo(AliasMetaData, StreamOutput) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
 
writeTo(IndexMetaData, StreamOutput) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
writeTo(T, StreamOutput) - Method in interface org.elasticsearch.cluster.metadata.IndexMetaData.Custom.Factory
 
writeTo(IndexTemplateMetaData, StreamOutput) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
writeTo(MappingMetaData, StreamOutput) - Static method in class org.elasticsearch.cluster.metadata.MappingMetaData
 
writeTo(MetaData, StreamOutput) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
writeTo(T, StreamOutput) - Method in class org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
writeTo(RepositoriesMetaData, StreamOutput) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetaData.Factory
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.RepositoryMetaData
Writes repository metadata to stream output
writeTo(RestoreMetaData, StreamOutput) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.Factory
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.RestoreMetaData.ShardRestoreStatus
Writes restore status to stream output
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.SnapshotId
writeTo(SnapshotMetaData, StreamOutput) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.Factory
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.SnapshotMetaData.ShardSnapshotStatus
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
writeTo(DiscoveryNodes, StreamOutput) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
 
writeTo(AllocateAllocationCommand, StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateAllocationCommand.Factory
 
writeTo(T, StreamOutput) - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand.Factory
writeTo(AllocationCommands, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
writeTo(CancelAllocationCommand, StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand.Factory
 
writeTo(MoveAllocationCommand, StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand.Factory
 
writeTo(Decision.Type, StreamOutput) - Static method in enum org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
 
writeTo(Decision, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
 
writeTo(RerouteExplanation, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
 
writeTo(RoutingExplanations, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
Write the RoutingExplanations object
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
writeTo(IndexRoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
writeTo(IndexShardRoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RestoreSource
 
writeTo(RoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.service.PendingClusterTask
 
writeTo(CircuitBreaker.Name, StreamOutput) - Static method in enum org.elasticsearch.common.breaker.CircuitBreaker.Name
 
writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.BytesArray
 
writeTo(GatheringByteChannel) - Method in class org.elasticsearch.common.bytes.BytesArray
 
writeTo(OutputStream) - Method in interface org.elasticsearch.common.bytes.BytesReference
Writes the bytes directly to the output stream.
writeTo(GatheringByteChannel) - Method in interface org.elasticsearch.common.bytes.BytesReference
Writes the bytes directly to the channel.
writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
 
writeTo(GatheringByteChannel) - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
 
writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.HashedBytesArray
 
writeTo(GatheringByteChannel) - Method in class org.elasticsearch.common.bytes.HashedBytesArray
 
writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.PagedBytesReference
 
writeTo(GatheringByteChannel) - Method in class org.elasticsearch.common.bytes.PagedBytesReference
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.compress.CompressedString
 
writeTo(Writer) - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Writes the contents of the buffer to another character stream.
writeTo(StreamOutput) - Method in interface org.elasticsearch.common.io.stream.Streamable
 
writeTo(Priority, StreamOutput) - Static method in class org.elasticsearch.common.Priority
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.rounding.Rounding.FactorRounding
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.rounding.Rounding.Interval
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.rounding.Rounding.PrePostRounding
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.transport.BoundTransportAddress
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.transport.DummyTransportAddress
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.transport.LocalTransportAddress
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.Percent
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.SizeValue
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.TimeValue
 
writeTo(BloomFilter, StreamOutput) - Static method in class org.elasticsearch.common.util.BloomFilter
 
writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection.PingRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices.AllocateDangledResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState
 
writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState
 
writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards
 
writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards
 
writeTo(StreamOutput) - Method in class org.elasticsearch.http.HttpInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.http.HttpStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.cache.filter.FilterCacheStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.cache.id.IdCacheStats
Deprecated.
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.Segment
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.SegmentsStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.flush.FlushStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.get.GetField
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.get.GetResult
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.get.GetStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.Index
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.indexing.IndexingStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.merge.MergeStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.percolator.stats.PercolateStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.recovery.RecoveryStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.refresh.RefreshStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.search.stats.SearchStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.DocsStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.ShardId
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.StoreFileMetaData
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.StoreStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.suggest.stats.SuggestStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.translog.Translog.Create
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.translog.Translog.Delete
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.translog.Translog.Index
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.translog.TranslogStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.warmer.WarmerStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.NodeIndicesStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.File
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Start
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.network.NetworkInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.network.NetworkStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsInfo.Mem
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsInfo.Swap
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Swap
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.VerificationFailure
 
writeTo(StreamOutput, RestStatus) - Static method in enum org.elasticsearch.rest.RestStatus
 
writeTo(RiverClusterState, StreamOutput) - Static method in class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
writeTo(StreamOutput) - Method in class org.elasticsearch.river.routing.RiverRouting
 
writeTo(RiversRouting, StreamOutput) - Static method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
writeTo(ScriptService.ScriptType, StreamOutput) - Static method in enum org.elasticsearch.script.ScriptService.ScriptType
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.filters.InternalFilters
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ChiSquare
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.GND
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.JLHScore
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.MutualInformation
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.PercentageScore
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.ScriptHeuristic
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.SignificanceHeuristic
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantLongTerms
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.significant.UnmappedSignificantTerms
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.avg.InternalAvg
 
writeTo(long, StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.HyperLogLogPlusPlus
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.cardinality.InternalCardinality
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.geobounds.InternalGeoBounds
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.max.InternalMax
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.min.InternalMin
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.scripted.InternalScriptedMetric
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.stats.InternalStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.sum.InternalSum
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.tophits.InternalTopHits
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.valuecount.InternalValueCount
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.DateTime
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.GeoHash
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.IPv4Formatter
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Number.Pattern
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.format.ValueFormatter.Raw
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.dfs.AggregatedDfs
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.histogram.InternalCountHistogramFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.histogram.InternalFullHistogramFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.InternalFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.InternalFacets
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.FetchSearchResult
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.source.FetchSourceContext
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.highlight.HighlightField
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchHit.InternalNestedIdentity
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
writeTo(StreamOutput, InternalSearchHits.StreamContext) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchHitField
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchHits
 
writeTo(StreamOutput, InternalSearchHits.StreamContext) - Method in class org.elasticsearch.search.internal.InternalSearchHits
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.ShardSearchTransportRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.Scroll
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchShardTarget
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
 
writeTo(IndexWarmersMetaData, StreamOutput) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.RestoreInfo
writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotShardFailure
 
writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPool.Info
 
writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.BytesTransportRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportMessage
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportStats
 
writeToChannel(ChannelBuffer, int, int, GatheringByteChannel) - Static method in class org.elasticsearch.common.io.Channels
Copies bytes from source ChannelBuffer to a GatheringByteChannel
writeToChannel(byte[], WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
Writes part of a byte array to a WritableByteChannel
writeToChannel(byte[], int, int, WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
Writes part of a byte array to a WritableByteChannel
writeToChannel(ByteBuffer, WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
writeToNoId(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
writeTopDocs(StreamOutput, TopDocs, int) - Static method in class org.elasticsearch.common.lucene.Lucene
 
writeToThin(StreamOutput) - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
Writes shard information to StreamOutput without writing index name and shard id
writeToThin(IndexShardRoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
writeToThin(StreamOutput) - Method in interface org.elasticsearch.cluster.routing.ShardRouting
Does not write index name and shard id
writeTranslogOperation(StreamOutput, Translog.Operation) - Static method in class org.elasticsearch.index.translog.TranslogStreams
Write the Translog.Operation to the output stream using the latest translog version
writeUTF8String(byte[], int, int) - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
writeUTF8String(byte[], int, int) - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
writeVersion(long, StreamOutput) - Static method in class org.elasticsearch.common.lucene.uid.Versions
 
writeVersion(Version, StreamOutput) - Static method in class org.elasticsearch.Version
 
writeVersionWithVLongForBW(long, StreamOutput) - Static method in class org.elasticsearch.common.lucene.uid.Versions
 
writeVInt(int) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeVInt(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes an int in a variable-length format.
writeVLong(long) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeVLong(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Writes an long in a variable-length format.
writeVLong(ByteArrayDataOutput, long) - Static method in enum org.elasticsearch.common.util.ByteUtils
Same as DataOutput#writeVLong but accepts negative values (written on 9 bytes).
writtenBy() - Method in class org.elasticsearch.index.store.StoreFileMetaData
Returns the Lucene version this file has been written by or null if unknown

X

X_FIELD_NAME - Static variable in class org.elasticsearch.common.unit.Fuzziness
 
XAnalyzingSuggester - Class in org.apache.lucene.search.suggest.analyzing
Suggester that first analyzes the surface form, adds the analyzed form to a weighted FST, and then does the same thing at lookup time.
XAnalyzingSuggester(Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
Calls AnalyzingSuggester(analyzer, analyzer, EXACT_FIRST | PRESERVE_SEP, 256, -1)
XAnalyzingSuggester(Analyzer, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
Calls AnalyzingSuggester(indexAnalyzer, queryAnalyzer, EXACT_FIRST | PRESERVE_SEP, 256, -1)
XAnalyzingSuggester(Analyzer, Automaton, Analyzer, int, int, int, boolean, FST<PairOutputs.Pair<Long, BytesRef>>, boolean, int, int, int, int, int) - Constructor for class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester
Creates a new suggester.
XAnalyzingSuggester.XBuilder - Class in org.apache.lucene.search.suggest.analyzing
 
XBooleanFilter - Class in org.elasticsearch.common.lucene.search
Similar to BooleanFilter.
XBooleanFilter() - Constructor for class org.elasticsearch.common.lucene.search.XBooleanFilter
 
XBuilder(int, boolean, int) - Constructor for class org.apache.lucene.search.suggest.analyzing.XAnalyzingSuggester.XBuilder
 
XCollector - Class in org.elasticsearch.common.lucene.search
An extension to Collector that allows for a callback when collection is done.
XCollector() - Constructor for class org.elasticsearch.common.lucene.search.XCollector
 
XConstantScoreQuery - Class in org.elasticsearch.common.lucene.search
We still need sometimes to exclude deletes, because we don't remove them always with acceptDocs on filters
XConstantScoreQuery(Filter) - Constructor for class org.elasticsearch.common.lucene.search.XConstantScoreQuery
 
XContent - Interface in org.elasticsearch.common.xcontent
A generic abstraction on top of handling content, inspired by JSON and pull parsing.
xContent(XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Returns the XContent for the provided content type.
xContent(CharSequence) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Guesses the content (type) based on the provided char sequence.
xContent(byte[]) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
xContent(byte[], int, int) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
xContent(BytesReference) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
 
xContent() - Method in enum org.elasticsearch.common.xcontent.XContentType
 
XContentBuilder - Class in org.elasticsearch.common.xcontent
 
XContentBuilder(XContent, OutputStream) - Constructor for class org.elasticsearch.common.xcontent.XContentBuilder
Constructs a new builder using the provided xcontent and an OutputStream.
XContentBuilder.FieldCaseConversion - Enum in org.elasticsearch.common.xcontent
 
XContentBuilderString - Class in org.elasticsearch.common.xcontent
 
XContentBuilderString(String) - Constructor for class org.elasticsearch.common.xcontent.XContentBuilderString
 
XContentFactory - Class in org.elasticsearch.common.xcontent
A one stop to use XContent and XContentBuilder.
XContentFactory() - Constructor for class org.elasticsearch.common.xcontent.XContentFactory
 
XContentFilterParsersBindings(MapBinder<String, FilterParserFactory>, Map<String, Settings>) - Constructor for class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings
 
XContentGenerator - Interface in org.elasticsearch.common.xcontent
 
XContentHelper - Class in org.elasticsearch.common.xcontent
 
XContentHelper() - Constructor for class org.elasticsearch.common.xcontent.XContentHelper
 
XContentMapValues - Class in org.elasticsearch.common.xcontent.support
 
XContentMapValues() - Constructor for class org.elasticsearch.common.xcontent.support.XContentMapValues
 
XContentParser - Interface in org.elasticsearch.common.xcontent
Interface for pull - parsing XContent see XContentType for supported types.
XContentParser.NumberType - Enum in org.elasticsearch.common.xcontent
 
XContentParser.Token - Enum in org.elasticsearch.common.xcontent
 
XContentQueryParsersBindings(MapBinder<String, QueryParserFactory>, Map<String, Settings>) - Constructor for class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings
 
XContentSettingsLoader - Class in org.elasticsearch.common.settings.loader
Settings loader that loads (parses) the settings in a xcontent format by flattening them into a map.
XContentSettingsLoader() - Constructor for class org.elasticsearch.common.settings.loader.XContentSettingsLoader
 
XContentString - Class in org.elasticsearch.common.xcontent
 
XContentString(String) - Constructor for class org.elasticsearch.common.xcontent.XContentString
 
XContentStructure - Class in org.elasticsearch.index.query.support
XContentStructure is a class used to capture a subset of query, to be parsed at a later time when more information (in this case, types) is available.
XContentStructure(QueryParseContext) - Constructor for class org.elasticsearch.index.query.support.XContentStructure
Create a new XContentStructure for the current parsing context.
XContentStructure.InnerFilter - Class in org.elasticsearch.index.query.support
InnerFilter is an extension of XContentStructure that eagerly parses the filter in a streaming manner if the types are available at construction time.
XContentStructure.InnerQuery - Class in org.elasticsearch.index.query.support
InnerQuery is an extension of XContentStructure that eagerly parses the query in a streaming manner if the types are available at construction time.
xContentType(CharSequence) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Guesses the content type based on the provided char sequence.
xContentType(byte[]) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
xContentType(InputStream) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Guesses the content type based on the provided input stream.
xContentType(byte[], int, int) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
xContentType(BytesReference) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
XContentType - Enum in org.elasticsearch.common.xcontent
The content type of XContent.
XFieldComparatorSource() - Constructor for class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
 
XFilteredQuery - Class in org.elasticsearch.common.lucene.search
A query that applies a filter to the results of another query.
XFilteredQuery(Query, Filter) - Constructor for class org.elasticsearch.common.lucene.search.XFilteredQuery
Constructs a new query which applies a filter to the results of the original query.
XFilteredQuery(Query, Filter, FilteredQuery.FilterStrategy) - Constructor for class org.elasticsearch.common.lucene.search.XFilteredQuery
Expert: Constructs a new query which applies a filter to the results of the original query.
XFilteredQuery.CustomRandomAccessFilterStrategy - Class in org.elasticsearch.common.lucene.search
Extends FilteredQuery.RandomAccessFilterStrategy.
XFuzzySuggester - Class in org.apache.lucene.search.suggest.analyzing
Implements a fuzzy AnalyzingSuggester.
XFuzzySuggester(Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
Creates a FuzzySuggester instance initialized with default values.
XFuzzySuggester(Analyzer, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
Creates a FuzzySuggester instance with an index & a query analyzer initialized with default values.
XFuzzySuggester(Analyzer, Automaton, Analyzer, int, int, int, int, boolean, int, int, boolean, FST<PairOutputs.Pair<Long, BytesRef>>, boolean, int, int, int, int, int) - Constructor for class org.apache.lucene.search.suggest.analyzing.XFuzzySuggester
Creates a FuzzySuggester instance.
XIOUtils - Class in org.apache.lucene.util
This class emulates the new Java 7 "Try-With-Resources" statement.
XMoreLikeThis - Class in org.elasticsearch.common.lucene.search
Generate "more like this" similarity queries.
XMoreLikeThis(IndexReader) - Constructor for class org.elasticsearch.common.lucene.search.XMoreLikeThis
Constructor requiring an IndexReader.
XMoreLikeThis(IndexReader, TFIDFSimilarity) - Constructor for class org.elasticsearch.common.lucene.search.XMoreLikeThis
 
XPostingsHighlighter - Class in org.apache.lucene.search.postingshighlight
 
XPostingsHighlighter() - Constructor for class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Creates a new highlighter with default parameters.
XPostingsHighlighter(int) - Constructor for class org.apache.lucene.search.postingshighlight.XPostingsHighlighter
Creates a new highlighter, specifying maximum content length.
XRejectedExecutionHandler - Interface in org.elasticsearch.common.util.concurrent
 
XShapeCollection<S extends com.spatial4j.core.shape.Shape> - Class in org.elasticsearch.common.geo
Overrides bounding box logic in ShapeCollection base class to comply with OGC OpenGIS Abstract Specification: An Object Model for Interoperable Geoprocessing.
XShapeCollection(List<S>, SpatialContext) - Constructor for class org.elasticsearch.common.geo.XShapeCollection
 

Y

yamlBuilder() - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Returns a content builder using YAML format (XContentType.YAML.
yamlBuilder(OutputStream) - Static method in class org.elasticsearch.common.xcontent.XContentFactory
Constructs a new yaml builder that will output the result into the provided output stream.
YamlSettingsLoader - Class in org.elasticsearch.common.settings.loader
Settings loader that loads (parses) the settings in a yaml format by flattening them into a map.
YamlSettingsLoader() - Constructor for class org.elasticsearch.common.settings.loader.YamlSettingsLoader
 
YamlXContent - Class in org.elasticsearch.common.xcontent.yaml
A YAML based content implementation using Jackson.
yamlXContent - Static variable in class org.elasticsearch.common.xcontent.yaml.YamlXContent
 
YamlXContentGenerator - Class in org.elasticsearch.common.xcontent.yaml
 
YamlXContentGenerator(JsonGenerator) - Constructor for class org.elasticsearch.common.xcontent.yaml.YamlXContentGenerator
 
YamlXContentParser - Class in org.elasticsearch.common.xcontent.yaml
 
YamlXContentParser(JsonParser) - Constructor for class org.elasticsearch.common.xcontent.yaml.YamlXContentParser
 
YEAR - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogram.Interval
 
YES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
 
YOUNG - Static variable in class org.elasticsearch.monitor.jvm.GcNames
 

Z

ZenDiscovery - Class in org.elasticsearch.discovery.zen
 
ZenDiscovery(Settings, ClusterName, ThreadPool, TransportService, ClusterService, NodeSettingsService, DiscoveryNodeService, ZenPingService, ElectMasterService, DiscoverySettings, DynamicSettings) - Constructor for class org.elasticsearch.discovery.zen.ZenDiscovery
 
ZenDiscoveryModule - Class in org.elasticsearch.discovery.zen
 
ZenDiscoveryModule() - Constructor for class org.elasticsearch.discovery.zen.ZenDiscoveryModule
 
ZenPing - Interface in org.elasticsearch.discovery.zen.ping
 
ZenPing.PingCollection - Class in org.elasticsearch.discovery.zen.ping
a utility collection of pings where only the most recent ping is stored per node
ZenPing.PingListener - Interface in org.elasticsearch.discovery.zen.ping
 
ZenPing.PingResponse - Class in org.elasticsearch.discovery.zen.ping
 
ZenPingException - Exception in org.elasticsearch.discovery.zen.ping
 
ZenPingException(String) - Constructor for exception org.elasticsearch.discovery.zen.ping.ZenPingException
 
ZenPingException(String, Throwable) - Constructor for exception org.elasticsearch.discovery.zen.ping.ZenPingException
 
zenPings() - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
 
zenPings(ImmutableList<? extends ZenPing>) - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
 
ZenPingService - Class in org.elasticsearch.discovery.zen.ping
 
ZenPingService(Settings, ThreadPool, TransportService, ClusterName, NetworkService, ElectMasterService, Set<UnicastHostsProvider>) - Constructor for class org.elasticsearch.discovery.zen.ping.ZenPingService
 
ZenPingService(Settings, ThreadPool, TransportService, ClusterName, NetworkService, Version, ElectMasterService, Set<UnicastHostsProvider>) - Constructor for class org.elasticsearch.discovery.zen.ping.ZenPingService
 
ZERO - Static variable in class org.elasticsearch.common.unit.Fuzziness
 
zeroTermsQuery(MatchQueryBuilder.ZeroTermsQuery) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
 
zeroTermsQuery(MatchQueryBuilder.ZeroTermsQuery) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
 
zeroTermsQuery - Variable in class org.elasticsearch.index.search.MatchQuery
 
zeroTermsQuery() - Method in class org.elasticsearch.index.search.MatchQuery
 
zigZagDecode(long) - Static method in enum org.elasticsearch.common.util.ByteUtils
Zig-zag decode.
zigZagEncode(long) - Static method in enum org.elasticsearch.common.util.ByteUtils
Zig-zag encode: this helps transforming small signed numbers into small positive numbers.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

Copyright © 2009–2015. All rights reserved.