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

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
 
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
 
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
 
AbstractConcurrentMapFieldDataCache - Class in org.elasticsearch.index.cache.field.data.support
 
AbstractConcurrentMapFieldDataCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
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
 
AbstractDump - Class in org.elasticsearch.monitor.dump
 
AbstractDump(long, String, Map<String, Object>) - Constructor for class org.elasticsearch.monitor.dump.AbstractDump
 
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
 
AbstractFacetBuilder - Class in org.elasticsearch.search.facet
 
AbstractFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.AbstractFacetBuilder
 
AbstractFacetCollector - Class in org.elasticsearch.search.facet
 
AbstractFacetCollector(String) - Constructor for class org.elasticsearch.search.facet.AbstractFacetCollector
 
AbstractFieldMapper<T> - Class in org.elasticsearch.index.mapper.core
 
AbstractFieldMapper(FieldMapper.Names, Field.Index, Field.Store, Field.TermVector, float, boolean, FieldInfo.IndexOptions, NamedAnalyzer, NamedAnalyzer) - 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.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
AbstractFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
AbstractFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
AbstractFieldMapper.OpenBuilder<T extends AbstractFieldMapper.Builder,Y extends AbstractFieldMapper> - Class in org.elasticsearch.index.mapper.core
 
AbstractFieldMapper.OpenBuilder(String) - Constructor for class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
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
 
AbstractFragmentsBuilder - Class in org.apache.lucene.search.vectorhighlight
Abstract FragmentsBuilder implementation that detects whether highlight hits occurred on a field that is multivalued (Basically fields that have the same name) and splits the highlight snippets according to a single field boundary.
AbstractFragmentsBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.AbstractFragmentsBuilder
 
AbstractFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.AbstractFragmentsBuilder
 
AbstractFragmentsBuilder(String[], String[]) - Constructor for class org.apache.lucene.search.vectorhighlight.AbstractFragmentsBuilder
 
AbstractFragmentsBuilder(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.AbstractFragmentsBuilder
 
AbstractFsBlobContainer - Class in org.elasticsearch.common.blobstore.fs
 
AbstractFsBlobContainer(FsBlobStore, BlobPath, File) - Constructor for class org.elasticsearch.common.blobstore.fs.AbstractFsBlobContainer
 
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.
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) - 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
 
AbstractJmxModule - Class in org.elasticsearch.jmx
Simple based class for JMX related services with AbstractJmxModule.doConfigure() only being called if jmx is enabled.
AbstractJmxModule(Settings) - Constructor for class org.elasticsearch.jmx.AbstractJmxModule
 
AbstractJvmQueryParserCache - Class in org.elasticsearch.index.cache.query.parser.support
 
AbstractJvmQueryParserCache(Index, Settings, ConcurrentMap<QueryParserSettings, Query>) - Constructor for class org.elasticsearch.index.cache.query.parser.support.AbstractJvmQueryParserCache
 
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
 
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
 
AbstractPlugin - Class in org.elasticsearch.plugins
A base class for a plugin.
AbstractPlugin() - Constructor for class org.elasticsearch.plugins.AbstractPlugin
 
AbstractRestRequest - Class in org.elasticsearch.rest.support
 
AbstractRestRequest() - Constructor for class org.elasticsearch.rest.support.AbstractRestRequest
 
AbstractRestResponse - Class in org.elasticsearch.rest
 
AbstractRestResponse() - Constructor for class org.elasticsearch.rest.AbstractRestResponse
 
AbstractRiverComponent - Class in org.elasticsearch.river
 
AbstractRiverComponent(RiverName, RiverSettings) - Constructor for class org.elasticsearch.river.AbstractRiverComponent
 
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<T extends org.apache.lucene.search.Similarity> - Class in org.elasticsearch.index.similarity
 
AbstractSimilarityProvider(Index, Settings, String) - Constructor for class org.elasticsearch.index.similarity.AbstractSimilarityProvider
 
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(String) - Method in class org.elasticsearch.common.lucene.document.SingleFieldSelector
 
accept(String) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldSelector
 
accept(String) - Method in class org.elasticsearch.index.mapper.selector.AllButSourceFieldSelector
 
accept(String) - Method in class org.elasticsearch.index.mapper.selector.FieldMappersFieldSelector
 
accept(String) - Method in class org.elasticsearch.index.mapper.selector.UidAndRoutingFieldSelector
 
accept(String) - Method in class org.elasticsearch.index.mapper.selector.UidAndSourceFieldSelector
 
accept(String) - Method in class org.elasticsearch.index.mapper.selector.UidFieldSelector
 
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.docset.DocIdSetCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.common.lucene.Lucene.ExistsCollector
 
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.index.search.child.ChildCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.index.search.nested.NestedChildrenCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
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.search.internal.SearchContext
 
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.delete.index.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.broadcast.TransportBroadcastOperationAction
 
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
 
ack() - Method in class org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices.AllocateDangledResponse
 
acknowledged() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse
 
acknowledged() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
 
acknowledged() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
Has the index creation been acknowledged by all current cluster nodes within the provided CreateIndexRequest.timeout(org.elasticsearch.common.unit.TimeValue).
acknowledged() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexResponse
Has the index deletion been acknowledged by all current cluster nodes within the provided DeleteIndexRequest.timeout(org.elasticsearch.common.unit.TimeValue).
acknowledged() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingResponse
Has the put mapping creation been acknowledged by all current cluster nodes within the provided PutMappingRequest.timeout(org.elasticsearch.common.unit.TimeValue).
acknowledged() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
 
acknowledged() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateResponse
 
acknowledged() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateResponse
 
acknowledged() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerResponse
 
acknowledged() - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerResponse
Has the put warmer been ack'ed.
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Response
 
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Response
 
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService.Response
 
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutResponse
 
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveResponse
 
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService.Response
 
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataStateIndexService.Response
 
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
 
Action<Request extends ActionRequest,Response extends ActionResponse,RequestBuilder extends ActionRequestBuilder<Request,Response>> - Class in org.elasticsearch.action
Main action (used with Client API.
Action(String) - Constructor for class org.elasticsearch.action.Action
 
action() - Method in exception org.elasticsearch.transport.ActionNotFoundTransportException
 
action() - Method in exception org.elasticsearch.transport.ActionTransportException
The action to invoke.
action() - Method in interface org.elasticsearch.transport.ActionTransportRequestHandler
 
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
 
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 wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
actionGet(String) - Method in interface org.elasticsearch.action.ActionFuture
Similar to Future.get(long, java.util.concurrent.TimeUnit), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
actionGet(long) - Method in interface org.elasticsearch.action.ActionFuture
Similar to Future.get(long, java.util.concurrent.TimeUnit), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
actionGet(long, TimeUnit) - Method in interface org.elasticsearch.action.ActionFuture
Similar to Future.get(long, java.util.concurrent.TimeUnit), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
actionGet(TimeValue) - Method in interface org.elasticsearch.action.ActionFuture
Similar to Future.get(long, java.util.concurrent.TimeUnit), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
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
 
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 - Interface in org.elasticsearch.action
 
ActionRequestBuilder<Request extends ActionRequest,Response extends ActionResponse> - Interface in org.elasticsearch.action
 
ActionRequestValidationException - Exception in org.elasticsearch.action
 
ActionRequestValidationException() - Constructor for exception org.elasticsearch.action.ActionRequestValidationException
 
ActionResponse - Interface in org.elasticsearch.action
 
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
 
ActionTransportRequestHandler<T extends Streamable> - Interface in org.elasticsearch.transport
 
actionType() - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
activateOptions() - Method in class org.elasticsearch.common.logging.log4j.ConsoleAppender
Prepares the appender for use.
active() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
active() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
Relocating or started.
active() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
activeOpens() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
activePrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
activePrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
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).
activeShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
activeShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
activeShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
activeShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
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
 
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
 
adapt(Runnable) - Static method in class jsr166y.ForkJoinTask
Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns a null result upon ForkJoinTask.join().
adapt(Runnable, T) - Static method in class jsr166y.ForkJoinTask
Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns the given result upon ForkJoinTask.join().
adapt(Callable<? extends T>) - Static method in class jsr166y.ForkJoinTask
Returns a new ForkJoinTask that performs the call method of the given Callable as its action, and returns its result upon ForkJoinTask.join(), translating any checked exceptions encountered into RuntimeException.
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(E) - Method in class jsr166e.extra.ReadMostlyVector
 
add(int, E) - Method in class jsr166e.extra.ReadMostlyVector
 
add(long) - Method in class jsr166e.LongAdder
Adds the given value.
add(K, long) - Method in class jsr166e.LongAdderTable
Adds the given value to the sum associated with the given key.
add(E) - Method in class jsr166y.ConcurrentLinkedDeque
Inserts the specified element at the tail of this deque.
add(E) - Method in class jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
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
 
add(BytesReference, boolean, String, String) - 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(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(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
Adds an DeleteRequest to the list of actions to execute.
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(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(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[], byte[], int, int) - Method in class org.elasticsearch.action.get.MultiGetRequest
 
add(String, String, String[], BytesReference) - 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, String, String, String[]) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
 
add(int, GetResponse) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
 
add(int, MultiGetResponse.Failure) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
 
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, IgnoreIndices) - 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(NodeAliasesUpdatedAction.Listener, TimeValue) - Method in class org.elasticsearch.cluster.action.index.NodeAliasesUpdatedAction
 
add(NodeIndexCreatedAction.Listener) - Method in class org.elasticsearch.cluster.action.index.NodeIndexCreatedAction
 
add(NodeIndexDeletedAction.Listener) - Method in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
 
add(NodeMappingCreatedAction.Listener, TimeValue) - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction
 
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.
add(ShardId, AllocationExplanation.NodeExplanation) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
 
add(Class<? extends AllocationDecider>) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecidersModule
 
add(MutableShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
add(IndexMetaData, boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
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(byte[], int, int) - Method in interface org.elasticsearch.common.bloom.BloomFilter
 
add(byte[], int, int) - Method in class org.elasticsearch.common.bloom.ObsBloomFilter
 
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(E) - Method in class org.elasticsearch.common.collect.MapBackedSet
 
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(Fieldable) - Method in class org.elasticsearch.common.lucene.DocumentBuilder
 
add(FieldBuilder) - Method in class org.elasticsearch.common.lucene.DocumentBuilder
 
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(String, CompressedString) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
add(CacheStats) - Method in class org.elasticsearch.index.cache.CacheStats
 
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, String) - Method in class org.elasticsearch.index.mapper.MapperService
 
add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper.Builder
 
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(String) - Method in class org.elasticsearch.index.mapper.selector.FieldMappersFieldSelector
 
add(FieldMappers) - Method in class org.elasticsearch.index.mapper.selector.FieldMappersFieldSelector
 
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(FilterBuilder) - Method in class org.elasticsearch.index.query.AndFilterBuilder
Adds a filter to the list of filters to "and".
add(FilterBuilder, String) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
 
add(FilterBuilder, float) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
 
add(QueryBuilder) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
Add a sub-query to this disjunction.
add(FilterBuilder) - Method in class org.elasticsearch.index.query.OrFilterBuilder
Adds a filter to the list of filters to "or".
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(StoreStats) - Method in class org.elasticsearch.index.store.StoreStats
 
add(byte[], int, int) - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
add(Translog.Operation) - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
add(byte[], int, int) - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
add(byte[], int, int) - 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(long, long, long) - Method in class org.elasticsearch.index.warmer.WarmerStats
 
add(WarmerStats) - Method in class org.elasticsearch.index.warmer.WarmerStats
 
add(RiverClusterStateListener) - Method in class org.elasticsearch.river.cluster.RiverClusterService
 
add(PartialFieldsContext.PartialField) - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsContext
 
add(ScriptFieldsContext.ScriptField) - Method in class org.elasticsearch.search.fetch.script.ScriptFieldsContext
 
addAddressType(TransportAddress) - Static method in class org.elasticsearch.common.transport.TransportAddressSerializers
 
addAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
Adds an alias to the index.
addAlias(String, String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
Adds an alias to the index.
addAlias(String, String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
Adds an alias to the index.
addAlias(String, String, FilterBuilder) - 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, 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, FilterBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
Adds an alias to the index.
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.
addAll(Collection<? extends E>) - Method in class jsr166e.extra.ReadMostlyVector
 
addAll(int, Collection<? extends E>) - Method in class jsr166e.extra.ReadMostlyVector
 
addAll(Collection<? extends E>) - Method in class jsr166y.ConcurrentLinkedDeque
Appends all of the elements in the specified collection to the end of this deque, in the order that they are returned by the specified collection's iterator.
addAll(Collection<? extends E>) - Method in class org.elasticsearch.common.collect.BoundedTreeSet
 
addAllAbsent(Collection<? extends E>) - Method in class jsr166e.extra.ReadMostlyVector
Appends all of the elements in the specified collection that are not already contained in this list, to the end of this list, in the order that they are returned by the specified collection's iterator.
addAnalyzer(String, Class<? extends AnalyzerProvider>) - Method in class org.elasticsearch.index.analysis.AnalysisModule
 
addAndCheck(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Add two integers, checking for overflow.
addAndCheck(long, long) - Static method in class org.elasticsearch.common.math.MathUtils
Add two long integers, checking for overflow.
addAndGet(double) - Method in class jsr166e.extra.AtomicDouble
Atomically adds the given value to the current value.
addAndGet(int, double) - Method in class jsr166e.extra.AtomicDoubleArray
Atomically adds the given value to the element at index i.
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
 
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
 
addCollector(String, Collector) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
addConflict(String) - Method in class org.elasticsearch.index.mapper.MergeContext
 
addConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
 
addCurrentFilesSize(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
addCustomAttributeProvider(DiscoveryNodeService.CustomAttributesProvider) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeService
 
addCustomNameResolver(NetworkService.CustomNameResolver) - Method in class org.elasticsearch.common.network.NetworkService
Add a custom name resolver.
addDoc(Document) - Method in class org.elasticsearch.index.mapper.ParseContext
 
addDynamicSettings(String...) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
addDynamicSettings(String...) - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
added() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
addedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
addElement(E) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.addElement(E)
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.
addExposureBuilder(ExposureBuilder<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
 
addFacet(AbstractFacetBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Adds a facet to the search operation.
addFacetProcessor(Class<? extends FacetProcessor>) - Method in class org.elasticsearch.search.facet.FacetModule
 
addFailedEngineListener(Engine.FailedEngineListener) - Method in interface org.elasticsearch.index.engine.Engine
 
addFailedEngineListener(Engine.FailedEngineListener) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
addFailure(String) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
addField(String, String, Analyzer) - Method in class org.apache.lucene.index.memory.CustomMemoryIndex
Convenience method; Tokenizes the given field text and adds the resulting terms to the index; Equivalent to adding an indexed non-keyword Lucene Field that is tokenized, not stored, termVectorStored with positions (or termVectorStored with positions and offsets),
addField(String, TokenStream) - Method in class org.apache.lucene.index.memory.CustomMemoryIndex
Equivalent to addField(fieldName, stream, 1.0f).
addField(String, TokenStream, float) - Method in class org.apache.lucene.index.memory.CustomMemoryIndex
Iterates over the given token stream and adds the resulting terms to the index; Equivalent to adding a tokenized, indexed, termVectorStored, unstored, Lucene Field.
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.
addFieldMapper(FieldMapper) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
addFieldMapperListener(FieldMapperListener, boolean) - 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.
addFilter(SettingsFilter.Filter) - Method in class org.elasticsearch.common.settings.SettingsFilter
 
addFilterFacetAndGlobal(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.AbstractFacetBuilder
 
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(E) - Method in class jsr166y.ConcurrentLinkedDeque
Inserts the specified element at the front of this deque.
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
 
addGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
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.
addHostsProvider(UnicastHostsProvider) - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
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.
addIfAbsent(E) - Method in class jsr166e.extra.ReadMostlyVector
Appends the element, if not present.
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
 
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
 
additionalSettings() - Method in class org.elasticsearch.plugins.AbstractPlugin
 
additionalSettings() - Method in interface org.elasticsearch.plugins.Plugin
Additional node settings loaded by the plugin
addLast(E) - Method in class jsr166y.ConcurrentLinkedDeque
Inserts the specified element at the end of this deque.
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(Runnable) - Method in interface org.elasticsearch.action.ListenableActionFuture
Add an action listener (runnable) to be invoked when a response has received.
addListener(ActionListener<T>) - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
 
addListener(Runnable) - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
 
addListener() - Method in enum org.elasticsearch.action.ThreadingModel
 
addListener(InitialStateDiscoveryListener) - Method in interface org.elasticsearch.discovery.Discovery
 
addListener(InitialStateDiscoveryListener) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
addListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
addListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
 
addListener(InitialStateDiscoveryListener) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
addListener(IndexingOperationListener) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
addListener(IndexSettingsService.Listener) - Method in class org.elasticsearch.index.settings.IndexSettingsService
 
addListener(IndicesLifecycle.Listener) - Method in interface org.elasticsearch.indices.IndicesLifecycle
Add a listener.
addListener(IndicesLifecycle.Listener) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
addListener(IndicesWarmer.Listener) - Method in interface org.elasticsearch.indices.warmer.IndicesWarmer
 
addListener(IndicesWarmer.Listener) - Method in class org.elasticsearch.indices.warmer.InternalIndicesWarmer
 
addListener(NodeSettingsService.Listener) - Method in class org.elasticsearch.node.settings.NodeSettingsService
 
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, 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, 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.
addMessage(String, Object...) - Method in class org.elasticsearch.common.inject.internal.Errors
 
addMessage(Message) - Method in class org.elasticsearch.common.inject.internal.Errors
 
addMust(Filter) - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
addNamedFilter(String, Filter) - Method in class org.elasticsearch.index.query.QueryParseContext
 
addNestedQuery(String, BlockJoinQuery) - Method in class org.elasticsearch.search.internal.SearchContext
 
addNot(Filter) - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
addObjectMapper(ObjectMapper) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
addObjectMapperListener(ObjectMapperListener, boolean) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
addOperation() - Method in enum org.elasticsearch.action.ThreadingModel
 
addParam(String, Object) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
 
addPartialField(String, String, String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Adds a partial field based on _source, with an "include" and/or "exclude" set which can include simple wildcard elements.
addPartialField(String, String[], String[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Adds a partial field based on _source, with an "includes" and/or "excludes set which can include simple wildcard elements.
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
 
addProcessor(AnalysisModule.AnalysisBinderProcessor) - Method in class org.elasticsearch.index.analysis.AnalysisModule
 
addProcessor(IndexQueryParserModule.QueryParsersProcessor) - Method in class org.elasticsearch.index.query.IndexQueryParserModule
 
addQueries(Map<String, Query>) - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
addQuery(String, QueryBuilder) - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
addQuery(String, BytesReference) - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
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(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.
addRemovalListener(String, RemovalListener<WeightedFilterCache.FilterCacheKey, DocSet>) - Method in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
addReplica() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
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
 
addScopePhase(ScopePhase) - Method in class org.elasticsearch.search.internal.SearchContext
 
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.
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.
addShard(ShardRouting, boolean) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
addShard(ImmutableShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
addShardFailure(ShardSearchFailure) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
addShould(Filter) - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
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.
addStringToArray(String[], String) - Static method in class org.elasticsearch.common.Strings
Append the given String to the given String array, returning a new array consisting of the input array contents plus the given String.
addTerm(Term) - Method in class org.apache.lucene.search.PublicTermsFilter
Adds a term to the list of acceptable terms
addText(String, String, float) - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
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
 
addToPendingCount(int) - Method in class jsr166y.CountedCompleter
Adds (atomically) the given value to the pending count.
addTranslogOperations(int) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Translog
 
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
 
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(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
 
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.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.AllDocSet.AllDocIdSetIterator
 
advance(int) - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.NotDocIdSetIterator
 
advance(int) - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet.OrDocIdSetIterator
 
advance(int) - Method in class org.elasticsearch.common.lucene.docset.OrDocSet.OrDocIdSetIterator
 
advance(int) - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
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 interface org.elasticsearch.common.component.LifecycleListener
 
afterIndexClosed(Index, boolean) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called after the index has been closed.
afterIndexClosed(Index, boolean) - 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
 
afterIndexShardClosed(ShardId, boolean) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called after the index shard has been closed.
afterIndexShardClosed(ShardId, boolean) - 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
 
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.
afterStart() - Method in interface org.elasticsearch.common.component.LifecycleListener
 
afterStop() - Method in interface org.elasticsearch.common.component.LifecycleListener
 
afterUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
AggregatedDfs - Class in org.elasticsearch.search.dfs
 
AggregatedDfs(TObjectIntHashMap<Term>, long) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
 
aggregateDfs(Iterable<DfsSearchResult>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
aggregator - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
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 - Class in org.elasticsearch.cluster.metadata
 
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
 
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.MetaData
 
aliasesService() - Method in interface org.elasticsearch.index.service.IndexService
 
aliasesService() - Method in class org.elasticsearch.index.service.InternalIndexService
 
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.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
 
AliasMetaData.Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
 
AliasMetaData.Builder(AliasMetaData) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
 
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.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 method in class org.elasticsearch.index.mapper.MapperBuilders
 
ALL_NODES - Static variable in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
allActiveShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
allAssignedShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
AllButSourceFieldSelector - Class in org.elasticsearch.index.mapper.selector
A field selector that loads all fields except the source field.
AllButSourceFieldSelector() - Constructor for class org.elasticsearch.index.mapper.selector.AllButSourceFieldSelector
 
AllDocSet - Class in org.elasticsearch.common.lucene.docset
An always positive
AllDocSet(int) - Constructor for class org.elasticsearch.common.lucene.docset.AllDocSet
 
AllDocSet.AllDocIdSetIterator - Class in org.elasticsearch.common.lucene.docset
 
AllDocSet.AllDocIdSetIterator(int) - Constructor for class org.elasticsearch.common.lucene.docset.AllDocSet.AllDocIdSetIterator
 
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.Entry - Class in org.elasticsearch.common.lucene.all
 
AllEntries.Entry(String, FastStringReader, float) - Constructor for class org.elasticsearch.common.lucene.all.AllEntries.Entry
 
allFailures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
AllField - Class in org.elasticsearch.common.lucene.all
 
AllField(String, Field.Store, Field.TermVector, AllEntries, Analyzer) - 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, Field.Store, Field.TermVector, boolean, FieldInfo.IndexOptions, NamedAnalyzer, NamedAnalyzer, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
AllFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
AllFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper.Builder
 
AllFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
AllFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper.Defaults
 
AllFieldMapper.IncludeInAll - Interface in org.elasticsearch.index.mapper.internal
 
AllFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
AllFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.AllFieldMapper.TypeParser
 
allocate(ByteBufferAllocator.Type) - Method in interface org.apache.lucene.store.bytebuffer.ByteBufferAllocator
Allocate a byte buffer for the specific type.
allocate(ByteBufferAllocator.Type) - Method in class org.apache.lucene.store.bytebuffer.CachingByteBufferAllocator
 
allocate(ByteBufferAllocator.Type) - Method in class org.apache.lucene.store.bytebuffer.PlainByteBufferAllocator
 
allocate(ByteBufferAllocator.Type) - Method in class org.elasticsearch.cache.memory.ByteBufferCache
 
allocate() - Method in enum org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider.Decision
 
allocated() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
allocateDangled(IndexMetaData[], LocalAllocateDangledIndices.Listener) - Method in class org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices
 
allocatedPostApi() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Has this shard group primary shard been allocated post API creation.
allocateLongs(int) - Method in class org.elasticsearch.common.lab.LongsLAB
Allocate a slice of the given length.
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
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.blobstore.BlobReuseExistingGatewayAllocator
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.local.LocalGatewayAllocator
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.none.NoneGatewayAllocator
 
AllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
A pluggable logic allowing to control if allocation of a shard is allowed on a specific node.
AllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
 
AllocationDecider.Decision - Enum in org.elasticsearch.cluster.routing.allocation.decider
 
AllocationDeciders - Class in org.elasticsearch.cluster.routing.allocation.decider
Holds several AllocationDeciders and combines them into a single allocation decision.
AllocationDeciders(Settings, NodeSettingsService) - 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
 
AllocationDecidersModule(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecidersModule
 
allocationExplanation() - Method in class org.elasticsearch.cluster.ClusterState
 
allocationExplanation(AllocationExplanation) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
AllocationExplanation - Class in org.elasticsearch.cluster.routing.allocation
 
AllocationExplanation() - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
 
AllocationExplanation.NodeExplanation - Class in org.elasticsearch.cluster.routing.allocation
 
AllocationExplanation.NodeExplanation(DiscoveryNode, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationExplanation.NodeExplanation
 
AllocationModule - Class in org.elasticsearch.cluster.routing.allocation
 
AllocationModule(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationModule
 
AllocationService - Class in org.elasticsearch.cluster.routing.allocation
 
AllocationService() - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
 
AllocationService(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
 
AllocationService(Settings, AllocationDeciders, ShardsAllocators) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
 
allowLeadingWildcard() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
allowLeadingWildcard(boolean) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
allowLeadingWildcard(boolean) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
Should leading wildcards be allowed or not.
allowLeadingWildcard(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Should leading wildcards be allowed or not.
allowsNull(Annotation[]) - Static method in class org.elasticsearch.common.inject.internal.Nullability
 
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
 
allPrimaryShardsUnassigned() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
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(Term, boolean) - Constructor for class org.elasticsearch.common.lucene.all.AllTermQuery
 
AllTermQuery.AllTermWeight - Class in org.elasticsearch.common.lucene.all
 
AllTermQuery.AllTermWeight(AllTermQuery, Searcher) - Constructor for class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight
 
AllTermQuery.AllTermWeight.AllTermSpanScorer - Class in org.elasticsearch.common.lucene.all
 
AllTermQuery.AllTermWeight.AllTermSpanScorer(TermSpans, Weight, Similarity, byte[]) - Constructor for class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
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.
AllTokenStream - Class in org.elasticsearch.common.lucene.all
 
allTokenStream(String, AllEntries, Analyzer) - Static method in class org.elasticsearch.common.lucene.all.AllTokenStream
 
allValidationFailures() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
All the validation failures, including index level validation failures.
ALPHA - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
ALPHANUM - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
AlreadyExpiredException - Exception in org.elasticsearch.index
 
AlreadyExpiredException(String, String, String, long, long, long) - Constructor for exception org.elasticsearch.index.AlreadyExpiredException
 
ALWAYS_INSTANCE - Static variable in enum org.elasticsearch.index.search.geo.GeoDistance
 
ambiguousTypeConversion(String, Object, TypeLiteral<?>, MatcherAndConverter, MatcherAndConverter) - Method in class org.elasticsearch.common.inject.internal.Errors
 
Analysis - Class in org.elasticsearch.index.analysis
 
Analysis() - Constructor for class org.elasticsearch.index.analysis.Analysis
 
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() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
 
AnalysisModule.AnalysisBinderProcessor.AnalyzersBindings - Class in org.elasticsearch.index.analysis
 
AnalysisModule.AnalysisBinderProcessor.AnalyzersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.AnalyzersBindings
 
AnalysisModule.AnalysisBinderProcessor.CharFiltersBindings - Class in org.elasticsearch.index.analysis
 
AnalysisModule.AnalysisBinderProcessor.CharFiltersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.CharFiltersBindings
 
AnalysisModule.AnalysisBinderProcessor.TokenFiltersBindings - Class in org.elasticsearch.index.analysis
 
AnalysisModule.AnalysisBinderProcessor.TokenFiltersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.TokenFiltersBindings
 
AnalysisModule.AnalysisBinderProcessor.TokenizersBindings - Class in org.elasticsearch.index.analysis
 
AnalysisModule.AnalysisBinderProcessor.TokenizersBindings() - Constructor for class org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor.TokenizersBindings
 
AnalysisService - Class in org.elasticsearch.index.analysis
 
AnalysisService(Index) - 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.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.query.QueryParseContext
 
analysisService() - Method in interface org.elasticsearch.index.service.IndexService
 
analysisService() - Method in class org.elasticsearch.index.service.InternalIndexService
 
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
 
AnalyzeAction - Class in org.elasticsearch.action.admin.indices.analyze
 
analyzed() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
analyzed() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
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.Create
 
analyzer() - Method in class org.elasticsearch.index.engine.Engine.Index
 
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.ParsedDocument
 
analyzer(String) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
The optional analyzer used to analyze the query string.
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
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 - Variable in class org.elasticsearch.index.search.MatchQuery
 
analyzer(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
 
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
 
AnalyzeResponse.AnalyzeToken(String, int, int, int, String) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
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.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.AnalyzerMapper.Builder
 
AnalyzerMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
AnalyzerMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.AnalyzerMapper.Defaults
 
AnalyzerMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
AnalyzerMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.AnalyzerMapper.TypeParser
 
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
 
AnalyzerScope - Enum in org.elasticsearch.index.analysis
 
analyzeWildcard() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
analyzeWildcard(boolean) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
analyzeWildcard(boolean) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
Set to true to enable analysis on wildcard and prefix queries.
analyzeWildcard(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Set to true to enable analysis on wildcard and prefix queries.
and(Matcher<? super T>) - Method in class org.elasticsearch.common.inject.matcher.AbstractMatcher
 
and(Matcher<? super T>) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
Returns a new matcher which returns true if both this and the given matcher return true.
and(FixedBitSet, DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocSets
 
AndDocIdSet - Class in org.elasticsearch.common.lucene.docset
 
AndDocIdSet(List<DocIdSet>) - Constructor for class org.elasticsearch.common.lucene.docset.AndDocIdSet
 
AndDocSet - Class in org.elasticsearch.common.lucene.docset
 
AndDocSet(List<DocSet>) - Constructor for class org.elasticsearch.common.lucene.docset.AndDocSet
 
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
 
andNot(FixedBitSet, DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocSets
 
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.
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.
applyFailedShard(ClusterState, 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.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
 
applyFailedShards(FailedRerouteAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
 
applyFailedShards(FailedRerouteAllocation) - Method in class org.elasticsearch.gateway.blobstore.BlobReuseExistingGatewayAllocator
 
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
 
applyRelativePath(String, String) - Static method in class org.elasticsearch.common.Strings
Apply the given relative path to the given path, assuming standard Java folder separation (i.e.
applyStartedShards(ClusterState, List<? extends ShardRouting>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
Applies the started shards.
applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
applyStartedShards(StartedRerouteAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.GatewayAllocator
 
applyStartedShards(StartedRerouteAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
 
applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
 
applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.gateway.blobstore.BlobReuseExistingGatewayAllocator
 
applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.gateway.local.LocalGatewayAllocator
 
applyStartedShards(StartedRerouteAllocation) - Method in class org.elasticsearch.gateway.none.NoneGatewayAllocator
 
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
 
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.mapper.geo.GeoPointDocFieldData
 
arcDistance(int, DistanceUnit, double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
arcDistanceInKm(double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
arcDistanceInKmWithDefault(double, double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
arcDistanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
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.ByteBufferBytesReference
 
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(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.ByteBufferBytesReference
 
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
 
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.
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.
arrive() - Method in class jsr166y.Phaser
Arrives at this phaser, without waiting for others to arrive.
arriveAndAwaitAdvance() - Method in class jsr166y.Phaser
Arrives at this phaser and awaits others.
arriveAndDeregister() - Method in class jsr166y.Phaser
Arrives at this phaser and deregisters from it without waiting for others to arrive.
ASCIIFoldingTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
ASCIIFoldingTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ASCIIFoldingTokenFilterFactory
 
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
 
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
 
asMap() - Method in class org.elasticsearch.search.lookup.SearchLookup
 
assignedReplicasIncludingRelocating() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
assignedReplicasIncludingRelocating() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
assignedShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
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
The shard is assigned to a node.
assignToNode(String) - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
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.
asUnordered() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
asUnordered() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
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
 
atoi(byte[]) - Static method in class org.elasticsearch.common.Bytes
 
atol(byte[]) - Static method in class org.elasticsearch.common.Bytes
 
AtomicDouble - Class in jsr166e.extra
A double value that may be updated atomically.
AtomicDouble(double) - Constructor for class jsr166e.extra.AtomicDouble
Creates a new AtomicDouble with the given initial value.
AtomicDouble() - Constructor for class jsr166e.extra.AtomicDouble
Creates a new AtomicDouble with initial value 0.0.
AtomicDoubleArray - Class in jsr166e.extra
A double array in which elements may be updated atomically.
AtomicDoubleArray(int) - Constructor for class jsr166e.extra.AtomicDoubleArray
Creates a new AtomicDoubleArray of the given length, with all elements initially zero.
AtomicDoubleArray(double[]) - Constructor for class jsr166e.extra.AtomicDoubleArray
Creates a new AtomicDoubleArray with the same length as, and all elements copied from, the given array.
attemptFails() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
attributes() - Method in class org.elasticsearch.action.search.type.ParsedScrollId
 
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).
autoGeneratePhraseQueries() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
autoGeneratePhraseQueries(boolean) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
autoGeneratePhraseQueries(boolean) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
Set to true if phrase queries will be automatically generated when the analyzer returns more than one term from whitespace delimited text.
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.
available() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
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 - Static variable in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappy
 
available() - Method in class org.elasticsearch.common.io.FastByteArrayInputStream
Returns the number of remaining bytes that can be read (or skipped over) from this input 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.monitor.fs.FsStats.Info
 
available() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
await() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
 
await(long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
 
awaitAdvance(int) - Method in class jsr166y.Phaser
Awaits the phase of this phaser to advance from the given phase value, returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitAdvanceInterruptibly(int) - Method in class jsr166y.Phaser
Awaits the phase of this phaser to advance from the given phase value, throwing InterruptedException if interrupted while waiting, or returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitAdvanceInterruptibly(int, long, TimeUnit) - Method in class jsr166y.Phaser
Awaits the phase of this phaser to advance from the given phase value or the given timeout to elapse, throwing InterruptedException if interrupted while waiting, or returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitAvailability() - Method in class jsr166e.SequenceLock
Returns the current sequence number when the lock is, or becomes, available.
awaitTermination(long, TimeUnit) - Method in class jsr166y.ForkJoinPool
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.threadpool.ThreadPool
 
AwarenessAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
 
AwarenessAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
 
AwarenessAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
 
AwarenessAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
 
awarenessAttributes() - Method in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
 

B

backingStoreFreeSpace() - Method in class org.elasticsearch.index.store.fs.FsIndexStore
 
backingStoreFreeSpace() - Method in interface org.elasticsearch.index.store.IndexStore
Returns the backing store free space.
backingStoreFreeSpace() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexStore
 
backingStoreFreeSpace() - Method in class org.elasticsearch.index.store.ram.RamIndexStore
 
backingStoreTotalSpace() - Method in class org.elasticsearch.index.store.fs.FsIndexStore
 
backingStoreTotalSpace() - Method in interface org.elasticsearch.index.store.IndexStore
Returns the backing store total space.
backingStoreTotalSpace() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexStore
 
backingStoreTotalSpace() - Method in class org.elasticsearch.index.store.ram.RamIndexStore
 
Base64 - Class in org.elasticsearch.common
Encodes and decodes to and from Base64 notation.
Base64.InputStream - Class in org.elasticsearch.common
A Base64.InputStream will read data from another java.io.InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.InputStream(InputStream) - Constructor for class org.elasticsearch.common.Base64.InputStream
Constructs a Base64.InputStream in DECODE mode.
Base64.InputStream(InputStream, int) - Constructor for class org.elasticsearch.common.Base64.InputStream
Constructs a Base64.InputStream in either ENCODE or DECODE mode.
Base64.OutputStream - Class in org.elasticsearch.common
A Base64.OutputStream will write data to another java.io.OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.OutputStream(OutputStream) - Constructor for class org.elasticsearch.common.Base64.OutputStream
Constructs a Base64.OutputStream in ENCODE mode.
Base64.OutputStream(OutputStream, int) - Constructor for class org.elasticsearch.common.Base64.OutputStream
Constructs a Base64.OutputStream in either ENCODE or DECODE mode.
baseBlockSize - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
BaseClusterRequestBuilder<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.admin.cluster.support
 
BaseClusterRequestBuilder(ClusterAdminClient, Request) - Constructor for class org.elasticsearch.action.admin.cluster.support.BaseClusterRequestBuilder
 
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
 
BaseIndicesRequestBuilder<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.admin.indices.support
 
BaseIndicesRequestBuilder(IndicesAdminClient, Request) - Constructor for class org.elasticsearch.action.admin.indices.support.BaseIndicesRequestBuilder
 
basePath() - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
BaseQueryBuilder - Class in org.elasticsearch.index.query
 
BaseQueryBuilder() - Constructor for class org.elasticsearch.index.query.BaseQueryBuilder
 
BaseRequestBuilder<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support
 
BaseRequestBuilder(Client, Request) - Constructor for class org.elasticsearch.action.support.BaseRequestBuilder
 
BaseRestHandler - Class in org.elasticsearch.rest
 
BaseRestHandler(Settings, Client) - Constructor for class org.elasticsearch.rest.BaseRestHandler
 
BaseTransportRequestHandler<T extends Streamable> - Class in org.elasticsearch.transport
A simple based class that always spawns.
BaseTransportRequestHandler() - Constructor for class org.elasticsearch.transport.BaseTransportRequestHandler
 
BaseTransportResponseHandler<T extends Streamable> - 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
 
BATCH_ENUM_DOCS - Static variable in class org.elasticsearch.common.lucene.Lucene
 
beforeBulk(long, BulkRequest) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
Callback before the bulk is executed.
beforeClose() - Method in interface org.elasticsearch.common.component.LifecycleListener
 
beforeFieldAdded(FieldMapper, Fieldable, ParseContext) - Method in interface org.elasticsearch.index.mapper.DocumentMapper.ParseListener
Called before a field is added to the document.
beforeFieldAdded(FieldMapper, Fieldable, Object) - Method in class org.elasticsearch.index.mapper.DocumentMapper.ParseListenerAdapter
 
beforeIndexClosed(IndexService, boolean) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index get closed.
beforeIndexClosed(IndexService, boolean) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexCreated(Index) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index gets created.
beforeIndexCreated(Index) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexShardClosed(ShardId, IndexShard, boolean) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index shard gets closed.
beforeIndexShardClosed(ShardId, IndexShard, boolean) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
beforeIndexShardCreated(ShardId) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index shard gets created.
beforeIndexShardCreated(ShardId) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
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.search.SearchRequest
Internal.
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
 
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.search.SearchRequest
 
beforeStart() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
beforeStart() - Method in interface org.elasticsearch.common.component.LifecycleListener
 
beforeStop() - Method in interface 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
BigLongArray - Class in org.elasticsearch.common.util
A GC friendly long[].
BigLongArray(int) - Constructor for class org.elasticsearch.common.util.BigLongArray
 
BigLongArray(int, int) - Constructor for class org.elasticsearch.common.util.BigLongArray
 
binaryField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
BinaryFieldMapper - Class in org.elasticsearch.index.mapper.core
 
BinaryFieldMapper(FieldMapper.Names, Field.Store, Boolean, long) - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
BinaryFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
BinaryFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Builder
 
BinaryFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
BinaryFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Defaults
 
BinaryFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
BinaryFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.BinaryFieldMapper.TypeParser
 
binaryValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
binaryValue() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
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
 
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
 
binomialCoefficient(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns an exact representation of the Binomial Coefficient, "n choose k", the number of k-element subsets that can be selected from an n-element set.
binomialCoefficientDouble(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns a double representation of the Binomial Coefficient, "n choose k", the number of k-element subsets that can be selected from an n-element set.
binomialCoefficientLog(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the natural log of the Binomial Coefficient, "n choose k", the number of k-element subsets that can be selected from an n-element set.
BlobContainer - Interface in org.elasticsearch.common.blobstore
 
blobContainer - Variable in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
BlobContainer.BlobNameFilter - Interface in org.elasticsearch.common.blobstore
 
BlobContainer.ReadBlobListener - 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.AbstractFsBlobContainer
 
BlobMetaData - Interface in org.elasticsearch.common.blobstore
 
BlobPath - Class in org.elasticsearch.common.blobstore
 
BlobPath() - Constructor for class org.elasticsearch.common.blobstore.BlobPath
 
BlobReuseExistingGatewayAllocator - Class in org.elasticsearch.gateway.blobstore
 
BlobReuseExistingGatewayAllocator(Settings, Node, TransportNodesListShardStoreMetaData) - Constructor for class org.elasticsearch.gateway.blobstore.BlobReuseExistingGatewayAllocator
 
BlobStore - Interface in org.elasticsearch.common.blobstore
 
blobStore - Variable in class org.elasticsearch.common.blobstore.fs.AbstractFsBlobContainer
 
blobStore() - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
blobStore() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexGateway
 
blobStore - Variable in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
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
 
BlobStoreGateway - Class in org.elasticsearch.gateway.blobstore
 
BlobStoreGateway(Settings, ThreadPool, ClusterService) - Constructor for class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
BlobStoreGatewayModule - Class in org.elasticsearch.gateway.blobstore
 
BlobStoreGatewayModule() - Constructor for class org.elasticsearch.gateway.blobstore.BlobStoreGatewayModule
 
BlobStoreIndexGateway - Class in org.elasticsearch.index.gateway.blobstore
 
BlobStoreIndexGateway(Index, Settings, Gateway) - Constructor for class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexGateway
 
BlobStoreIndexShardGateway - Class in org.elasticsearch.index.gateway.blobstore
 
BlobStoreIndexShardGateway(ShardId, Settings, ThreadPool, IndexGateway, IndexShard, Store) - Constructor for class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
BlobStores - Class in org.elasticsearch.common.blobstore.support
 
BlobStores() - Constructor for class org.elasticsearch.common.blobstore.support.BlobStores
 
block() - Method in interface jsr166y.ForkJoinPool.ManagedBlocker
Possibly blocks the current thread, for example waiting for a lock or condition.
BlockJoinQuery - Class in org.elasticsearch.index.search.nested
This query requires that you index children and parent docs as a single block, using the IndexWriter.addDocuments(java.util.Collection) or IndexWriter.updateDocuments(org.apache.lucene.index.Term, java.util.Collection) API.
BlockJoinQuery(Query, Filter, BlockJoinQuery.ScoreMode) - Constructor for class org.elasticsearch.index.search.nested.BlockJoinQuery
 
BlockJoinQuery.ScoreMode - Enum in org.elasticsearch.index.search.nested
 
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(Set<ClusterBlock>) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Request
 
blocks() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
blocksChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
bloomCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
bloomCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
BloomCache - Interface in org.elasticsearch.index.cache.bloom
 
bloomCache() - Method in class org.elasticsearch.index.cache.IndexCache
 
BloomCacheModule - Class in org.elasticsearch.index.cache.bloom
 
BloomCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.bloom.BloomCacheModule
 
BloomCacheModule.BloomCacheSettings - Class in org.elasticsearch.index.cache.bloom
 
BloomCacheModule.BloomCacheSettings() - Constructor for class org.elasticsearch.index.cache.bloom.BloomCacheModule.BloomCacheSettings
 
BloomFilter - Interface in org.elasticsearch.common.bloom
 
BloomFilterFactory - Class in org.elasticsearch.common.bloom
 
BloomFilterFactory() - Constructor for class org.elasticsearch.common.bloom.BloomFilterFactory
 
bloomSize() - Method in class org.elasticsearch.index.cache.CacheStats
 
bloomSizeInBytes() - Method in class org.elasticsearch.index.cache.CacheStats
 
booleanField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
BooleanFieldMapper - Class in org.elasticsearch.index.mapper.core
 
BooleanFieldMapper(FieldMapper.Names, Field.Index, Field.Store, Field.TermVector, float, boolean, FieldInfo.IndexOptions, Boolean) - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
BooleanFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
BooleanFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
BooleanFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
BooleanFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Defaults
 
BooleanFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
BooleanFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.BooleanFieldMapper.TypeParser
 
Booleans - Class in org.elasticsearch.common
 
Booleans() - Constructor for class org.elasticsearch.common.Booleans
 
BooleanStreamable - Class in org.elasticsearch.common.io
 
BooleanStreamable() - Constructor for class org.elasticsearch.common.io.BooleanStreamable
 
BooleanStreamable(boolean) - Constructor for class org.elasticsearch.common.io.BooleanStreamable
 
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.QueryParserSettings
 
boost(float) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
boost() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
 
boost(float) - Method in class org.elasticsearch.common.lucene.DocumentBuilder
 
boost(float) - Method in class org.elasticsearch.common.lucene.FieldBuilder
 
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(float) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
boost(float) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
boost(float) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
 
boost() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
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.ConstantScoreQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.CustomScoreQueryBuilder
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.FieldQueryBuilder
Sets the boost for this query.
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.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
 
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.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
 
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.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.
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.CustomBoostFactorQueryBuilder
Sets the boost factor for this query.
BoostFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
BoostFieldMapper() - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
BoostFieldMapper(String, String) - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
BoostFieldMapper(String, String, int, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, Float) - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
BoostFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
BoostFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Builder
 
BoostFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
BoostFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Defaults
 
BoostFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
BoostFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.BoostFieldMapper.TypeParser
 
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
 
boosts() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
boosts(TObjectFloatHashMap<String>) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
BoostScoreFunction - Class in org.elasticsearch.common.lucene.search.function
 
BoostScoreFunction(float) - Constructor for class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
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
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
 
bottomRight(double, double) - Method in class org.elasticsearch.common.geo.ShapeBuilder.RectangleBuilder
Sets the bottom right point of the Rectangle
bottomRight(double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
Adds bottom right point.
bottomRight(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
bottomRight() - Method in interface org.elasticsearch.index.search.geo.GeoDistance.DistanceBoundingCheck
 
bottomRight() - Method in class org.elasticsearch.index.search.geo.GeoDistance.Meridian180DistanceBoundingCheck
 
bottomRight() - Method in class org.elasticsearch.index.search.geo.GeoDistance.SimpleDistanceBoundingCheck
 
bottomRight() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
boundAddress() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
 
boundAddress() - Method in interface org.elasticsearch.http.HttpServerTransport
 
boundAddress() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
boundAddress() - Method in class org.elasticsearch.transport.local.LocalTransport
 
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 - Variable in class org.elasticsearch.common.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
boundaryChars() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
boundaryChars(char[]) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
boundaryMaxScan() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
boundaryMaxScan(int) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
BoundedCountHistogramFacetCollector - Class in org.elasticsearch.search.facet.histogram.bounded
 
BoundedCountHistogramFacetCollector(String, String, long, long, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.BoundedCountHistogramFacetCollector
 
BoundedCountHistogramFacetCollector.HistogramProc - Class in org.elasticsearch.search.facet.histogram.bounded
 
BoundedCountHistogramFacetCollector.HistogramProc(long, long, long, long, int) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.BoundedCountHistogramFacetCollector.HistogramProc
 
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
 
BoundedValueHistogramFacetCollector - Class in org.elasticsearch.search.facet.histogram.bounded
 
BoundedValueHistogramFacetCollector(String, String, String, long, long, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.BoundedValueHistogramFacetCollector
 
BoundedValueHistogramFacetCollector.HistogramProc - Class in org.elasticsearch.search.facet.histogram.bounded
 
BoundedValueHistogramFacetCollector.HistogramProc(long, long, long, long, int) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.BoundedValueHistogramFacetCollector.HistogramProc
 
BoundedValueHistogramFacetCollector.HistogramProc.ValueAggregator - Class in org.elasticsearch.search.facet.histogram.bounded
 
BoundedValueHistogramFacetCollector.HistogramProc.ValueAggregator() - Constructor for class org.elasticsearch.search.facet.histogram.bounded.BoundedValueHistogramFacetCollector.HistogramProc.ValueAggregator
 
BoundedValueScriptHistogramFacetCollector - Class in org.elasticsearch.search.facet.histogram.bounded
 
BoundedValueScriptHistogramFacetCollector(String, String, String, String, Map<String, Object>, long, long, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.BoundedValueScriptHistogramFacetCollector
 
BoundedValueScriptHistogramFacetCollector.HistogramProc - Class in org.elasticsearch.search.facet.histogram.bounded
 
BoundedValueScriptHistogramFacetCollector.HistogramProc(long, long, long, long, int, SearchScript) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.BoundedValueScriptHistogramFacetCollector.HistogramProc
 
bounds(Object, Object) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
Sets the bounds from and to for the facet.
bounds(Object, Object) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
Sets the bounds from and to for the facet.
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
 
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 - Class in org.elasticsearch.action.support.broadcast
 
BroadcastOperationRequest() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
BroadcastOperationRequest(String[]) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
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
 
BroadcastOperationThreading - Enum in org.elasticsearch.action.support.broadcast
Controls the operation threading model for broadcast operation that are performed locally on the executing node.
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(String, int) - 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(String, int) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardOperationResponse
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueScriptHistogramFacetCollector
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.unbounded.CountHistogramFacetCollector
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.unbounded.FullHistogramFacetCollector
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.unbounded.ScriptHistogramFacetCollector
 
bucket(double, long) - Static method in class org.elasticsearch.search.facet.histogram.unbounded.ValueScriptHistogramFacetCollector
 
buf - Variable in class org.elasticsearch.common.io.FastByteArrayInputStream
An array of bytes that was provided by the creator of the stream.
buf - Variable in class org.elasticsearch.common.io.FastByteArrayOutputStream
The buffer where data is stored.
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
 
buf - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
The buffer where data is stored.
BUFFER_SIZE - Static variable in class org.elasticsearch.common.io.Streams
 
BufferedChecksumIndexOutput - Class in org.elasticsearch.common.lucene.store
 
BufferedChecksumIndexOutput(IndexOutput, Checksum) - Constructor for class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
BufferingFsTranslogFile - Class in org.elasticsearch.index.translog.fs
 
BufferingFsTranslogFile(ShardId, long, RafReference, int) - Constructor for class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
bufferSizeInBytes() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
build() - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
Builds a new bulk processor.
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.geo.ShapeBuilder.PolygonBuilder
Builds a Shape instance representing the polygon
build() - Method in class org.elasticsearch.common.geo.ShapeBuilder.RectangleBuilder
Builds the Rectangle instance
build() - Method in class org.elasticsearch.common.joda.TimeZoneRounding.Builder
 
build() - Method in class org.elasticsearch.common.lucene.DocumentBuilder
 
build() - Method in class org.elasticsearch.common.lucene.FieldBuilder
 
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(AnalysisService) - Method in class org.elasticsearch.index.analysis.CustomAnalyzerProvider
 
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.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.ShortFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.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.GeoPointFieldMapper.GeoStringFieldMapper.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.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.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.multifield.MultiFieldMapper.Builder
 
build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
build() - Method in interface org.elasticsearch.index.store.DirectoryService
 
build() - Method in class org.elasticsearch.index.store.fs.MmapFsDirectoryService
 
build() - Method in class org.elasticsearch.index.store.fs.NioFsDirectoryService
 
build() - Method in class org.elasticsearch.index.store.fs.SimpleFsDirectoryService
 
build() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectoryService
 
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.river.cluster.RiverClusterState.Builder
 
build() - Method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
build - Variable in class org.elasticsearch.Version
 
buildAsBytes(XContentType) - Method in class org.elasticsearch.action.explain.ExplainSourceBuilder
 
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.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
 
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
 
buildDynamicNodes() - Method in interface org.elasticsearch.discovery.zen.ping.unicast.UnicastHostsProvider
Builds the dynamic list of unicast hosts to be used for unicast discovery.
builder(Client, BulkProcessor.Listener) - Static method in class org.elasticsearch.action.bulk.BulkProcessor
 
builder() - Static method in class org.elasticsearch.cluster.block.ClusterBlocks
 
builder() - Static method in class org.elasticsearch.cluster.ClusterState
 
builder(String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
builder(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
builder(String) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
builder() - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
builder() - Static method in class org.elasticsearch.cluster.routing.RoutingTable
 
builder(DateTimeField) - Static method in class org.elasticsearch.common.joda.TimeZoneRounding
 
builder(TimeValue) - Static method in class org.elasticsearch.common.joda.TimeZoneRounding
 
builder(XContent) - Static method in class org.elasticsearch.common.xcontent.XContentBuilder
Constructs a new builder using a fresh FastByteArrayOutputStream.
builder - Variable in class org.elasticsearch.index.mapper.Mapper.Builder
 
builder() - Method in class org.elasticsearch.rest.XContentRestResponse
 
builder() - Static method in class org.elasticsearch.river.cluster.RiverClusterState
 
builder() - Static method in class org.elasticsearch.river.routing.RiversRouting
 
buildFailureMessage() - Method in class org.elasticsearch.action.bulk.BulkResponse
 
buildFieldDataMap() - Method in class org.elasticsearch.index.cache.field.data.resident.ResidentFieldDataCache
 
buildFieldDataMap() - Method in class org.elasticsearch.index.cache.field.data.soft.SoftFieldDataCache
 
buildFieldDataMap() - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
buildFromKeyValue(Map<String, String>) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
 
buildFromSettings(String, Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
 
buildFullName(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
buildIndexGroupName(Index) - Static method in class org.elasticsearch.index.IndexServiceManagement
 
buildIndexName(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
buildLockFactory() - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
buildMultiValue(String, int[][]) - Method in interface org.elasticsearch.index.field.data.support.FieldDataLoader.TypeLoader
 
buildNames(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
buildRequest(CachedStreamOutput.Entry, long, String, Streamable, TransportRequestOptions) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
buildResponse(CachedStreamOutput.Entry, long, Streamable, TransportResponseOptions) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
buildScrollId(SearchType, Collection<? extends SearchPhaseResult>, Map<String, String>) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
buildScrollId(String, Collection<? 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
 
buildShardGroupName(ShardId) - Static method in class org.elasticsearch.index.shard.IndexShardManagement
 
buildSingleValue(String, int[]) - Method in interface org.elasticsearch.index.field.data.support.FieldDataLoader.TypeLoader
 
buildText() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
buildTookInMillis() - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
Builds how long it took to execute the search.
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.
BulkItemResponse.Failure(String, String, String, String) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.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.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.
BulkProcessor.Listener - Interface in org.elasticsearch.action.bulk
A listener for the execution.
bulkRegister(int) - Method in class jsr166y.Phaser
Adds the given number of new unarrived parties to this phaser.
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 - Static variable in class org.elasticsearch.index.field.data.FieldDataType.DefaultTypes
 
byteBuffer() - Method in class org.elasticsearch.cache.NodeCache
 
ByteBufferAllocator - Interface in org.apache.lucene.store.bytebuffer
A byte buffer allocator simple allocates byte buffers, and handles releasing them.
ByteBufferAllocator.Cleaner - Class in org.apache.lucene.store.bytebuffer
Helper class to allocator implementations allowing to clean direct buffers.
ByteBufferAllocator.Cleaner() - Constructor for class org.apache.lucene.store.bytebuffer.ByteBufferAllocator.Cleaner
 
ByteBufferAllocator.Type - Enum in org.apache.lucene.store.bytebuffer
 
ByteBufferBytesReference - Class in org.elasticsearch.common.bytes
 
ByteBufferBytesReference(ByteBuffer) - Constructor for class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
ByteBufferCache - Class in org.elasticsearch.cache.memory
 
ByteBufferCache() - Constructor for class org.elasticsearch.cache.memory.ByteBufferCache
 
ByteBufferCache(int, int, boolean) - Constructor for class org.elasticsearch.cache.memory.ByteBufferCache
 
ByteBufferCache(Settings) - Constructor for class org.elasticsearch.cache.memory.ByteBufferCache
 
ByteBufferDirectory - Class in org.apache.lucene.store.bytebuffer
A memory based directory that uses ByteBuffer in order to store the directory content.
ByteBufferDirectory() - Constructor for class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
Constructs a new directory using PlainByteBufferAllocator.
ByteBufferDirectory(ByteBufferAllocator) - Constructor for class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
Constructs a new byte buffer directory with a custom allocator.
ByteBufferDirectoryService - Class in org.elasticsearch.index.store.memory
 
ByteBufferDirectoryService(ShardId, Settings, IndexStore, ByteBufferCache) - Constructor for class org.elasticsearch.index.store.memory.ByteBufferDirectoryService
 
ByteBufferFile - Class in org.apache.lucene.store.bytebuffer
 
ByteBufferFile(ByteBufferDirectory, int) - Constructor for class org.apache.lucene.store.bytebuffer.ByteBufferFile
 
ByteBufferFileOutput - Class in org.apache.lucene.store.bytebuffer
 
ByteBufferFileOutput(ByteBufferDirectory, int) - Constructor for class org.apache.lucene.store.bytebuffer.ByteBufferFileOutput
 
ByteBufferIndexInput - Class in org.apache.lucene.store.bytebuffer
 
ByteBufferIndexInput(String, ByteBufferFile) - Constructor for class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
ByteBufferIndexOutput - Class in org.apache.lucene.store.bytebuffer
 
ByteBufferIndexOutput(ByteBufferDirectory, String, ByteBufferAllocator, ByteBufferAllocator.Type, ByteBufferFileOutput) - Constructor for class org.apache.lucene.store.bytebuffer.ByteBufferIndexOutput
 
ByteBufferIndexStore - Class in org.elasticsearch.index.store.memory
 
ByteBufferIndexStore(Index, Settings, IndexService, ByteBufferCache, IndicesStore) - Constructor for class org.elasticsearch.index.store.memory.ByteBufferIndexStore
 
ByteBufferStreamInput - Class in org.elasticsearch.common.io.stream
 
ByteBufferStreamInput(ByteBuffer) - Constructor for class org.elasticsearch.common.io.stream.ByteBufferStreamInput
 
ByteDocFieldData - Class in org.elasticsearch.index.field.data.bytes
 
ByteDocFieldData(ByteFieldData) - Constructor for class org.elasticsearch.index.field.data.bytes.ByteDocFieldData
 
byteField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
ByteFieldData - Class in org.elasticsearch.index.field.data.bytes
 
ByteFieldData(String, byte[]) - Constructor for class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
ByteFieldData.ValueInDocProc - Interface in org.elasticsearch.index.field.data.bytes
 
ByteFieldData.ValueProc - Interface in org.elasticsearch.index.field.data.bytes
 
ByteFieldDataComparator - Class in org.elasticsearch.index.field.data.bytes
 
ByteFieldDataComparator(int, String, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.bytes.ByteFieldDataComparator
 
ByteFieldDataMissingComparator - Class in org.elasticsearch.index.field.data.bytes
 
ByteFieldDataMissingComparator(int, String, FieldDataCache, byte) - Constructor for class org.elasticsearch.index.field.data.bytes.ByteFieldDataMissingComparator
 
ByteFieldDataType - Class in org.elasticsearch.index.field.data.bytes
 
ByteFieldDataType() - Constructor for class org.elasticsearch.index.field.data.bytes.ByteFieldDataType
 
ByteFieldMapper - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper(FieldMapper.Names, int, String, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, Byte, boolean) - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
ByteFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.Builder
 
ByteFieldMapper.CustomByteNumericField - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper.CustomByteNumericField(NumberFieldMapper, byte) - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.CustomByteNumericField
 
ByteFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.Defaults
 
ByteFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
ByteFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.ByteFieldMapper.TypeParser
 
Bytes - Class in org.elasticsearch.common
 
Bytes() - Constructor for class org.elasticsearch.common.Bytes
 
bytes() - Method in interface org.elasticsearch.common.io.BytesStream
 
bytes() - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Returns the underlying byte array.
bytes() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
bytes() - Method in class org.elasticsearch.common.io.stream.CachedStreamOutput.Entry
 
bytes(Compressor) - Method in class org.elasticsearch.common.io.stream.CachedStreamOutput.Entry
 
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.XContentBuilder
 
bytes() - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
BYTES_LIMIT - Static variable in class org.elasticsearch.common.io.stream.CachedStreamOutput
 
BytesArray - Class in org.elasticsearch.common.bytes
 
BytesArray(String) - 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
 
bytesEquals(BytesArray) - Method in class org.elasticsearch.common.bytes.BytesArray
 
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
 
BytesReference - Interface in org.elasticsearch.common.bytes
A reference to bytes.
BytesRestResponse - Class in org.elasticsearch.rest
 
BytesRestResponse(byte[], String) - 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
 
BytesStreamOutput() - Constructor for class org.elasticsearch.common.io.stream.BytesStreamOutput
 
BytesStreamOutput(int) - 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.
bytesToFloat(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to float.
bytesToInt(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to an int.
bytesToLong(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to a long.
bytesToShort(byte[]) - Static method in class org.elasticsearch.common.Numbers
Converts a byte array to an short.
byteValue(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
byteValue(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
byteValue(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
byteValue(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
byteValue(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
byteValue(int) - Method in class org.elasticsearch.index.field.data.NumericFieldData
Returns the value of the specified number as a byte.
byteValue(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
BZip2Constants - Interface in org.elasticsearch.common.compress.bzip2
Base class for both the compress and decompress classes.

C

cache(FieldDataType, IndexReader, String) - Method in interface org.elasticsearch.index.cache.field.data.FieldDataCache
 
cache(FieldDataType, IndexReader, String) - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
cache(FieldDataType, IndexReader, String) - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
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(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.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.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
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.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() - Method in interface org.elasticsearch.index.service.IndexService
 
cache() - Method in class org.elasticsearch.index.service.InternalIndexService
 
cache() - Method in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
cache() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
cache() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
CACHE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
cacheable(IndexReader, DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocSets
Returns a cacheable version of the doc id set (might be the same instance provided as a parameter).
CachedDfSource - Class in org.elasticsearch.search.dfs
 
CachedDfSource(AggregatedDfs, Similarity) - Constructor for class org.elasticsearch.search.dfs.CachedDfSource
 
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
 
CachedStreamInput - Class in org.elasticsearch.common.io.stream
 
CachedStreamInput() - Constructor for class org.elasticsearch.common.io.stream.CachedStreamInput
 
CachedStreamOutput - Class in org.elasticsearch.common.io.stream
 
CachedStreamOutput() - Constructor for class org.elasticsearch.common.io.stream.CachedStreamOutput
 
CachedStreamOutput.Entry - Class in org.elasticsearch.common.io.stream
 
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.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.NestedFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
 
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.ScriptFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.TermFilterBuilder
 
cacheKey(String) - Method in class org.elasticsearch.index.query.TermsFilterBuilder
 
CacheKeyFilter - Interface in org.elasticsearch.index.cache.filter.support
 
CacheKeyFilter.Key - Class in org.elasticsearch.index.cache.filter.support
 
CacheKeyFilter.Key(byte[]) - Constructor for class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
CacheKeyFilter.Key(String) - Constructor for class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
CacheKeyFilter.Wrapper - Class in org.elasticsearch.index.cache.filter.support
 
CacheKeyFilter.Wrapper(Filter, CacheKeyFilter.Key) - Constructor for class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
CacheRecycler - Class in org.elasticsearch.common
 
CacheRecycler() - Constructor for class org.elasticsearch.common.CacheRecycler
 
cacheSize() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
CacheStats - Class in org.elasticsearch.index.cache
 
CacheStats() - Constructor for class org.elasticsearch.index.cache.CacheStats
 
CacheStats(long, long, long, long, long, long) - Constructor for class org.elasticsearch.index.cache.CacheStats
 
CachingByteBufferAllocator - Class in org.apache.lucene.store.bytebuffer
The caching byte buffer allocator allows to define a global size for both the small and large buffers allocated.
CachingByteBufferAllocator(boolean, int, int, int, int) - Constructor for class org.apache.lucene.store.bytebuffer.CachingByteBufferAllocator
 
calc(long) - Method in class org.elasticsearch.common.joda.TimeZoneRounding
 
calculate(double, double) - Method in class org.elasticsearch.index.search.geo.GeoDistance.ArcFixedSourceDistance
 
calculate(double, double, double, double, DistanceUnit) - Method in enum org.elasticsearch.index.search.geo.GeoDistance
 
calculate(double, double) - Method in class org.elasticsearch.index.search.geo.GeoDistance.FactorFixedSourceDistance
 
calculate(double, double) - Method in interface org.elasticsearch.index.search.geo.GeoDistance.FixedSourceDistance
 
calculate(double, double) - Method in class org.elasticsearch.index.search.geo.GeoDistance.PlaneFixedSourceDistance
 
camelCase() - Method in class org.elasticsearch.common.xcontent.XContentBuilderString
 
canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
 
canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
 
canAllocate(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
 
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.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.ThrottlingAllocationDecider
 
canBindToMcastAddress() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
cancel(boolean) - Method in class jsr166y.ForkJoinTask
Attempts to cancel execution of this task.
cancel(boolean) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
 
cancelRecovery(IndexShard) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
 
cancelRelocation() - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
canDeleteUnallocated(ShardId) - Method in class org.elasticsearch.index.store.fs.FsIndexStore
 
canDeleteUnallocated(ShardId) - Method in interface org.elasticsearch.index.store.IndexStore
Returns true if this shard is allocated on this node.
canDeleteUnallocated(ShardId) - Method in class org.elasticsearch.index.store.support.AbstractIndexStore
 
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().
canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
 
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
 
canRemain(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
Can the provided shard routing remain on the 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.FilterAllocationDecider
 
canRemain(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
 
canReuse(HashedBytesArray) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderCache
Returns an already stored instance if exists, if not, returns null;
canReuse(HashedBytesArray) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderTypeCache
Returns an already stored instance if exists, if not, returns null;
capacity() - Method in class jsr166e.extra.ReadMostlyVector
See Vector.capacity()
capacity() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
 
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).
CatalanAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
CatalanAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CatalanAnalyzerProvider
 
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.create.CreateIndexRequestBuilder
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.monitor.dump.AbstractDump
 
cause() - Method in interface org.elasticsearch.monitor.dump.Dump
 
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
 
CBZip2InputStream - Class in org.elasticsearch.common.compress.bzip2
An input stream that decompresses from the BZip2 format (without the file header chars) to be read as any other stream.
CBZip2InputStream(InputStream) - Constructor for class org.elasticsearch.common.compress.bzip2.CBZip2InputStream
Constructs a new CBZip2InputStream which decompresses bytes read from the specified stream.
CBZip2OutputStream - Class in org.elasticsearch.common.compress.bzip2
An output stream that compresses into the BZip2 format (without the file header chars) into another stream.
CBZip2OutputStream(OutputStream) - Constructor for class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
Constructs a new CBZip2OutputStream with a blocksize of 900k.
CBZip2OutputStream(OutputStream, int) - Constructor for class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
Constructs a new CBZip2OutputStream with specified blocksize.
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
 
changed() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
 
changesAllowed() - Method in interface org.elasticsearch.indices.IndicesService
Returns true if changes (adding / removing) indices, shards and so on are allowed.
changesAllowed() - Method in class org.elasticsearch.indices.InternalIndicesService
Returns true if changes (adding / removing) indices, shards and so on are allowed.
channel() - Method in class org.elasticsearch.index.translog.fs.RafReference
 
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
 
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() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
CharSequenceReader - Class in org.elasticsearch.common.io
 
CharSequenceReader() - Constructor for class org.elasticsearch.common.io.CharSequenceReader
 
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(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.TransportIndicesExistsAction
 
checkBlock(DeleteMappingRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
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(DeleteIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
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(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
 
checkChronology(Chronology) - Method in class org.joda.time.base.BaseDateTime
Checks the specified chronology before storing it, potentially altering it.
checkContentsNotNull(T) - Static method in class org.elasticsearch.common.Preconditions
Ensures that an Iterable object passed as a parameter to the calling method is not null and contains no null elements.
checkContentsNotNull(T, Object) - Static method in class org.elasticsearch.common.Preconditions
Ensures that an Iterable object passed as a parameter to the calling method is not null and contains no null elements.
checkContentsNotNull(T, String, Object...) - Static method in class org.elasticsearch.common.Preconditions
Ensures that an Iterable object passed as a parameter to the calling method is not null and contains no null elements.
checkElementIndex(int, int) - Static method in class org.elasticsearch.common.Preconditions
Ensures that index specifies a valid element in an array, list or string of size size.
checkElementIndex(int, int, String) - Static method in class org.elasticsearch.common.Preconditions
Ensures that index specifies a valid element in an array, list or string of size size.
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.
checkGlobalBlock(ClusterState, AnalyzeRequest) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
 
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, GatewaySnapshotRequest) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
checkGlobalBlock(ClusterState, OptimizeRequest) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
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
 
checkGlobalBlock(ClusterState, ValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
checkGlobalBlock(ClusterState, BulkShardRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
checkGlobalBlock(ClusterState, CountRequest) - Method in class org.elasticsearch.action.count.TransportCountAction
 
checkGlobalBlock(ClusterState, IndexDeleteRequest) - Method in class org.elasticsearch.action.delete.index.TransportIndexDeleteAction
 
checkGlobalBlock(ClusterState, ShardDeleteRequest) - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
checkGlobalBlock(ClusterState, DeleteRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
checkGlobalBlock(ClusterState, DeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
checkGlobalBlock(ClusterState, IndexDeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
checkGlobalBlock(ClusterState, ShardDeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
checkGlobalBlock(ClusterState, ExplainRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
checkGlobalBlock(ClusterState, GetRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
 
checkGlobalBlock(ClusterState, MultiGetShardRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
checkGlobalBlock(ClusterState, IndexRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
checkGlobalBlock(ClusterState, PercolateRequest) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
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, Request) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
checkGlobalBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
checkGlobalBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
checkGlobalBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
checkGlobalBlock(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
checkIndexTime() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Start
 
checkIndexTime(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Start
 
checkIndexTook() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
checkInstant(long, Chronology) - Method in class org.joda.time.base.BaseDateTime
Checks the specified instant before storing it, potentially altering it.
checkMkdirsStall(long) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
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
 
checkOrder(double[], int, boolean) - Static method in class org.elasticsearch.common.math.MathUtils
Checks that the given array is sorted.
checkPositionIndex(int, int) - Static method in class org.elasticsearch.common.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndex(int, int, String) - Static method in class org.elasticsearch.common.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndexes(int, int, int) - Static method in class org.elasticsearch.common.Preconditions
Ensures that start and end specify a valid positions in an array, list or string of size size, and are in order.
checkRequestBlock(ClusterState, AnalyzeRequest) - 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, GatewaySnapshotRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
checkRequestBlock(ClusterState, OptimizeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
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
 
checkRequestBlock(ClusterState, ValidateQueryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
checkRequestBlock(ClusterState, BulkShardRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
checkRequestBlock(ClusterState, CountRequest, String[]) - Method in class org.elasticsearch.action.count.TransportCountAction
 
checkRequestBlock(ClusterState, IndexDeleteRequest) - Method in class org.elasticsearch.action.delete.index.TransportIndexDeleteAction
 
checkRequestBlock(ClusterState, ShardDeleteRequest) - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
checkRequestBlock(ClusterState, DeleteRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
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, ShardDeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
checkRequestBlock(ClusterState, ExplainRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
checkRequestBlock(ClusterState, GetRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
 
checkRequestBlock(ClusterState, MultiGetShardRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
checkRequestBlock(ClusterState, IndexRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
checkRequestBlock(ClusterState, PercolateRequest) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
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, Request) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
checkRequestBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
checkRequestBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
checkRequestBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
checkRequestBlock(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
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.
checksum() - Method in class org.elasticsearch.index.gateway.CommitPoint.FileInfo
 
checksum() - Method in class org.elasticsearch.index.store.StoreFileMetaData
 
ChecksumIndexOutput - Class in org.elasticsearch.common.lucene.store
 
ChecksumIndexOutput(IndexOutput, Checksum) - Constructor for class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
checkWriteConsistency() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
checkWriteConsistency() - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
checkWriteConsistency() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
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
 
ChildCollector - Class in org.elasticsearch.index.search.child
 
ChildCollector(String, SearchContext) - Constructor for class org.elasticsearch.index.search.child.ChildCollector
 
ChineseAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ChineseAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ChineseAnalyzerProvider
 
chooseBlockSize(long) - Static method in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
Chooses a blocksize based on the given length of the data to compress.
chunkSize - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexInput
 
chunkSize - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamInput
 
chunkSize() - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
chunkSize - Variable in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexGateway
 
chunkSize() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexGateway
 
chunkSize - Variable in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
CjkAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
CjkAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CjkAnalyzerProvider
 
Classes - Class in org.elasticsearch.common
 
Classes - Class in org.elasticsearch.common.inject.internal
Class utilities.
Classes() - Constructor for class org.elasticsearch.common.inject.internal.Classes
 
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
 
clean(ByteBuffer) - Static method in class org.apache.lucene.store.bytebuffer.ByteBufferAllocator.Cleaner
 
CLEAN_FILES - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
 
CLEAN_SUPPORTED - Static variable in class org.apache.lucene.store.bytebuffer.ByteBufferAllocator.Cleaner
 
cleanCaches(Injector) - Static method in class org.elasticsearch.common.inject.Injectors
 
cleanHandles() - Method in class org.elasticsearch.common.io.stream.HandlesStreamInput
 
cleanIndex(String, String) - Method in interface org.elasticsearch.indices.IndicesService
Cleans the index without actually deleting any content for it.
cleanIndex(String, String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
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.
cleanShard(int, String) - Method in interface org.elasticsearch.index.service.IndexService
Cleans the shard locally, does not touch the gateway!.
cleanShard(int, String) - Method in class org.elasticsearch.index.service.InternalIndexService
 
clear() - Method in class jsr166e.ConcurrentHashMapV8
Removes all of the mappings from this map.
clear() - Method in class jsr166e.extra.ReadMostlyVector
 
clear() - Method in class jsr166y.ConcurrentLinkedDeque
Removes all of the elements from this deque.
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.indices.stats.IndicesStatsRequest
Clears all stats.
clear() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
Clears all stats.
clear() - Method in class org.elasticsearch.common.bloom.ObsBloomFilter
 
clear() - Static method in class org.elasticsearch.common.CacheRecycler
 
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.MapBackedSet
 
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() - Static method in class org.elasticsearch.common.io.stream.CachedStreamOutput
 
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 interface org.elasticsearch.index.cache.bloom.BloomCache
 
clear(IndexReader) - Method in interface org.elasticsearch.index.cache.bloom.BloomCache
 
clear() - Method in class org.elasticsearch.index.cache.bloom.none.NoneBloomCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.bloom.none.NoneBloomCache
 
clear() - Method in class org.elasticsearch.index.cache.bloom.simple.SimpleBloomCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.bloom.simple.SimpleBloomCache
 
clear(String, String) - Method in interface org.elasticsearch.index.cache.field.data.FieldDataCache
 
clear(String) - Method in interface org.elasticsearch.index.cache.field.data.FieldDataCache
 
clear(IndexReader) - Method in interface org.elasticsearch.index.cache.field.data.FieldDataCache
 
clear(String, String) - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
clear(String) - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
clear(String, String) - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
clear(String) - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
clear(IndexReader) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
clear(String) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
clear(String) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
clear(String) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
clear() - Method in interface org.elasticsearch.index.cache.id.IdCache
 
clear(IndexReader) - Method in interface org.elasticsearch.index.cache.id.IdCache
 
clear() - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdCache
 
clear(IndexReader) - Method in class org.elasticsearch.index.cache.IndexCache
 
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 class org.elasticsearch.index.cache.query.parser.support.AbstractJvmQueryParserCache
 
clear() - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
clear() - Method in class org.elasticsearch.index.search.child.HasChildFilter
 
clear() - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
clear() - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
clear() - Method in class org.elasticsearch.script.ScriptService
 
clear() - Method in interface org.elasticsearch.search.internal.ScopePhase
 
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
 
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
 
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.
clearLock(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
CLEARMASK - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This constant is accessible by subclasses for historical purposes.
clearReferencesThreadLocals() - Static method in class org.elasticsearch.common.util.concurrent.ThreadLocals
 
clearUnreferenced() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
clearUnreferenced() - Method in interface org.elasticsearch.index.translog.Translog
Clears unreferenced transaclogs.
CLibrary - Class in org.elasticsearch.common.jna
 
client - Variable in class org.elasticsearch.action.admin.cluster.support.BaseClusterRequestBuilder
 
client - Variable in class org.elasticsearch.action.admin.indices.support.BaseIndicesRequestBuilder
 
client - Variable in class org.elasticsearch.action.support.BaseRequestBuilder
 
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 - Variable in class org.elasticsearch.rest.BaseRestHandler
 
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
 
clone() - Method in class jsr166e.extra.ReadMostlyVector
 
clone() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
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
 
clone() - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
 
clone() - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexInput
 
clone() - Method in class org.elasticsearch.index.search.nested.BlockJoinQuery
 
clone() - Method in class org.elasticsearch.index.search.nested.IncludeAllChildrenQuery
 
close() - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
close() - Method in interface org.apache.lucene.store.bytebuffer.ByteBufferAllocator
Close the allocator, releasing any cached buffers for example.
close() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
close() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
close() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexOutput
 
close() - Method in class org.apache.lucene.store.bytebuffer.CachingByteBufferAllocator
 
close() - Method in class org.apache.lucene.store.bytebuffer.PlainByteBufferAllocator
 
close() - Method in class org.apache.lucene.store.OpenBufferedIndexOutput
Closes this stream to further operations.
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.memory.ByteBufferCache
 
close() - Method in class org.elasticsearch.cache.NodeCache
 
close() - Method in interface org.elasticsearch.client.Client
Closes the client.
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 class org.elasticsearch.common.Base64.OutputStream
Flushes and closes (I think, in the superclass) the stream.
close() - Method in interface org.elasticsearch.common.blobstore.BlobStore
 
close() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
close() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
close() - Method in interface org.elasticsearch.common.component.CloseableComponent
 
close() - Method in class org.elasticsearch.common.compress.bzip2.CBZip2InputStream
 
close() - Method in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
 
close() - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
close() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
 
close() - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
close() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
 
close() - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
close(Injector) - Static method in class org.elasticsearch.common.inject.Injectors
 
close() - Method in class org.elasticsearch.common.io.FastByteArrayInputStream
Closing a ByteArrayInputStream has no effect.
close() - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Closing a ByteArrayOutputStream has no effect.
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.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 class org.elasticsearch.common.lucene.all.AllEntries
 
close() - Method in class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
close() - Method in class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
close() - Method in class org.elasticsearch.common.lucene.store.NullIndexOutput
 
close() - Method in class org.elasticsearch.common.lucene.store.OutputStreamIndexOutput
 
close() - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
close() - Method in class org.elasticsearch.common.netty.OpenChannelsHandler
 
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 interface org.elasticsearch.common.xcontent.XContentParser
 
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.index.analysis.AnalysisService
 
close() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
 
close() - Method in class org.elasticsearch.index.cache.bloom.none.NoneBloomCache
 
close() - Method in class org.elasticsearch.index.cache.bloom.simple.SimpleBloomCache
 
close() - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
close() - Method in class org.elasticsearch.index.cache.field.data.resident.ResidentFieldDataCache
 
close() - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
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.id.simple.SimpleIdCache
 
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 class org.elasticsearch.index.cache.query.parser.support.AbstractJvmQueryParserCache
 
close(boolean) - Method in interface org.elasticsearch.index.CloseableIndexComponent
Closes the index component.
close() - Method in interface org.elasticsearch.index.engine.IndexEngine
 
close() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
close() - Method in class org.elasticsearch.index.engine.robin.RobinIndexEngine
 
close(boolean) - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexGateway
 
close(boolean) - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
close(boolean) - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
 
close(boolean) - Method in class org.elasticsearch.index.gateway.local.LocalIndexGateway
 
close(boolean) - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
close(boolean) - Method in class org.elasticsearch.index.gateway.none.NoneIndexGateway
 
close(boolean) - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
close() - Method in class org.elasticsearch.index.IndexServiceManagement
 
close() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
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.UidFieldMapper
 
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.multifield.MultiFieldMapper
 
close() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
close(boolean) - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
close() - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.CustomLogByteSizeMergePolicy
 
close() - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy
 
close(boolean) - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
close() - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.CustomLogDocMergePolicy
 
close() - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy
 
close(boolean) - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
close() - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.CustomTieredMergePolicyProvider
 
close() - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider
 
close() - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
close() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider.CustomSerialMergeScheduler
 
close() - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
close() - Method in class org.elasticsearch.index.percolator.PercolatorService
 
close() - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
close(boolean, String, Executor) - Method in class org.elasticsearch.index.service.InternalIndexService
 
close() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
close(String) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
close() - Method in class org.elasticsearch.index.store.Store
 
close(boolean) - Method in class org.elasticsearch.index.store.support.AbstractIndexStore
 
close(boolean) - Method in class org.elasticsearch.index.translog.fs.BufferingFsTranslogFile
 
close(boolean) - 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(boolean) - Method in interface org.elasticsearch.index.translog.Translog
Closes the transaction log.
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.recovery.RecoverySettings
 
close() - Method in class org.elasticsearch.indices.store.IndicesStore
 
close() - Method in class org.elasticsearch.jmx.JmxClusterService
 
close() - Method in class org.elasticsearch.jmx.JmxService
 
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.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
 
close() - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService
 
close() - Method in class org.elasticsearch.script.NativeScriptEngineService
 
close() - Method in interface org.elasticsearch.script.ScriptEngineService
 
close() - Method in class org.elasticsearch.script.ScriptService
 
close() - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
close() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
close() - Method in class org.elasticsearch.transport.netty.NettyTransport.NodeChannels
 
CloseableComponent - Interface in org.elasticsearch.common.component
 
CloseableIndexComponent - Interface in org.elasticsearch.index
 
closed() - Method in class org.elasticsearch.common.component.Lifecycle
Returns true if the state is closed.
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(MetaDataStateIndexService.Request, MetaDataStateIndexService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataStateIndexService
 
CloseIndexAction - Class in org.elasticsearch.action.admin.indices.close
 
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 delete 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
 
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.
closeRiver(RiverName) - Method in class org.elasticsearch.river.RiversService
 
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.node.NodeAdminClient
 
cluster() - Method in class org.elasticsearch.client.transport.support.InternalTransportAdminClient
 
CLUSTER - Static variable in class org.elasticsearch.monitor.dump.cluster.ClusterDumpContributor
 
CLUSTER_READ_ONLY_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.MetaData
 
ClusterAction<Request extends ActionRequest,Response extends ActionResponse,RequestBuilder extends ActionRequestBuilder<Request,Response>> - Class in org.elasticsearch.action.admin.cluster
Cluster action (used with ClusterAdminClient API.
ClusterAction(String) - Constructor for class org.elasticsearch.action.admin.cluster.ClusterAction
 
ClusterAdminClient - Interface in org.elasticsearch.client
Administrative actions/operations against indices.
ClusterBlock - Class in org.elasticsearch.cluster.block
 
ClusterBlock(int, String, boolean, boolean, RestStatus, 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
 
ClusterBlocks.Builder() - Constructor for class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cache.NodeCache
 
clusterChanged(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.ClusterStateListener
Called when cluster state changes.
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.gateway.shared.SharedStorageGateway
 
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.river.routing.RiversRouter
 
ClusterChangedEvent - Class in org.elasticsearch.cluster
 
ClusterChangedEvent(String, ClusterState, ClusterState) - Constructor for class org.elasticsearch.cluster.ClusterChangedEvent
 
ClusterDumpContributor - Class in org.elasticsearch.monitor.dump.cluster
 
ClusterDumpContributor(ClusterService, String, Settings) - Constructor for class org.elasticsearch.monitor.dump.cluster.ClusterDumpContributor
 
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, List<String>) - 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(String, int, int, List<String>) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
ClusterModule - Class in org.elasticsearch.cluster
 
ClusterModule(Settings) - Constructor for class org.elasticsearch.cluster.ClusterModule
 
clusterName() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
clusterName() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse
 
clusterName() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
 
clusterName() - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
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() - 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
 
ClusterRebalanceAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
 
ClusterRebalanceAllocationDecider.ClusterRebalanceType - Enum in org.elasticsearch.cluster.routing.allocation.decider
 
ClusterRerouteAction - Class in org.elasticsearch.action.admin.cluster.reroute
 
ClusterRerouteRequest - Class in org.elasticsearch.action.admin.cluster.reroute
 
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
 
ClusterRerouteRequestBuilder(ClusterAdminClient) - Constructor for class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
 
ClusterRerouteResponse - Class in org.elasticsearch.action.admin.cluster.reroute
 
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(long, MetaData, RoutingTable, DiscoveryNodes, ClusterBlocks, AllocationExplanation, ImmutableMap<String, ClusterState.Custom>) - Constructor for class org.elasticsearch.cluster.ClusterState
 
ClusterState.Builder - Class in org.elasticsearch.cluster
 
ClusterState.Builder() - Constructor for class org.elasticsearch.cluster.ClusterState.Builder
 
ClusterState.Custom - Interface in org.elasticsearch.cluster
 
ClusterState.Custom.Factory<T extends ClusterState.Custom> - Interface 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.
clusterStateProcessed(ClusterState) - Method in interface 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
 
ClusterStateUpdateTask - Interface in org.elasticsearch.cluster
A task that can update the cluster state.
ClusterUpdateSettingsAction - Class in org.elasticsearch.action.admin.cluster.settings
 
ClusterUpdateSettingsRequest - Class in org.elasticsearch.action.admin.cluster.settings
 
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
 
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.
collect(int) - Method in class org.elasticsearch.common.lucene.docset.DocIdSetCollector
 
collect(int) - Method in class org.elasticsearch.common.lucene.Lucene.ExistsCollector
 
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.ChildCollector
 
collect(int) - Method in class org.elasticsearch.index.search.nested.NestedChildrenCollector
 
collect(int) - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
collectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
collectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
 
collectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
collectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
 
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) - Static method in class org.elasticsearch.common.Strings
Convenience method to return a Collection as a delimited (e.g.
collector() - Method in class org.elasticsearch.index.search.child.HasChildFilter
 
collector() - Method in interface org.elasticsearch.search.internal.ScopePhase.CollectorPhase
 
collectors() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
 
collectPayloads(boolean) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
 
collectTerm(String) - Method in interface org.elasticsearch.index.field.data.support.FieldDataLoader.TypeLoader
 
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.
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.
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.FileInfo(String, String, long, String) - Constructor for class org.elasticsearch.index.gateway.CommitPoint.FileInfo
 
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
 
committed() - Method in class org.elasticsearch.index.engine.Segment
 
CommonStats - Class in org.elasticsearch.action.admin.indices.stats
 
CommonStats() - Constructor for class org.elasticsearch.action.admin.indices.stats.CommonStats
 
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
 
comparatorSource(SearchScript) - Static method in class org.elasticsearch.index.field.function.sort.DoubleFieldsFunctionDataComparator
 
comparatorSource(SearchScript) - Static method in class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
comparatorSource(String, double, double, DistanceUnit, GeoDistance, FieldDataCache, MapperService) - Static method in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
compare(FieldFragList.WeightedFragInfo, FieldFragList.WeightedFragInfo) - Method in class org.apache.lucene.search.vectorhighlight.XScoreOrderFragmentsBuilder.ScoreComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataMissingComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataMissingComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataMissingComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataMissingComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataMissingComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataMissingComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.function.sort.DoubleFieldsFunctionDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
compare(int, int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
compareAndSet(double, double) - Method in class jsr166e.extra.AtomicDouble
Atomically sets the value to the given updated value if the current value is bitwise equal to the expected value.
compareAndSet(int, double, double) - Method in class jsr166e.extra.AtomicDoubleArray
Atomically sets the element at position i to the given updated value if the current value is bitwise equal to the expected value.
compareAndSetForkJoinTaskTag(short, short) - Method in class jsr166y.ForkJoinTask
Atomically conditionally sets the tag value for this task.
compareAndSetPendingCount(int, int) - Method in class jsr166y.CountedCompleter
Sets (atomically) the pending count to the given count only if it currently holds the given expected value.
compareBottom(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataMissingComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataMissingComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataMissingComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataMissingComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataMissingComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataMissingComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.function.sort.DoubleFieldsFunctionDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
compareBottom(int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
compareTo(Node) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
compareTo(double, double, double) - Static method in class org.elasticsearch.common.math.MathUtils
Compares two numbers given some amount of allowed error.
compareTo(UUID) - Method in class org.elasticsearch.common.UUID
Compares this UUID with the specified UUID.
compareTo(TermsFacet.Entry) - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet.ByteEntry
 
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.floats.InternalFloatTermsFacet.FloatEntry
 
compareTo(TermsFacet.Entry) - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet.IntEntry
 
compareTo(TermsFacet.Entry) - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet.LongEntry
 
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.shorts.InternalShortTermsFacet.ShortEntry
 
compareTo(TermsFacet.Entry) - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.StringEntry
 
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
 
compile(String, String) - Static method in class org.elasticsearch.common.regex.Regex
 
compile(String) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService
 
compile(String) - Method in class org.elasticsearch.script.NativeScriptEngineService
 
compile(String) - Method in interface org.elasticsearch.script.ScriptEngineService
 
compile(String) - Method in class org.elasticsearch.script.ScriptService
 
compile(String, String) - Method in class org.elasticsearch.script.ScriptService
 
compiled() - Method in class org.elasticsearch.script.CompiledScript
 
CompiledScript - Class in org.elasticsearch.script
 
CompiledScript(String, Object) - Constructor for class org.elasticsearch.script.CompiledScript
 
complete(Void) - Method in class jsr166y.CountedCompleter
Regardless of pending count, invokes CountedCompleter.onCompletion(jsr166y.CountedCompleter), marks this task as complete with a null return value, and further triggers CountedCompleter.tryComplete() on this task's completer, if one exists.
complete(V) - Method in class jsr166y.ForkJoinTask
Completes this task, and if not already aborted or cancelled, returning the given value as the result of subsequent invocations of join and related operations.
completeExceptionally(Throwable) - Method in class jsr166y.ForkJoinTask
Completes this task abnormally, and if not already aborted or cancelled, causes it to throw the given exception upon join and related operations.
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
 
compress(byte[], int, int, IndexOutput) - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
Compresses the data into the output
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, IndexOutput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexOutput
 
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(byte[], int, int) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
compress(byte[], int, int) - Method in class org.elasticsearch.common.compress.snappy.UnavailableSnappyCompressor
 
compress(byte[], int, int, IndexOutput) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressedIndexOutput
 
compress(byte[], int, int, StreamOutput) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressedStreamOutput
 
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() - 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
 
compressChunkLength() - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressorContext
 
compressed() - Method in class org.elasticsearch.common.compress.CompressedString
 
compressed(Compressor, StreamInput) - Static method in class org.elasticsearch.common.io.stream.CachedStreamInput
 
compressedBuffer - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexOutput
 
compressedBuffer - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamOutput
 
CompressedDirectory - Class in org.elasticsearch.common.compress
 
CompressedDirectory(Directory, Compressor, boolean, String...) - Constructor for class org.elasticsearch.common.compress.CompressedDirectory
 
CompressedDirectory(Directory, Compressor, boolean, String[], String[]) - Constructor for class org.elasticsearch.common.compress.CompressedDirectory
 
CompressedIndexInput<T extends CompressorContext> - Class in org.elasticsearch.common.compress
 
CompressedIndexInput(IndexInput, T) - Constructor for class org.elasticsearch.common.compress.CompressedIndexInput
 
CompressedIndexOutput<T extends CompressorContext> - Class in org.elasticsearch.common.compress
 
CompressedIndexOutput(IndexOutput, T) - Constructor for class org.elasticsearch.common.compress.CompressedIndexOutput
 
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
 
compressMaxCompressedChunkLength() - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressorContext
 
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
 
compressorContext - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
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
 
compute(K, ConcurrentHashMapV8.RemappingFunction<? super K, V>) - Method in class jsr166e.ConcurrentHashMapV8
Computes and enters a new mapping value given a key and its current mapped value (or null if there is no current mapping).
compute() - Method in class jsr166y.CountedCompleter
The main computation performed by this task.
compute() - Method in class jsr166y.RecursiveAction
The main computation performed by this task.
compute() - Method in class jsr166y.RecursiveTask
The main computation performed by this task.
computeHashCode(String) - Method in class org.elasticsearch.common.trove.StringIdentityHashingStrategy
 
computeIfAbsent(K, ConcurrentHashMapV8.MappingFunction<? super K, ? extends V>) - Method in class jsr166e.ConcurrentHashMapV8
If the specified key is not already associated with a value, computes its value using the given mappingFunction and enters it into the map.
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.FieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.strings.MultiValueStringFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.strings.SingleValueStringFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
computeSizeInBytes() - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
concat(DocumentMapper, FieldMapper...) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
concat(DocumentMapper, Iterable<FieldMapper>) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
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.
concatenateStringArrays(String[], String[]) - Static method in class org.elasticsearch.common.Strings
Concatenate the given String arrays into one, with overlapping array elements included twice.
concreteAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
Returns all the concrete indices.
concreteAllIndicesAsSet() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
concreteAllOpenIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
concreteIndex(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
concreteIndices(String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
Translates the provided indices (possibly aliased) into actual indices.
concreteIndices(String[], IgnoreIndices, boolean) - Method in class org.elasticsearch.cluster.metadata.MetaData
Translates the provided indices (possibly aliased) into actual indices.
concreteIndicesIgnoreMissing(String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
Translates the provided indices (possibly aliased) into actual indices.
ConcurrentCollections - Class in org.elasticsearch.common.util.concurrent
 
ConcurrentHashMapLong<T> - Class in org.elasticsearch.common.util.concurrent
 
ConcurrentHashMapLong() - Constructor for class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
ConcurrentHashMapV8<K,V> - Class in jsr166e
A hash table supporting full concurrency of retrievals and high expected concurrency for updates.
ConcurrentHashMapV8() - Constructor for class jsr166e.ConcurrentHashMapV8
Creates a new, empty map with the default initial table size (16),
ConcurrentHashMapV8(int) - Constructor for class jsr166e.ConcurrentHashMapV8
Creates a new, empty map with an initial table size accommodating the specified number of elements without the need to dynamically resize.
ConcurrentHashMapV8(Map<? extends K, ? extends V>) - Constructor for class jsr166e.ConcurrentHashMapV8
Creates a new map with the same mappings as the given map.
ConcurrentHashMapV8(int, float) - Constructor for class jsr166e.ConcurrentHashMapV8
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity) and initial table density (loadFactor).
ConcurrentHashMapV8(int, float, int) - Constructor for class jsr166e.ConcurrentHashMapV8
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity), table density (loadFactor), and number of concurrently updating threads (concurrencyLevel).
ConcurrentHashMapV8.MappingFunction<K,V> - Interface in jsr166e
A function computing a mapping from the given key to a value.
ConcurrentHashMapV8.RemappingFunction<K,V> - Interface in jsr166e
A function computing a new mapping given a key and its current mapped value (or null if there is no current mapping).
ConcurrentLinkedDeque<E> - Class in jsr166y
An unbounded concurrent deque based on linked nodes.
ConcurrentLinkedDeque() - Constructor for class jsr166y.ConcurrentLinkedDeque
Constructs an empty deque.
ConcurrentLinkedDeque(Collection<? extends E>) - Constructor for class jsr166y.ConcurrentLinkedDeque
Constructs a deque initially containing the elements of the given collection, added in traversal order of the collection's iterator.
ConcurrentMapLong<T> - Interface in org.elasticsearch.common.util.concurrent
 
ConcurrentMergeSchedulerProvider - Class in org.elasticsearch.index.merge.scheduler
 
ConcurrentMergeSchedulerProvider(ShardId, Settings) - 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
 
ConcurrentRebalanceAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
 
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
 
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.NodeCacheModule
 
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(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(Settings) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
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.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.fs.FsGatewayModule
 
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.http.netty.NettyHttpServerTransportModule
 
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.bloom.BloomCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.field.data.FieldDataCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.filter.FilterCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.id.IdCacheModule
 
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.deletionpolicy.DeletionPolicyModule
 
configure() - Method in class org.elasticsearch.index.engine.EngineModule
 
configure() - Method in class org.elasticsearch.index.engine.IndexEngineModule
 
configure() - Method in class org.elasticsearch.index.engine.robin.RobinEngineModule
 
configure() - Method in class org.elasticsearch.index.engine.robin.RobinIndexEngineModule
 
configure() - Method in class org.elasticsearch.index.gateway.fs.FsIndexGatewayModule
 
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.PercolatorModule
 
configure() - Method in class org.elasticsearch.index.query.IndexQueryParserModule
 
configure() - Method in class org.elasticsearch.index.search.stats.ShardSearchModule
 
configure() - Method in class org.elasticsearch.index.settings.IndexSettingsModule
 
configure() - Method in class org.elasticsearch.index.shard.IndexShardModule
 
configure() - Method in class org.elasticsearch.index.similarity.SimilarityModule
 
configure() - Method in class org.elasticsearch.index.store.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.memory.MemoryIndexStoreModule
 
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.translog.TranslogModule
 
configure() - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisModule
 
configure() - Method in class org.elasticsearch.indices.IndicesModule
 
configure() - Method in class org.elasticsearch.indices.query.IndicesQueriesModule
 
configure() - Method in class org.elasticsearch.jmx.AbstractJmxModule
 
configure() - Method in class org.elasticsearch.jmx.JmxModule
 
configure() - Method in class org.elasticsearch.monitor.MonitorModule
 
configure() - Method in class org.elasticsearch.node.internal.NodeModule
 
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.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.facet.FacetModule
 
configure() - Method in class org.elasticsearch.search.facet.TransportFacetModule
 
configure() - Method in class org.elasticsearch.search.SearchModule
 
configure() - Method in class org.elasticsearch.search.TransportSearchModule
 
configure() - Method in class org.elasticsearch.threadpool.ThreadPoolModule
 
configure() - Method in class org.elasticsearch.transport.local.LocalTransportModule
 
configure() - Method in class org.elasticsearch.transport.netty.NettyTransportModule
 
configure() - Method in class org.elasticsearch.transport.TransportModule
 
conflicts() - Method in class org.elasticsearch.index.mapper.DocumentMapper.MergeResult
The merge conflicts.
connectAndRegister(String, NetworkService) - Method in class org.elasticsearch.jmx.JmxService
 
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
 
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(WriteConsistencyLevel) - Method in class org.elasticsearch.action.delete.DeleteRequest
Sets the consistency level of write.
consistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
consistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.index.IndexRequest
Sets the consistency level of write.
consistencyLevel - Variable in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
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() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
consistencyLevel(WriteConsistencyLevel) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
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.
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.
ConstantScoreQueryParser - Class in org.elasticsearch.index.query
 
ConstantScoreQueryParser() - Constructor for class org.elasticsearch.index.query.ConstantScoreQueryParser
 
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.
containPhysicalIndexFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoint
 
contains(Object) - Method in class jsr166e.ConcurrentHashMapV8
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class jsr166e.extra.ReadMostlyVector
 
contains(Object) - Method in class jsr166y.ConcurrentLinkedDeque
Returns true if this deque contains at least one element e such that o.equals(e).
contains(Object) - Method in class jsr166y.LinkedTransferQueue
Returns true if this queue contains the specified element.
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.collect.MapBackedSet
 
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.
containsAll(Collection<?>) - Method in class jsr166e.extra.ReadMostlyVector
 
containsKey(Object) - Method in class jsr166e.ConcurrentHashMapV8
Tests if the specified object is a key in this table.
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.search.lookup.DocLookup
 
containsKey(Object) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
containsKey(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
containsValue(Object) - Method in class jsr166e.ConcurrentHashMapV8
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
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.
containsWhitespace(String) - Static method in class org.elasticsearch.common.Strings
Check whether the given String contains any whitespace characters.
content() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
content() - Method in class org.elasticsearch.rest.BytesRestResponse
 
content() - Method in interface org.elasticsearch.rest.RestRequest
 
content() - Method in interface org.elasticsearch.rest.RestResponse
Returns the actual content.
content() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
content() - Method in class org.elasticsearch.rest.XContentRestResponse
 
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.DateFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.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.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.ip.IpFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.object.ObjectMapper
 
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
 
contentLength() - Method in class org.elasticsearch.rest.BytesRestResponse
 
contentLength() - Method in interface org.elasticsearch.rest.RestResponse
The content length.
contentLength() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
contentLength() - Method in class org.elasticsearch.rest.XContentRestResponse
 
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 interface org.elasticsearch.rest.RestResponse
Can the content byte[] be used only with this thread (false), or by any thread (true).
contentThreadSafe() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
contentThreadSafe() - Method in class org.elasticsearch.rest.XContentRestResponse
 
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() - 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.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.DateFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.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.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.ip.IpFieldMapper
 
contentType() - Method in class org.elasticsearch.rest.BytesRestResponse
 
contentType() - Method in interface org.elasticsearch.rest.RestResponse
 
contentType() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
contentType() - Method in class org.elasticsearch.rest.XContentRestResponse
 
contentUnsafe() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
contentUnsafe() - Method in interface org.elasticsearch.rest.RestRequest
Is the byte array content safe or unsafe for usage on other threads
context() - Method in class org.elasticsearch.action.search.type.ParsedScrollId
 
context - Variable in class org.elasticsearch.common.compress.CompressedIndexInput
 
context - Variable in class org.elasticsearch.common.compress.CompressedIndexOutput
 
context - Variable in class org.elasticsearch.common.compress.CompressedStreamInput
 
context - Variable in class org.elasticsearch.common.compress.CompressedStreamOutput
 
context() - Method in class org.elasticsearch.monitor.dump.AbstractDump
 
context() - Method in interface org.elasticsearch.monitor.dump.Dump
 
ContextIndexSearcher - Class in org.elasticsearch.search.internal
 
ContextIndexSearcher(SearchContext, Engine.Searcher) - Constructor for class org.elasticsearch.search.internal.ContextIndexSearcher
 
ContextIndexSearcher.Scopes - Class in org.elasticsearch.search.internal
 
ContextIndexSearcher.Scopes() - Constructor for class org.elasticsearch.search.internal.ContextIndexSearcher.Scopes
 
continueProcessing(RestRequest, RestChannel) - Method in interface org.elasticsearch.rest.RestFilterChain
Continue processing the request.
contribute(Dump) - Method in class org.elasticsearch.monitor.dump.cluster.ClusterDumpContributor
 
contribute(Dump) - Method in interface org.elasticsearch.monitor.dump.DumpContributor
 
contribute(Dump) - Method in class org.elasticsearch.monitor.dump.heap.HeapDumpContributor
 
contribute(Dump) - Method in class org.elasticsearch.monitor.dump.summary.SummaryDumpContributor
 
contribute(Dump) - Method in class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
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(IndexReader, DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocSets
 
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
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[], boolean, IgnoreIndices) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
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
 
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
 
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
 
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(int, int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataMissingComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataMissingComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataMissingComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataMissingComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataMissingComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataMissingComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.function.sort.DoubleFieldsFunctionDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
copy(int, int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
copyBytes(DataInput, long) - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
copyBytesArray() - Method in class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
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
 
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
 
copyFile(File, File) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
copyInto(Object[]) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.copyInto(java.lang.Object[])
copyNamedFilters() - Method in class org.elasticsearch.index.query.QueryParseContext
 
copySign(Double, Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
copySign(Float, Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
copyText(Unicode.UTF16Result) - Method in class org.elasticsearch.common.Unicode.UTF16Result
 
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
 
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
 
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.MathUtils
Returns the hyperbolic cosine of x.
cosh(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
count() - Method in class org.elasticsearch.action.count.CountResponse
The count of documents matching the query provided.
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.FastByteArrayInputStream
The index one greater than the last valid character in the input stream buffer.
count - Variable in class org.elasticsearch.common.io.FastByteArrayOutputStream
The number of valid bytes in the buffer.
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.BytesStreamInput
 
count - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
The number of valid bytes in the buffer.
count(IndexSearcher, Query) - Static method in class org.elasticsearch.common.lucene.Lucene
 
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.get.GetStats
 
count - Variable in class org.elasticsearch.index.search.child.TopChildrenQuery.ParentDoc
 
count() - Method in class org.elasticsearch.index.shard.DocsStats
 
count() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
count() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
count() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The number of hits that fall within that key "range" or "interval".
count() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
count() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
count() - Method in interface org.elasticsearch.search.facet.filter.FilterFacet
The count of the facet.
count() - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
The count of the facet.
count() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
count() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
count() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
count() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The number of hits that fall within that key "range" or "interval".
count() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
count() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
count() - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
The count of the facet.
count() - Method in interface org.elasticsearch.search.facet.query.QueryFacet
The count of the facet.
count() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
count() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
count() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The number of values counted.
count() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector.StatsProc
 
count() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector.StatsProc
 
count() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet.ByteEntry
 
count() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
count() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet.FloatEntry
 
count() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet.IntEntry
 
count() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet.LongEntry
 
count() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
count() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet.ShortEntry
 
count() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.StringEntry
 
count() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet.Entry
 
count() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
count() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
count() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
count() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
COUNT_LIMIT - Static variable in class org.elasticsearch.common.io.stream.CachedStreamOutput
 
CountAction - Class in org.elasticsearch.action.count
 
CountDateHistogramFacetCollector - 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.
CountDateHistogramFacetCollector(String, String, TimeZoneRounding, DateHistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetCollector
 
CountDateHistogramFacetCollector.DateHistogramProc - Class in org.elasticsearch.search.facet.datehistogram
 
CountDateHistogramFacetCollector.DateHistogramProc(TimeZoneRounding) - Constructor for class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetCollector.DateHistogramProc
 
CountedCompleter - Class in jsr166y
A resultless ForkJoinTask with a completion action performed when triggered and there are no remaining pending actions.
CountedCompleter(CountedCompleter, int) - Constructor for class jsr166y.CountedCompleter
Creates a new CountedCompleter with the given completer and initial pending count.
CountedCompleter(CountedCompleter) - Constructor for class jsr166y.CountedCompleter
Creates a new CountedCompleter with the given completer and an initial pending count of zero.
CountedCompleter() - Constructor for class jsr166y.CountedCompleter
Creates a new CountedCompleter with no completer and an initial pending count of zero.
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
 
CountHistogramFacetCollector - Class in org.elasticsearch.search.facet.histogram.unbounded
A histogram facet collector that uses the same field as the key as well as the value.
CountHistogramFacetCollector(String, String, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.CountHistogramFacetCollector
 
CountHistogramFacetCollector.HistogramProc - Class in org.elasticsearch.search.facet.histogram.unbounded
 
CountHistogramFacetCollector.HistogramProc(long) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.CountHistogramFacetCollector.HistogramProc
 
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() - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetCollector.DateHistogramProc
 
counts() - Method in class org.elasticsearch.search.facet.histogram.unbounded.CountHistogramFacetCollector.HistogramProc
 
CountSearchResult - Class in org.elasticsearch.search.count
The initial scan search result, including the count of hits matching the provided query.
CountSearchResult() - Constructor for class org.elasticsearch.search.count.CountSearchResult
 
CountSearchResult(long, long) - Constructor for class org.elasticsearch.search.count.CountSearchResult
 
countWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
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(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(String, Settings) - Method in interface org.elasticsearch.index.analysis.AnalyzerProviderFactory
 
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(CharStream) - 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.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.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.GermanStemTokenFilterFactory
 
create(CharStream) - Method in class org.elasticsearch.index.analysis.HtmlStripCharFilterFactory
 
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.LowerCaseTokenFilterFactory
 
create(Reader) - Method in class org.elasticsearch.index.analysis.LowerCaseTokenizerFactory
 
create(CharStream) - 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.PatternReplaceTokenFilterFactory
 
create(Reader) - Method in class org.elasticsearch.index.analysis.PatternTokenizerFactory
 
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.ShingleTokenFilterFactory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.SnowballTokenFilterFactory
 
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(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(Reader) - Method in class org.elasticsearch.index.analysis.WhitespaceTokenizerFactory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.WordDelimiterTokenFilterFactory
 
create(Engine.Create) - Method in interface org.elasticsearch.index.engine.Engine
 
create(Engine.Create) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
create(String, Settings) - Method in interface org.elasticsearch.index.query.FilterParserFactory
 
create(String, Settings) - Method in interface org.elasticsearch.index.query.QueryParserFactory
 
create(Point, Point, GeoPointFieldMapper) - Static method in class org.elasticsearch.index.search.geo.IndexedGeoBoundingBoxFilter
 
create(Engine.Create) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
create(Engine.Create) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
create(String, Settings) - Method in interface org.elasticsearch.index.similarity.SimilarityProviderFactory
 
create(ShardId, long, RafReference, int) - Method in enum org.elasticsearch.index.translog.fs.FsTranslogFile.Type
 
create(String, Settings) - Method in interface org.elasticsearch.monitor.dump.DumpContributorFactory
 
create(ChannelBuffer) - Static method in class org.elasticsearch.transport.netty.ChannelBufferStreamInputFactory
 
create(ChannelBuffer, int) - Static method in class org.elasticsearch.transport.netty.ChannelBufferStreamInputFactory
 
CREATE_CONNECTOR - Static variable in class org.elasticsearch.jmx.JmxService.SettingsConstants
 
createArithmeticException(String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new ArithmeticException with specified formatted detail message.
createArrayIndexOutOfBoundsException(String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new ArrayIndexOutOfBoundsException with specified formatted detail message.
createBuilder(String) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
 
createBuilder(String) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.TypeParser
 
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.elasticsearch.index.analysis.StandardHtmlStripAnalyzer
 
createConcurrentModificationException(String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new ConcurrentModificationException with specified formatted detail message.
createContainsFilter(Shape) - Method in class org.elasticsearch.common.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
Creates a Filter that will find all indexed Shapes that are properly contained within the given Shape (the indexed Shapes will not have any area outside of the given Shape).
createContainsFilter(Shape) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a Filter that will find all indexed Shapes that are properly contained within the given Shape (the indexed Shapes will not have any area outside of the given Shape).
createContainsQuery(Shape) - Method in class org.elasticsearch.common.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
Creates a Query that will find all indexed Shapes that are properly contained within the given Shape (the indexed Shapes will not have any area outside of the given Shape).
createContainsQuery(Shape) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a Query that will find all indexed Shapes that are properly contained within the given Shape (the indexed Shapes will not have any area outside of the given Shape).
createDisjointFilter(Shape) - Method in class org.elasticsearch.common.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
Creates a Filter that will find all indexed Shapes that are disjoint to the given Shape
createDisjointFilter(Shape) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a Filter that will find all indexed Shapes that are disjoint to the given Shape
createDisjointQuery(Shape) - Method in class org.elasticsearch.common.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
Creates a Query that will find all indexed Shapes that are disjoint to the given Shape
createDisjointQuery(Shape) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a Query that will find all indexed Shapes that are disjoint to the given Shape
createEOFException(String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new EOFException with specified formatted detail message.
CreateFailedEngineException - Exception in org.elasticsearch.index.engine
 
CreateFailedEngineException(ShardId, Engine.Create, Throwable) - Constructor for exception org.elasticsearch.index.engine.CreateFailedEngineException
 
createField(Shape) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Converts the given Shape into its indexable format.
createFieldData() - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
createFieldData() - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
createFieldData() - Method in class org.elasticsearch.index.field.data.FieldData
 
createFieldData() - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
createFieldData() - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
createFieldData() - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
createFieldData() - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
createFieldData() - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
createFieldData() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
createFile(String) - Method in class org.elasticsearch.monitor.dump.AbstractDump
 
createFile(String) - Method in interface org.elasticsearch.monitor.dump.Dump
 
createFileOutputStream(String) - Method in class org.elasticsearch.monitor.dump.AbstractDump
 
createFileOutputStream(String) - Method in interface org.elasticsearch.monitor.dump.Dump
 
createFileWriter(String) - Method in class org.elasticsearch.monitor.dump.AbstractDump
 
createFileWriter(String) - Method in interface org.elasticsearch.monitor.dump.Dump
 
createFilter(Shape, ShapeRelation) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a Filter that will find all indexed Shapes that relate to the given Shape
createFixedBitSet(DocIdSetIterator, int) - Static method in class org.elasticsearch.common.lucene.docset.DocSets
 
createFragments(IndexReader, int, String, FieldFragList, int, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.AbstractFragmentsBuilder
 
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
 
createIllegalArgumentException(String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new IllegalArgumentException with specified formatted detail message.
createIllegalArgumentException(Throwable) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new IllegalArgumentException with specified nested Throwable root cause.
createIllegalStateException(String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new IllegalStateException with specified formatted detail message.
createIndex(MetaDataCreateIndexService.Request, MetaDataCreateIndexService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
 
createIndex(String, Settings, String) - Method in interface org.elasticsearch.indices.IndicesService
 
createIndex(String, Settings, String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
CreateIndexAction - Class in org.elasticsearch.action.admin.indices.create
 
createIndexNameTerm(String) - 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(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
 
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
 
createInternalError(Throwable) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Create an RuntimeException for an internal error.
createIntersectsFilter(Shape) - Method in class org.elasticsearch.common.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
Creates a Filter that will find all indexed Shapes that intersect with the given Shape
createIntersectsFilter(Shape) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a Filter that will find all indexed Shapes that intersect with the given Shape
createIntersectsQuery(Shape) - Method in class org.elasticsearch.common.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
Creates a Query that will find all indexed Shapes that intersect with the given Shape
createIntersectsQuery(Shape) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a Query that will find all indexed Shapes that intersect with the given Shape
createIOException(Throwable) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new IOException with specified nested Throwable root cause.
createMapper(String, String, boolean, ObjectMapper.Nested, ObjectMapper.Dynamic, ContentPath.Type, Map<String, Mapper>) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
createMapper(String, String, boolean, ObjectMapper.Nested, ObjectMapper.Dynamic, ContentPath.Type, Map<String, Mapper>) - 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
 
createNormalizedWeight(Query) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
createNoSuchElementException(String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new NoSuchElementException with specified formatted detail message.
createNullPointerException(String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new NullPointerException with specified formatted detail message.
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) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
createOutput(String) - Method in class org.apache.lucene.store.XMMapFSDirectory
 
createOutput(String) - Method in class org.apache.lucene.store.XNIOFSDirectory
 
createOutput(String) - Method in class org.apache.lucene.store.XSimpleFSDirectory
 
createOutput(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
createOutput(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
createOutputRaw(String) - Method in class org.elasticsearch.index.store.Store
Creates a raw output, no checksum is computed, and no compression if enabled.
createParseContext(String, String, String) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
 
createParseException(int, String, Object...) - Static method in exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new ParseException with specified formatted detail message.
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
 
createQuery(Shape, ShapeRelation) - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a Query that will find all indexed Shapes that relate to the given Shape
createRiver(RiverName, Map<String, Object>) - Method in class org.elasticsearch.river.RiversService
 
createSearcher() - Method in class org.apache.lucene.index.memory.CustomMemoryIndex
Creates and returns a searcher that can be used to execute arbitrary Lucene queries and to collect the resulting query results as hits.
createShard(int) - Method in interface org.elasticsearch.index.service.IndexService
 
createShard(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
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
 
createWeight(Searcher) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery
 
createWeight(Searcher) - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
createWeight(Searcher) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
createWeight(Searcher) - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsQuery
 
createWeight(Searcher) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
createWeight(Searcher) - Method in class org.elasticsearch.index.search.nested.BlockJoinQuery
 
createWeight(Searcher) - Method in class org.elasticsearch.index.search.nested.IncludeAllChildrenQuery
 
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.
ctx - Variable in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
current() - Static method in class jsr166y.ThreadLocalRandom
Returns the current thread's ThreadLocalRandom.
current() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
current() - Method in class org.elasticsearch.index.get.GetStats
 
current() - Method in class org.elasticsearch.index.merge.MergeStats
The current number of merges executing.
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
 
currentFieldData - Variable in class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
currentFieldData - Variable in class org.elasticsearch.index.field.data.support.NumericFieldDataComparator
 
currentFilesSize() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
currentFilesSize() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
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
 
currentMerges() - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
currentMergesNumDocs() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
currentMergesNumDocs() - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
currentMergesSizeInBytes() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
currentMergesSizeInBytes() - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
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 to.
currentNumDocs() - Method in class org.elasticsearch.index.merge.MergeStats
 
currentSize() - Method in class org.elasticsearch.index.merge.MergeStats
 
currentSizeInBytes() - Method in class org.elasticsearch.index.merge.MergeStats
 
currentSnapshotStatus() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
currentSnapshotStatus() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
The current snapshot status being performed.
currentSnapshotStatus() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
currentSnapshotStatus() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
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
 
currentStartedShards() - Method in class org.elasticsearch.gateway.local.state.shards.LocalGatewayShardsState
 
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
 
currentTranslogOperations() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Translog
 
currentTranslogOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
currEstab() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
custom(IndexMetaData.Custom) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
 
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
 
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
 
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
 
customBoostFactorQuery(QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that simply applies the boost fact to the wrapped query (multiplies it).
CustomBoostFactorQueryBuilder - Class in org.elasticsearch.index.query
A query that simply applies the boost factor to another query (multiply it).
CustomBoostFactorQueryBuilder(QueryBuilder) - Constructor for class org.elasticsearch.index.query.CustomBoostFactorQueryBuilder
A query that simply applies the boost factor to another query (multiply it).
CustomBoostFactorQueryParser - Class in org.elasticsearch.index.query
 
CustomBoostFactorQueryParser() - Constructor for class org.elasticsearch.index.query.CustomBoostFactorQueryParser
 
customFactories - Static variable in class org.elasticsearch.cluster.ClusterState
 
customFactories - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
 
customFactories - Static variable in class org.elasticsearch.cluster.metadata.MetaData
 
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
 
customFiltersScoreQuery(QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
 
CustomFiltersScoreQueryBuilder - Class in org.elasticsearch.index.query
A query that uses a filters with a script associated with them to compute the score.
CustomFiltersScoreQueryBuilder(QueryBuilder) - Constructor for class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
 
CustomFiltersScoreQueryParser - Class in org.elasticsearch.index.query
 
CustomFiltersScoreQueryParser() - Constructor for class org.elasticsearch.index.query.CustomFiltersScoreQueryParser
 
CustomMemoryIndex - Class in org.apache.lucene.index.memory
High-performance single-document main memory Apache Lucene fulltext search index.
CustomMemoryIndex() - Constructor for class org.apache.lucene.index.memory.CustomMemoryIndex
Constructs an empty instance.
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.MetaDataCreateIndexService.Request
 
customs(Map<String, IndexMetaData.Custom>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
 
customScoreQuery(QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that allows to define a custom scoring script.
CustomScoreQueryBuilder - Class in org.elasticsearch.index.query
A query that uses a script to compute the score.
CustomScoreQueryBuilder(QueryBuilder) - Constructor for class org.elasticsearch.index.query.CustomScoreQueryBuilder
A query that simply applies the boost factor to another query (multiply it).
CustomScoreQueryParser - Class in org.elasticsearch.index.query
 
CustomScoreQueryParser() - Constructor for class org.elasticsearch.index.query.CustomScoreQueryParser
 
CustomScoreQueryParser.ScriptScoreFunction - Class in org.elasticsearch.index.query
 
CustomScoreQueryParser.ScriptScoreFunction(String, Map<String, Object>, SearchScript) - Constructor for class org.elasticsearch.index.query.CustomScoreQueryParser.ScriptScoreFunction
 
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(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
 
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(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
date(int, MutableDateTime) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
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, String, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, String, TimeUnit, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper
 
DateFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
DateFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper.Builder
 
DateFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
DateFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
 
DateFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
DateFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.DateFieldMapper.TypeParser
 
DateHistogramFacet - Interface in org.elasticsearch.search.facet.datehistogram
A date histogram facet.
dateHistogramFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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.
DateHistogramFacetProcessor - Class in org.elasticsearch.search.facet.datehistogram
 
DateHistogramFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetProcessor
 
DateMathParser - Class in org.elasticsearch.common.joda
 
DateMathParser(FormatDateTimeFormatter, TimeUnit) - Constructor for class org.elasticsearch.common.joda.DateMathParser
 
dates(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
dates(int) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
dates(int) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
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(FormatDateTimeFormatter) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
 
dateTimeFormatter() - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
days() - Method in class org.elasticsearch.common.unit.TimeValue
 
daysFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
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
 
DeadlockAnalyzer.Deadlock(ThreadInfo[]) - Constructor for class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
deassignNode() - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
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
 
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
 
deciders() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
DECODE - Static variable in class org.elasticsearch.common.Base64
Specify decoding in first bit.
decode(byte[]) - Static method in class org.elasticsearch.common.Base64
Low-level access to decoding ASCII characters in the form of a byte array.
decode(byte[], int, int, int) - Static method in class org.elasticsearch.common.Base64
Low-level access to decoding ASCII characters in the form of a byte array.
decode(String) - Static method in class org.elasticsearch.common.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decode(String, int) - Static method in class org.elasticsearch.common.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in class org.elasticsearch.common.netty.KeepFrameDecoder
 
decode(String) - Method in interface org.elasticsearch.common.path.PathTrie.Decoder
 
decode(String) - Static method in class org.elasticsearch.index.search.geo.GeoHashUtils
 
decode(String, double[]) - Static method in class org.elasticsearch.index.search.geo.GeoHashUtils
Decodes the given geohash into a latitude and longitude
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.
decodeFileToFile(String, String) - Static method in class org.elasticsearch.common.Base64
Reads infile and decodes it to outfile.
decodeFromFile(String) - Static method in class org.elasticsearch.common.Base64
Convenience method for reading a base64-encoded file and decoding it.
decodeHex(String) - Static method in class org.elasticsearch.common.Hex
 
decodeHex(char[]) - Static method in class org.elasticsearch.common.Hex
 
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
 
decodeToFile(String, String) - Static method in class org.elasticsearch.common.Base64
Convenience method for decoding data to a file.
decodeToObject(String) - Static method in class org.elasticsearch.common.Base64
Attempts to decode Base64 data and deserialize a Java Object within.
decodeToObject(String, int, ClassLoader) - Static method in class org.elasticsearch.common.Base64
Attempts to decode Base64 data and deserialize a Java Object within.
decreaseRefCount(boolean) - Method in class org.elasticsearch.index.translog.fs.RafReference
 
decrement() - Method in class jsr166e.LongAdder
Equivalent to add(-1).
decrement(K) - Method in class jsr166e.LongAdderTable
Decrements the sum associated with the given key.
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.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
DEFAULT - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
DEFAULT - Static variable in class org.elasticsearch.search.highlight.HighlightPhase.Encoders
 
DEFAULT_ALLOW_LEADING_WILDCARD - Static variable in class org.apache.lucene.queryParser.QueryParserSettings
 
DEFAULT_ANALYZE_WILDCARD - Static variable in class org.apache.lucene.queryParser.QueryParserSettings
 
DEFAULT_BOUNDARY_CHARS - Static variable in class org.elasticsearch.common.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.lucene.store.OpenBufferedIndexOutput
 
DEFAULT_DATE_TIME_FORMAT - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
DEFAULT_ENGINE - Static variable in class org.elasticsearch.index.engine.IndexEngineModule.EngineSettings
 
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_INSTANCE - Static variable in class org.elasticsearch.common.inject.internal.SourceProvider
 
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_LEVELS - Static variable in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
DEFAULT_MAX_SCAN - Static variable in class org.elasticsearch.common.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
DEFAULT_MIME_TYPES - Static variable in class org.elasticsearch.http.HttpServer
 
DEFAULT_MIN_SCORE - Static variable in class org.elasticsearch.action.count.CountRequest
 
DEFAULT_PERCENT_TERMS_TO_MATCH - Static variable in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
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_WORD_DELIM_TABLE - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterIterator
 
defaultAnalyzer() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
defaultAnalyzer(Analyzer) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
defaultAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
defaultAnalyzer() - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
 
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
 
defaultCompressor() - Static method in class org.elasticsearch.common.compress.CompressorFactory
 
defaultDatePrinter - Static variable in class org.elasticsearch.common.xcontent.XContentBuilder
 
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.QueryParserSettings
 
defaultField(String) - Method in class org.apache.lucene.queryParser.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.
defaultForkJoinWorkerThreadFactory - Static variable in class jsr166y.ForkJoinPool
Creates a new ForkJoinWorkerThread.
defaultIndexAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
defaultIndexSimilarity() - Method in class org.elasticsearch.index.similarity.SimilarityService
 
defaultMapper() - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
defaultOperator() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
defaultOperator(QueryParser.Operator) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
defaultOperator(FieldQueryBuilder.Operator) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
Sets the boolean operator of the query parser used to parse the query string.
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.
defaultQuoteAnalyzer() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
defaultQuoteAnalyzer(Analyzer) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
defaultRefreshInterval() - Method in interface org.elasticsearch.index.engine.Engine
The default suggested refresh interval, -1 to disable it.
defaultRefreshInterval() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
defaultReplicationType - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
defaultReuseAddress() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
defaultSearchAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
defaultSearchQuoteAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
defaultSearchSimilarity() - Method in class org.elasticsearch.index.similarity.SimilarityService
 
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
 
DefaultSimilarityProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.similarity.DefaultSimilarityProvider
 
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
 
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.
delDocCount - Variable in class org.elasticsearch.index.engine.Segment
 
delegate - Variable in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
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() - 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(IndexMetaData) - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
delete(IndexMetaData) - Method in class org.elasticsearch.gateway.shared.SharedStorageGateway
 
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 interface org.elasticsearch.index.engine.Engine
 
delete(Engine.DeleteByQuery) - Method in interface org.elasticsearch.index.engine.Engine
 
delete(Engine.Delete) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
delete(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
delete(Engine.Delete) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
delete(Engine.Delete) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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.AbstractFsBlobContainer
 
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(Engine.DeleteByQuery) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
deleteByQuery(Engine.DeleteByQuery) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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(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
 
deleteContent() - Method in class org.elasticsearch.index.store.Store
 
deleteCount() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
deleteCurrent() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
deleted() - Method in class org.elasticsearch.index.shard.DocsStats
 
deletedDocs() - Method in class org.elasticsearch.action.admin.indices.status.DocsStatus
The number of deleted docs in the index.
deletedDocs() - Method in class org.elasticsearch.index.engine.Segment
 
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.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
deleteFile(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
deleteFile(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
deleteIndex(MetaDataDeleteIndexService.Request, MetaDataDeleteIndexService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService
 
deleteIndex(String, String) - Method in interface org.elasticsearch.indices.IndicesService
 
deleteIndex(String, String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
DeleteIndexAction - Class in org.elasticsearch.action.admin.indices.delete
 
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
 
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.
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
 
DeleteMappingRequest - Class in org.elasticsearch.action.admin.indices.mapping.delete
 
DeleteMappingRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
Constructs a new put 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
 
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.
deleteRecursively(File[]) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
deleteRecursively(File) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
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.
DeleteRequest - Class in org.elasticsearch.action.delete
A request to delete a document from an index based on its type and id.
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() - Constructor for class org.elasticsearch.action.delete.DeleteRequest
 
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
 
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
 
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
 
deleteTime() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
deleteTimeInMillis() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
deleteUnallocated(ShardId) - Method in class org.elasticsearch.index.store.fs.FsIndexStore
 
deleteUnallocated(ShardId) - Method in interface org.elasticsearch.index.store.IndexStore
Deletes this shard store since its no longer allocated.
deleteUnallocated(ShardId) - Method in class org.elasticsearch.index.store.support.AbstractIndexStore
 
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
 
DeleteWarmerRequest - Class in org.elasticsearch.action.admin.indices.warmer.delete
A request to delete an index warmer.
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
 
DeleteWarmerRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequestBuilder
 
DeleteWarmerResponse - Class in org.elasticsearch.action.admin.indices.warmer.delete
A response for a delete warmer.
DeletionAwareConstantScoreQuery - Class in org.apache.lucene.search
 
DeletionAwareConstantScoreQuery(Filter) - Constructor for class org.apache.lucene.search.DeletionAwareConstantScoreQuery
 
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
 
DeletionPolicyModule.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.
DELIMITER - Static variable in class org.elasticsearch.index.mapper.Uid
 
delta(DiscoveryNodes) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
Returns the changes comparing this nodes to the provided nodes.
Dependency<T> - Class in org.elasticsearch.common.inject.spi
A variable that can be resolved by an injector.
DEPTH_THRESH - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This constant is accessible by subclasses for historical purposes.
descendingIterator() - Method in class jsr166y.ConcurrentLinkedDeque
Returns an iterator over the elements in this deque in reverse sequential order.
description() - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
description() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation.NodeExplanation
 
description() - Method in interface org.elasticsearch.plugins.Plugin
The description of the plugin.
description() - Method in enum org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.ComparatorType
 
description() - Method in enum org.elasticsearch.search.facet.histogram.HistogramFacet.ComparatorType
 
destroy() - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
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
 
determineThreadName(String, String) - Method in class org.elasticsearch.common.netty.NettyStaticSetup.EsThreadNameDeterminer
 
dfMap() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
 
dfs() - Method in class org.elasticsearch.search.query.QuerySearchRequest
 
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.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
 
dFuzzyFactor - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
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
 
Digest - Class in org.elasticsearch.common
 
Digest() - Constructor for class org.elasticsearch.common.Digest
 
digest() - Method in class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
digest() - Method in class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
DIGIT - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
direct - Variable in class org.apache.lucene.store.bytebuffer.PlainByteBufferAllocator
 
direct() - Method in class org.elasticsearch.cache.memory.ByteBufferCache
 
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
 
directory() - Method in class org.elasticsearch.index.store.StoreFileMetaData
 
DirectoryService - Interface in org.elasticsearch.index.store
 
DisableAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
 
DisableAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.DisableAllocationDecider
 
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.
disableMerge() - Method in interface org.elasticsearch.index.merge.policy.EnableMergePolicy
 
disableMerge() - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy
 
disableMerge() - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy
 
disableMerge() - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider
 
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) - 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
 
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.
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) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
 
DiscoveryNode(String, String, TransportAddress, Map<String, String>) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
 
DiscoveryNodeFilters - Class in org.elasticsearch.cluster.node
 
DiscoveryNodes - Class in org.elasticsearch.cluster.node
 
DiscoveryNodes.Builder - Class in org.elasticsearch.cluster.node
 
DiscoveryNodes.Builder() - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
DiscoveryNodes.Delta - Class in org.elasticsearch.cluster.node
 
DiscoveryNodes.Delta(String, ImmutableList<DiscoveryNode>, ImmutableList<DiscoveryNode>) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
DiscoveryNodes.Delta(DiscoveryNode, DiscoveryNode, String, ImmutableList<DiscoveryNode>, ImmutableList<DiscoveryNode>) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
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, Discovery) - Constructor for class org.elasticsearch.discovery.DiscoveryService
 
discreteMultiValueHighlighting(List<FieldFragList.WeightedFragInfo>, Field[]) - Method in class org.apache.lucene.search.vectorhighlight.AbstractFragmentsBuilder
 
diskQueue() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
diskReads() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
diskReadSizeInBytes() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
diskReadSizeSize() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
diskServiceTime() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
diskWrites() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
diskWriteSizeInBytes() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
diskWriteSizeSize() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
disMaxClauses(DisjunctionMaxQuery) - Static method in class org.elasticsearch.common.lucene.search.Queries
 
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(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.RestController
 
distance(double[], double[]) - Static method in class org.elasticsearch.common.math.MathUtils
Calculates the L2 (Euclidean) distance between two points.
distance(int[], int[]) - Static method in class org.elasticsearch.common.math.MathUtils
Calculates the L2 (Euclidean) distance between two points.
distance(double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
distance(int, DistanceUnit, double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
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
 
distance1(double[], double[]) - Static method in class org.elasticsearch.common.math.MathUtils
Calculates the L1 (sum of abs) distance between two points.
distance1(int[], int[]) - Static method in class org.elasticsearch.common.math.MathUtils
Calculates the L1 (sum of abs) distance between two points.
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.index.search.geo.GeoDistance
 
distanceErrorPct(double) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
distanceGeohash(int, DistanceUnit, String) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
distanceInf(double[], double[]) - Static method in class org.elasticsearch.common.math.MathUtils
Calculates the L (max of abs) distance between two points.
distanceInf(int[], int[]) - Static method in class org.elasticsearch.common.math.MathUtils
Calculates the L (max of abs) distance between two points.
distanceInKm(double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
distanceInKmWithDefault(double, double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
distancePerDegree - Variable in enum org.elasticsearch.common.unit.DistanceUnit
 
DistanceUnit - Enum in org.elasticsearch.common.unit
 
distanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
DJB_HASH(String) - Static method in class org.elasticsearch.cluster.routing.operation.hash.djb.DjbHashFunction
 
DjbHashFunction - Class in org.elasticsearch.cluster.routing.operation.hash.djb
 
DjbHashFunction() - Constructor for class org.elasticsearch.cluster.routing.operation.hash.djb.DjbHashFunction
 
DO_BREAK_LINES - Static variable in class org.elasticsearch.common.Base64
Do break lines when encoding.
doBooleanValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doBooleanValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
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() - Method in class org.elasticsearch.action.update.UpdateRequest
 
doc() - Static method in class org.elasticsearch.common.lucene.DocumentBuilder
 
doc(String, RootObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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.percolator.PercolatorExecutor.DocAndQueryRequest
 
doc() - Method in class org.elasticsearch.index.percolator.PercolatorExecutor.DocAndSourceQueryRequest
 
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, FieldSelector) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
doc() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
doc() - Method in class org.elasticsearch.search.lookup.FieldLookup
 
doc(Document) - Method in class org.elasticsearch.search.lookup.FieldLookup
 
doc() - Method in class org.elasticsearch.search.lookup.SearchLookup
 
DOC_FIELD_NAME - Static variable in class org.elasticsearch.search.sort.SortParseElement
 
docById(String, HashedBytesArray) - Method in interface org.elasticsearch.index.cache.id.IdReaderCache
 
docById(HashedBytesArray) - Method in interface org.elasticsearch.index.cache.id.IdReaderTypeCache
 
docById(String, HashedBytesArray) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderCache
 
docById(HashedBytesArray) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderTypeCache
 
docCount - Variable in class org.elasticsearch.index.engine.Segment
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
DocFieldData<T extends FieldData> - Class in org.elasticsearch.index.field.data
 
DocFieldData(T) - Constructor for class org.elasticsearch.index.field.data.DocFieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.FieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.NumericFieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
docFieldData(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
docFreq(Term) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
docFreqs(Term[]) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
docID() - Method in class org.elasticsearch.common.lucene.docset.AllDocSet.AllDocIdSetIterator
 
docID() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.NotDocIdSetIterator
 
docID() - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet.OrDocIdSetIterator
 
docID() - Method in class org.elasticsearch.common.lucene.docset.OrDocSet.OrDocIdSetIterator
 
docId(IndexReader, Term) - Static method in class org.elasticsearch.common.lucene.Lucene
 
docID() - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
docId - Variable in class org.elasticsearch.common.lucene.uid.UidField.DocIdAndVersion
 
docId - Variable in class org.elasticsearch.index.field.data.DocFieldData
 
docId - Variable in class org.elasticsearch.index.search.child.TopChildrenQuery.ParentDoc
 
docId() - Method in interface org.elasticsearch.search.controller.ShardDoc
 
docId() - Method in class org.elasticsearch.search.controller.ShardFieldDoc
 
docId() - Method in class org.elasticsearch.search.controller.ShardScoreDoc
 
docId() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
docId() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
docIdAndVersion() - Method in class org.elasticsearch.index.engine.Engine.GetResult
 
docIds() - Method in class org.elasticsearch.search.fetch.FetchSearchRequest
 
docIdSet() - Method in class org.elasticsearch.common.lucene.docset.DocIdSetCollector
 
DocIdSetCollector - Class in org.elasticsearch.common.lucene.docset
 
DocIdSetCollector(Collector, IndexReader) - Constructor for class org.elasticsearch.common.lucene.docset.DocIdSetCollector
 
docIdsSize() - Method in class org.elasticsearch.search.fetch.FetchSearchRequest
 
docIdsToLoad(ShardDoc[]) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
docIdsToLoad() - Method in class org.elasticsearch.search.internal.SearchContext
 
docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.search.internal.SearchContext
 
docIdsToLoadFrom() - Method in class org.elasticsearch.search.internal.SearchContext
 
docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
doClose() - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
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
 
doClose() - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexOutput
 
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.common.compress.snappy.SnappyCompressedIndexInput
 
doClose() - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexOutput
 
doClose() - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamInput
 
doClose() - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamOutput
 
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.fs.FsGateway
 
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.gateway.shared.SharedStorageGateway
 
doClose() - Method in class org.elasticsearch.http.HttpServer
 
doClose() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doClose() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doClose() - Method in class org.elasticsearch.indices.InternalIndicesService
 
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.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.SearchService
 
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
 
docMapper() - Method in class org.elasticsearch.index.engine.Engine.Create
 
docMapper() - Method in class org.elasticsearch.index.engine.Engine.Index
 
docMapper() - Method in interface 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
 
docMapperParser() - Method in class org.elasticsearch.index.mapper.ParseContext
 
doCollect(int) - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.filter.FilterFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedCountHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueScriptHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.CountHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.FullHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ScriptHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueScriptHistogramFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.query.QueryFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.range.KeyValueRangeFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.range.RangeFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.range.ScriptRangeFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.statistical.ScriptStatisticalFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteOrdinalsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.index.IndexNameFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.strings.ScriptTermsStringFieldFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector
 
doCollect(int) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector
 
doConfigure() - Method in class org.elasticsearch.jmx.AbstractJmxModule
 
doCreateFile(String) - Method in class org.elasticsearch.monitor.dump.AbstractDump
 
doCreateFile(String) - Method in class org.elasticsearch.monitor.dump.SimpleDump
 
docs() - Method 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() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
docs() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
docs() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Docs level information for the shard index, null if not applicable.
docs() - Method in class org.elasticsearch.index.engine.Engine.Create
 
docs() - Method in class org.elasticsearch.index.engine.Engine.Index
 
docs() - Method in interface org.elasticsearch.index.engine.Engine.IndexingOperation
 
docs() - Method in class org.elasticsearch.index.mapper.ParseContext
 
docs() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
docs() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
DocSet - Class in org.elasticsearch.common.lucene.docset
 
DocSet() - Constructor for class org.elasticsearch.common.lucene.docset.DocSet
 
DocSets - Class in org.elasticsearch.common.lucene.docset
 
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
 
DocsStatus() - Constructor for class org.elasticsearch.action.admin.indices.status.DocsStatus
 
docStart - Variable in class org.elasticsearch.common.lucene.uid.UidField.DocIdAndVersion
 
docStarts() - Method in class org.apache.lucene.index.ExtendedIndexSearcher
 
docStats() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
docStats() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
DocumentAlreadyExistsException - Exception in org.elasticsearch.index.engine
 
DocumentAlreadyExistsException(ShardId, String, String) - Constructor for exception org.elasticsearch.index.engine.DocumentAlreadyExistsException
 
DocumentBuilder - Class in org.elasticsearch.common.lucene
 
DocumentFieldMappers - Class in org.elasticsearch.index.mapper
 
DocumentFieldMappers(DocumentMapper, Iterable<FieldMapper>) - 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>) - 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.Builder(String, Settings, RootObjectMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
DocumentMapper.MergeFlags - Class in org.elasticsearch.index.mapper
 
DocumentMapper.MergeFlags() - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.MergeFlags
 
DocumentMapper.MergeResult - Class in org.elasticsearch.index.mapper
A result of a merge.
DocumentMapper.MergeResult(String[]) - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.MergeResult
 
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
 
DocumentMapper.ParseListenerAdapter() - Constructor for class org.elasticsearch.index.mapper.DocumentMapper.ParseListenerAdapter
 
DocumentMapperParser - Class in org.elasticsearch.index.mapper
 
DocumentMapperParser(Index, AnalysisService) - Constructor for class org.elasticsearch.index.mapper.DocumentMapperParser
 
DocumentMapperParser(Index, Settings, AnalysisService) - 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
 
DocumentMissingException - Exception in org.elasticsearch.index.engine
 
DocumentMissingException(ShardId, String, String) - Constructor for exception org.elasticsearch.index.engine.DocumentMissingException
 
DocumentSourceMissingException - Exception in org.elasticsearch.index.engine
 
DocumentSourceMissingException(ShardId, String, String) - Constructor for exception org.elasticsearch.index.engine.DocumentSourceMissingException
 
doDoubleValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doDoubleValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
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<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<ClusterStateResponse>) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
 
doExecute(ActionListener<Response>) - Method in class org.elasticsearch.action.admin.cluster.support.BaseClusterRequestBuilder
 
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(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.IndicesExistsRequestBuilder
 
doExecute(IndicesExistsRequest, ActionListener<IndicesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.TransportIndicesExistsAction
 
doExecute(ActionListener<FlushResponse>) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
 
doExecute(ActionListener<GatewaySnapshotResponse>) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotRequestBuilder
 
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<PutMappingResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
 
doExecute(PutMappingRequest, ActionListener<PutMappingResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
doExecute(ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
 
doExecute(ActionListener<OptimizeResponse>) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
 
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<UpdateSettingsResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequestBuilder
 
doExecute(ActionListener<IndicesStats>) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
doExecute(ActionListener<IndicesStatusResponse>) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
 
doExecute(ActionListener<Response>) - Method in class org.elasticsearch.action.admin.indices.support.BaseIndicesRequestBuilder
 
doExecute(ActionListener<DeleteIndexTemplateResponse>) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
 
doExecute(ActionListener<PutIndexTemplateResponse>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
 
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(DeleteWarmerRequest, ActionListener<DeleteWarmerResponse>) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
 
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(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(ActionListener<ExplainResponse>) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
 
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<SearchResponse>) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
 
doExecute(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.mlt.TransportMoreLikeThisAction
 
doExecute(ActionListener<PercolateResponse>) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
 
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(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<Response>) - Method in class org.elasticsearch.action.support.BaseRequestBuilder
 
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<UpdateResponse>) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
 
doFloatValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doFloatValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
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
 
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 - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterIterator
Indicates the end of iteration
done() - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
 
done() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
 
DONT_GUNZIP - Static variable in class org.elasticsearch.common.Base64
Specify that gzipped data should not be automatically gunzipped.
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.filter.FilterFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedCountHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueScriptHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.CountHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.FullHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ScriptHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueScriptHistogramFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.query.QueryFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.range.KeyValueRangeFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.range.RangeFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.range.ScriptRangeFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.statistical.ScriptStatisticalFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteOrdinalsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.index.IndexNameFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.strings.ScriptTermsStringFieldFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector
 
doSetNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector
 
doShortValue() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
doShortValue() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
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.gateway.shared.SharedStorageGateway
 
doStart() - Method in class org.elasticsearch.http.HttpServer
 
doStart() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doStart() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doStart() - Method in class org.elasticsearch.indices.InternalIndicesService
 
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.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.transport.local.LocalTransport
 
doStart() - Method in class org.elasticsearch.transport.netty.NettyTransport
 
doStart() - Method in class org.elasticsearch.transport.TransportService
 
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.gateway.shared.SharedStorageGateway
 
doStop() - Method in class org.elasticsearch.http.HttpServer
 
doStop() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doStop() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doStop() - Method in class org.elasticsearch.indices.InternalIndicesService
 
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.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.transport.local.LocalTransport
 
doStop() - Method in class org.elasticsearch.transport.netty.NettyTransport
 
doStop() - Method in class org.elasticsearch.transport.TransportService
 
DOUBLE - Static variable in class org.elasticsearch.index.field.data.FieldDataType.DefaultTypes
 
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.
DoubleDocFieldData - Class in org.elasticsearch.index.field.data.doubles
 
DoubleDocFieldData(DoubleFieldData) - Constructor for class org.elasticsearch.index.field.data.doubles.DoubleDocFieldData
 
doubleField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
DoubleFieldData - Class in org.elasticsearch.index.field.data.doubles
 
DoubleFieldData(String, double[]) - Constructor for class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
DoubleFieldData.ValueInDocProc - Interface in org.elasticsearch.index.field.data.doubles
 
DoubleFieldData.ValueProc - Interface in org.elasticsearch.index.field.data.doubles
 
DoubleFieldDataComparator - Class in org.elasticsearch.index.field.data.doubles
 
DoubleFieldDataComparator(int, String, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.doubles.DoubleFieldDataComparator
 
DoubleFieldDataMissingComparator - Class in org.elasticsearch.index.field.data.doubles
 
DoubleFieldDataMissingComparator(int, String, FieldDataCache, double) - Constructor for class org.elasticsearch.index.field.data.doubles.DoubleFieldDataMissingComparator
 
DoubleFieldDataType - Class in org.elasticsearch.index.field.data.doubles
 
DoubleFieldDataType() - Constructor for class org.elasticsearch.index.field.data.doubles.DoubleFieldDataType
 
DoubleFieldMapper - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper(FieldMapper.Names, int, String, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, Double, boolean) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
DoubleFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Builder
 
DoubleFieldMapper.CustomDoubleNumericField - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper.CustomDoubleNumericField(NumberFieldMapper, double) - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericField
 
DoubleFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.Defaults
 
DoubleFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
DoubleFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.DoubleFieldMapper.TypeParser
 
DoubleFieldsFunctionDataComparator - Class in org.elasticsearch.index.field.function.sort
 
DoubleFieldsFunctionDataComparator(int, SearchScript) - Constructor for class org.elasticsearch.index.field.function.sort.DoubleFieldsFunctionDataComparator
 
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.
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 DoubleAdder.sum().
doubleValue() - Method in class jsr166e.DoubleMaxUpdater
Equivalent to DoubleMaxUpdater.max().
doubleValue() - Method in class jsr166e.extra.AtomicDouble
Returns the value of this AtomicDouble as a double.
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() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
doubleValue(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
doubleValue(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
doubleValue(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
doubleValue(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
doubleValue(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
doubleValue(int) - Method in class org.elasticsearch.index.field.data.NumericFieldData
Returns the value of the specified number as a double.
doubleValue(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.NumericFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
doubleValues(int) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
doWithNode(DiscoveryNode) - Method in interface org.elasticsearch.client.transport.TransportClientNodesService.NodeCallback
 
doWithNode(DiscoveryNode, ActionListener<Response>) - Method in interface org.elasticsearch.client.transport.TransportClientNodesService.NodeListenerCallback
 
download(URL, File, HttpDownloadHelper.DownloadProgress) - 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.ConstantScoreQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.CustomBoostFactorQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.CustomScoreQueryBuilder
 
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.FieldQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.FilteredQueryBuilder
 
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.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.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
 
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
 
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.ScriptFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
 
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.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.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) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
drainTasksTo(Collection<? super ForkJoinTask<?>>) - Method in class jsr166y.ForkJoinPool
Removes all available unexecuted submitted and forked tasks from scheduling queues and adds them to the given collection, without altering their execution status.
drainTo(Collection<? super E>) - Method in class jsr166y.LinkedTransferQueue
 
drainTo(Collection<? super E>, int) - Method in class jsr166y.LinkedTransferQueue
 
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
 
Dump - Interface in org.elasticsearch.monitor.dump
 
DumpContributionFailedException - Exception in org.elasticsearch.monitor.dump
 
DumpContributionFailedException(String, String) - Constructor for exception org.elasticsearch.monitor.dump.DumpContributionFailedException
 
DumpContributionFailedException(String, String, Throwable) - Constructor for exception org.elasticsearch.monitor.dump.DumpContributionFailedException
 
DumpContributor - Interface in org.elasticsearch.monitor.dump
 
DumpContributorFactory - Interface in org.elasticsearch.monitor.dump
 
DumpException - Exception in org.elasticsearch.monitor.dump
 
DumpException(String) - Constructor for exception org.elasticsearch.monitor.dump.DumpException
 
DumpException(String, Throwable) - Constructor for exception org.elasticsearch.monitor.dump.DumpException
 
DumpGenerationFailedException - Exception in org.elasticsearch.monitor.dump
 
DumpGenerationFailedException(String) - Constructor for exception org.elasticsearch.monitor.dump.DumpGenerationFailedException
 
DumpGenerationFailedException(String, Throwable) - Constructor for exception org.elasticsearch.monitor.dump.DumpGenerationFailedException
 
DumpGenerator - Interface in org.elasticsearch.monitor.dump
 
DumpGenerator.Result - Class in org.elasticsearch.monitor.dump
 
DumpGenerator.Result(File, Iterable<DumpContributionFailedException>) - Constructor for class org.elasticsearch.monitor.dump.DumpGenerator.Result
 
DumpMonitorService - Class in org.elasticsearch.monitor.dump
 
DumpMonitorService() - Constructor for class org.elasticsearch.monitor.dump.DumpMonitorService
 
DumpMonitorService(Settings, Environment, ClusterService, Map<String, DumpContributorFactory>) - Constructor for class org.elasticsearch.monitor.dump.DumpMonitorService
 
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() - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
dynamicSettings() - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
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_SINGLETON - Static variable in class org.elasticsearch.common.inject.internal.Scoping
 
earthCircumference - Variable in enum org.elasticsearch.common.unit.DistanceUnit
 
earthRadius - Variable in enum org.elasticsearch.common.unit.DistanceUnit
 
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
 
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.
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
 
ElasticSearchInterruptedException - Exception in org.elasticsearch
The same as InterruptedException simply a runtime one.
ElasticSearchInterruptedException(String) - Constructor for exception org.elasticsearch.ElasticSearchInterruptedException
 
ElasticSearchInterruptedException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticSearchInterruptedException
 
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() - Method in class jsr166y.ConcurrentLinkedDeque
 
Element - Interface in org.elasticsearch.common.inject.spi
A core component of a module or injector.
elementAt(int) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.elementAt(int)
elements() - Method in class jsr166e.ConcurrentHashMapV8
Returns an enumeration of the values in this table.
elements() - Method in class jsr166e.extra.ReadMostlyVector
See Vector.elements()
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.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.common.bloom.BloomFilter
 
EMPTY - Static variable in class org.elasticsearch.common.bytes.BytesArray
 
EMPTY - Static variable in class org.elasticsearch.common.lucene.DocumentBuilder
 
EMPTY - Static variable in interface org.elasticsearch.index.mapper.DocumentMapper.ParseListener
 
EMPTY - Static variable in class org.elasticsearch.rest.Utf8RestResponse
 
EMPTY - Static variable in class org.elasticsearch.river.routing.RiversRouting
 
EMPTY - Static variable in class org.elasticsearch.search.internal.InternalSearchHits
 
EMPTY - Static variable in class org.elasticsearch.search.internal.InternalSearchResponse
 
EMPTY - Static variable in class org.elasticsearch.transport.TransportRequestOptions
 
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.Bytes
 
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 class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
EMPTY_ARRAY - Static variable in interface org.elasticsearch.index.mapper.Mapper
 
EMPTY_CLUSTER_BLOCK - Static variable in class org.elasticsearch.cluster.block.ClusterBlocks
 
EMPTY_DOC_SET - Static variable in class org.elasticsearch.common.lucene.docset.DocSet
 
EMPTY_DOUBLE_ARRAY - Static variable in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
EMPTY_FIELDS - Static variable in class org.elasticsearch.search.highlight.vectorhighlight.SourceSimpleFragmentsBuilder
 
EMPTY_LIST - Static variable in class org.elasticsearch.cluster.node.DiscoveryNode
 
EMPTY_LOAD - Static variable in class org.elasticsearch.monitor.os.OsStats
 
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_TYPE_ARRAY - Static variable in class org.elasticsearch.common.inject.internal.MoreTypes
 
emptyDelta() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
emptyFieldNames() - Method in class org.elasticsearch.search.internal.SearchContext
 
EmptyScorer - Class in org.elasticsearch.common.lucene.search
 
EmptyScorer(Similarity) - Constructor for class org.elasticsearch.common.lucene.search.EmptyScorer
 
ENABLE_GEOHASH - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
ENABLE_LATLON - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
enableConsoleLogging() - Static method in class org.elasticsearch.common.logging.Loggers
 
enabled() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
enabled(boolean) - 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(boolean) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
enabled() - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
enabled - Variable in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
enabled(boolean) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Defaults
 
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(boolean) - 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(boolean) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
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
 
enableGcDeletes(boolean) - Method in interface org.elasticsearch.index.engine.Engine
 
enableGcDeletes(boolean) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
enableGeoHash(boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
enableLatLon(boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
enableMerge() - Method in interface org.elasticsearch.index.merge.policy.EnableMergePolicy
 
enableMerge() - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy
 
enableMerge() - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy
 
enableMerge() - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider
 
EnableMergePolicy - Interface in org.elasticsearch.index.merge.policy
Allows to control if merge should be enabled on the current thread or not.
enablePositionIncrements() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
enablePositionIncrements(boolean) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
enablePositionIncrements() - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
 
enablePositionIncrements(boolean) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
Set to true to enable position increments in result query.
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 - Static variable in class org.elasticsearch.common.Base64
Specify encoding in first bit.
encode(ByteBuffer, ByteBuffer) - Static method in class org.elasticsearch.common.Base64
Performs Base64 encoding on the raw ByteBuffer, writing it to the encoded ByteBuffer.
encode(ByteBuffer, CharBuffer) - Static method in class org.elasticsearch.common.Base64
Performs Base64 encoding on the raw ByteBuffer, writing it to the encoded CharBuffer.
encode(double, double) - Static method in class org.elasticsearch.index.search.geo.GeoHashUtils
 
encode(double, double, int) - Static method in class org.elasticsearch.index.search.geo.GeoHashUtils
Encodes the given latitude and longitude into a geohash
encodeBytes(byte[]) - Static method in class org.elasticsearch.common.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int) - Static method in class org.elasticsearch.common.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int) - Static method in class org.elasticsearch.common.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int, int) - Static method in class org.elasticsearch.common.Base64
Encodes a byte array into Base64 notation.
encodeBytesToBytes(byte[]) - Static method in class org.elasticsearch.common.Base64
Similar to Base64.encodeBytes(byte[]) but returns a byte array instead of instantiating a String.
encodeBytesToBytes(byte[], int, int, int) - Static method in class org.elasticsearch.common.Base64
Similar to Base64.encodeBytes(byte[], int, int, int) but returns a byte array instead of instantiating a String.
encodeFileToFile(String, String) - Static method in class org.elasticsearch.common.Base64
Reads infile and encodes it to outfile.
encodeFromFile(String) - Static method in class org.elasticsearch.common.Base64
Convenience method for reading a binary file and base64-encoding it.
encodeHex(byte[]) - Static method in class org.elasticsearch.common.Hex
Converts an array of bytes into an array of characters representing the hexadecimal values of each byte in order.
encodeHex(byte[], boolean) - Static method in class org.elasticsearch.common.Hex
Converts an array of bytes into an array of characters representing the hexadecimal values of each byte in order.
encodeHex(byte[], char[]) - Static method in class org.elasticsearch.common.Hex
Converts an array of bytes into an array of characters representing the hexadecimal values of each byte in order.
encodeHexString(byte[]) - Static method in class org.elasticsearch.common.Hex
Converts an array of bytes into a String representing the hexadecimal values of each byte in order.
encodeObject(Serializable) - Static method in class org.elasticsearch.common.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeObject(Serializable, int) - Static method in class org.elasticsearch.common.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
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.Field
 
encoder(String) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
encodeToFile(byte[], String) - Static method in class org.elasticsearch.common.Base64
Convenience method for encoding data to a file.
end() - Method in class org.apache.lucene.analysis.pattern.PatternTokenizer
 
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
endObject() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
endOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
endsWithIgnoreCase(String, String) - Static method in class org.elasticsearch.common.Strings
Test if the given String ends with the specified suffix, ignoring upper/lower case.
endTime(long) - Method in class org.elasticsearch.index.engine.Engine.Create
 
endTime() - Method in class org.elasticsearch.index.engine.Engine.Create
Returns operation end time in nanoseconds.
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.Index
 
endTime() - Method in class org.elasticsearch.index.engine.Engine.Index
Returns operation end time in nanoseconds.
endTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
Engine - Interface in org.elasticsearch.index.engine
 
engine() - Method in interface org.elasticsearch.index.service.IndexService
 
engine() - Method in class org.elasticsearch.index.service.InternalIndexService
 
engine() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
Engine.Create - Class in org.elasticsearch.index.engine
 
Engine.Create(DocumentMapper, Term, ParsedDocument) - Constructor for class org.elasticsearch.index.engine.Engine.Create
 
Engine.Delete - Class in org.elasticsearch.index.engine
 
Engine.Delete(String, String, Term) - Constructor for class org.elasticsearch.index.engine.Engine.Delete
 
Engine.DeleteByQuery - Class in org.elasticsearch.index.engine
 
Engine.DeleteByQuery(Query, BytesReference, String[], Filter, String...) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
Engine.FailedEngineListener - Interface in org.elasticsearch.index.engine
 
Engine.Flush - Class in org.elasticsearch.index.engine
 
Engine.Flush() - Constructor for class org.elasticsearch.index.engine.Engine.Flush
 
Engine.Get - Class in org.elasticsearch.index.engine
 
Engine.Get(boolean, Term) - Constructor for class org.elasticsearch.index.engine.Engine.Get
 
Engine.GetResult - Class in org.elasticsearch.index.engine
 
Engine.GetResult(boolean, long, Translog.Source) - Constructor for class org.elasticsearch.index.engine.Engine.GetResult
 
Engine.GetResult(Engine.Searcher, UidField.DocIdAndVersion) - Constructor for class org.elasticsearch.index.engine.Engine.GetResult
 
Engine.Index - Class in org.elasticsearch.index.engine
 
Engine.Index(DocumentMapper, Term, ParsedDocument) - Constructor for class org.elasticsearch.index.engine.Engine.Index
 
Engine.IndexingOperation - Interface in org.elasticsearch.index.engine
 
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.Optimize - Class in org.elasticsearch.index.engine
 
Engine.Optimize() - Constructor for class org.elasticsearch.index.engine.Engine.Optimize
 
Engine.RecoveryHandler - Interface in org.elasticsearch.index.engine
Recovery allow to start the recovery process.
Engine.Refresh - Class in org.elasticsearch.index.engine
 
Engine.Refresh(boolean) - Constructor for class org.elasticsearch.index.engine.Engine.Refresh
 
Engine.Searcher - Interface in org.elasticsearch.index.engine
 
Engine.SimpleSearcher - Class in org.elasticsearch.index.engine
 
Engine.SimpleSearcher(IndexSearcher) - Constructor for class org.elasticsearch.index.engine.Engine.SimpleSearcher
 
Engine.SnapshotHandler<T> - Interface in org.elasticsearch.index.engine
 
ENGINE_TYPE - Static variable in class org.elasticsearch.index.engine.IndexEngineModule.EngineSettings
 
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
 
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
 
EngineModule - Class in org.elasticsearch.index.engine
 
EngineModule(Settings) - Constructor for class org.elasticsearch.index.engine.EngineModule
 
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
 
ensureCapacity(int) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.ensureCapacity(int)
entries() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
entries() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet
An ordered list of histogram facet entries.
entries() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
entries() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
entries() - Method in interface org.elasticsearch.search.facet.geodistance.GeoDistanceFacet
An ordered list of geo distance facet entries.
entries - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
entries() - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
entries() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet
 
entries() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
entries() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet
An ordered list of histogram facet entries.
entries() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
entries() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
entries() - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
entries() - Method in interface org.elasticsearch.search.facet.range.RangeFacet
An ordered list of range facet entries.
entries() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
entries() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
entries() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
entries() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
entries() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
entries() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
entries() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
entries() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
entries() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet
The terms and counts.
entries() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
entries() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
entries() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
entries() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet
The terms and counts.
entries() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData
 
entriesStats() - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
entriesStats() - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
entriesStats() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
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 jsr166e.ConcurrentHashMapV8
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class jsr166e.LongAdderTable
Returns the current set of key-value mappings.
entrySet() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
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
 
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
 
EPSILON - Static variable in class org.elasticsearch.common.math.MathUtils
Smallest positive number such that 1 - EPSILON is not numerically equal to 1.
equal(Object, Object) - Static method in class org.elasticsearch.common.inject.internal.Objects
Determines whether two possibly-null objects are equal.
equals(Object) - Method in class jsr166e.ConcurrentHashMapV8
Compares the specified object with this map for equality.
equals(Object) - Method in class jsr166e.extra.ReadMostlyVector
 
equals(Object) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
equals(Object) - Method in class org.apache.lucene.search.PublicTermsFilter
 
equals(Object) - Method in class org.apache.lucene.search.XTermsFilter
 
equals(Object) - Method in class org.elasticsearch.action.GenericAction
 
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.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 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.HashedBytesArray
 
equals(Object) - Method in class org.elasticsearch.common.collect.Tuple
 
equals(Object) - Method in class org.elasticsearch.common.compress.CompressedString
 
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.IndexCommitDelegate
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
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.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.TermFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
equals(Object) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
equals(double, double) - Static method in class org.elasticsearch.common.math.MathUtils
Returns true iff both arguments are NaN or neither is NaN and they are equal
equals(double, double, double) - Static method in class org.elasticsearch.common.math.MathUtils
Returns true iff both arguments are equal or within the range of allowed error (inclusive).
equals(double, double, int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns true iff both arguments are equal or within the range of allowed error (inclusive).
equals(double[], double[]) - Static method in class org.elasticsearch.common.math.MathUtils
Returns true iff both arguments are null or have same dimensions and all their elements are equals
equals(Object) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
equals(Object) - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
equals(Object) - Method in class org.elasticsearch.common.transport.LocalTransportAddress
 
equals(String, String) - Method in class org.elasticsearch.common.trove.StringIdentityHashingStrategy
 
equals(Object) - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
equals(Object) - Method in class org.elasticsearch.common.unit.SizeValue
 
equals(Object) - Method in class org.elasticsearch.common.unit.TimeValue
 
equals(Object) - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
equals(Object) - Method in class org.elasticsearch.common.UUID
Compares this object to the specified object.
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.Index
 
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.geo.GeoDistanceFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
equals(Object) - Method in class org.elasticsearch.index.search.geo.Point
 
equals(Object) - Method in class org.elasticsearch.index.search.nested.BlockJoinQuery
 
equals(Object) - Method in class org.elasticsearch.index.search.nested.IncludeAllChildrenQuery
 
equals(Object) - Method in class org.elasticsearch.index.search.nested.NestedDocsFilter
 
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.search.UidFilter
 
equals(Object) - Method in class org.elasticsearch.index.shard.ShardId
 
equals(Object) - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
equals(Object) - Method in class org.elasticsearch.river.RiverName
 
equals(Object) - Method in class org.elasticsearch.script.ScriptService.CacheKey
 
equals(Object) - Method in class org.elasticsearch.search.SearchShardTarget
 
error() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
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
 
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
 
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.QueryParserSettings
 
escape(boolean) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
escapedTags() - Method in class org.elasticsearch.index.analysis.HtmlStripCharFilterFactory
 
EsExecutors - Class in org.elasticsearch.common.util.concurrent
 
ESLogger - Interface in org.elasticsearch.common.logging
 
ESLoggerFactory - Class in org.elasticsearch.common.logging
 
ESLoggerFactory() - Constructor for class org.elasticsearch.common.logging.ESLoggerFactory
 
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
 
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(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
 
EsThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
 
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.
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
 
estimatedTimeInMillis() - 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.store.Store
 
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
 
EvenShardsCountAllocator - Class in org.elasticsearch.cluster.routing.allocation.allocator
 
EvenShardsCountAllocator(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
evictions() - Method in interface org.elasticsearch.index.cache.field.data.FieldDataCache
 
evictions() - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
evictions() - Method in class org.elasticsearch.index.cache.field.data.resident.ResidentFieldDataCache
 
evictions() - Method in class org.elasticsearch.index.cache.field.data.soft.SoftFieldDataCache
 
evictions() - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
evictions() - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
evictions() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
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.
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.elasticsearch.http.netty.HttpRequestHandler
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.elasticsearch.transport.netty.MessageChannelHandler
 
ExceptionsHelper - Class in org.elasticsearch
 
ExceptionsHelper() - Constructor for class org.elasticsearch.ExceptionsHelper
 
exclude(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
 
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 - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
excludes() - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsContext.PartialField
 
exec() - Method in class jsr166y.CountedCompleter
Implements execution conventions for CountedCompleters
exec() - Method in class jsr166y.ForkJoinTask
Immediately performs the base action of this task and returns true if, upon return from this method, this task is guaranteed to have completed normally.
exec() - Method in class jsr166y.RecursiveAction
Implements execution conventions for RecursiveActions.
exec() - Method in class jsr166y.RecursiveTask
Implements execution conventions for RecursiveTask.
executable(Object, Map) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService
 
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, Map) - Method in class org.elasticsearch.script.ScriptService
 
executable(CompiledScript, Map) - Method in class org.elasticsearch.script.ScriptService
 
ExecutableScript - Interface in org.elasticsearch.script
An executable script, can't be used concurrently.
execute(ForkJoinTask<?>) - Method in class jsr166y.ForkJoinPool
Arranges for (asynchronous) execution of the given task.
execute(Runnable) - Method in class jsr166y.ForkJoinPool
 
execute() - Method in interface org.elasticsearch.action.ActionRequestBuilder
 
execute(ActionListener<Response>) - Method in interface org.elasticsearch.action.ActionRequestBuilder
 
execute() - Method in class org.elasticsearch.action.admin.cluster.support.BaseClusterRequestBuilder
 
execute(ActionListener<Response>) - Method in class org.elasticsearch.action.admin.cluster.support.BaseClusterRequestBuilder
 
execute() - Method in class org.elasticsearch.action.admin.indices.support.BaseIndicesRequestBuilder
 
execute(ActionListener<Response>) - Method in class org.elasticsearch.action.admin.indices.support.BaseIndicesRequestBuilder
 
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() - Method in class org.elasticsearch.action.support.BaseRequestBuilder
 
execute(ActionListener<Response>) - Method in class org.elasticsearch.action.support.BaseRequestBuilder
 
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) - Method in class org.elasticsearch.action.TransportActionNodeProxy
 
execute(DiscoveryNode, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.TransportActionNodeProxy
 
execute(Action<Request, Response, RequestBuilder>, Request) - Method in interface org.elasticsearch.client.Client
Executes a generic action, denoted by an Action.
execute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in interface org.elasticsearch.client.Client
Executes a generic action, denoted by an Action.
execute(ClusterAction<Request, Response, RequestBuilder>, Request) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
execute(ClusterAction<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
execute(IndicesAction<Request, Response, RequestBuilder>, Request) - Method in interface org.elasticsearch.client.IndicesAdminClient
 
execute(IndicesAction<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in interface org.elasticsearch.client.IndicesAdminClient
 
execute(Action<Request, Response, RequestBuilder>, Request) - Method in class org.elasticsearch.client.node.NodeClient
 
execute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeClient
 
execute(ClusterAction<Request, Response, RequestBuilder>, Request) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
execute(ClusterAction<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
execute(IndicesAction<Request, Response, RequestBuilder>, Request) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
execute(IndicesAction<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
execute(Action<Request, Response, RequestBuilder>, Request) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
execute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
execute(ClusterAction<Request, Response, RequestBuilder>, Request) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
execute(ClusterAction<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
execute(IndicesAction<Request, Response, RequestBuilder>, Request) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
execute(IndicesAction<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
execute(Action<Request, Response, RequestBuilder>, Request) - Method in class org.elasticsearch.client.transport.TransportClient
 
execute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.TransportClient
 
execute(TransportClientNodesService.NodeCallback<T>) - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
execute(TransportClientNodesService.NodeListenerCallback<Response>, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
execute(ClusterState) - Method in interface org.elasticsearch.cluster.ClusterStateUpdateTask
Update the cluster state based on the current state.
execute(RiverClusterState) - Method in interface org.elasticsearch.river.cluster.RiverClusterStateUpdateTask
 
execute(Object, Map) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService
 
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(CompiledScript, Map) - Method in class org.elasticsearch.script.ScriptService
 
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.scan.ScanContext
 
execute(SearchContext) - Method in interface org.elasticsearch.search.SearchPhase
 
executeDfsPhase(InternalSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeFetchPhase(InternalSearchRequest) - 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(FetchSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeQueryPhase(InternalSearchRequest) - 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(InternalSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
executeScan(InternalScrollSearchRequest) - Method in class org.elasticsearch.search.SearchService
 
execution(String) - Method in class org.elasticsearch.index.query.TermsFilterBuilder
Sets the execution mode for the terms filter.
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.reroute.TransportClusterRerouteAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
executor() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
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.TransportIndicesExistsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
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.refresh.TransportRefreshAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.settings.TransportUpdateSettingsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
executor() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
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.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.index.TransportShardDeleteAction
 
executor() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
executor() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
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.support.broadcast.TransportBroadcastOperationAction
 
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.update.TransportUpdateAction
 
executor() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
executor() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
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.store.TransportNodesListShardStoreMetaData
 
executor() - Method in interface org.elasticsearch.indices.warmer.IndicesWarmer.Listener
 
executor(String) - Method in class org.elasticsearch.threadpool.ThreadPool
 
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
 
executor() - Method in class org.elasticsearch.transport.VoidTransportResponseHandler
 
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 hte missing filter include documents where the field doesn't exists in the docs.
existingFiles() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
 
exists() - Method in class org.elasticsearch.action.admin.indices.exists.IndicesExistsResponse
 
exists() - Method in class org.elasticsearch.action.explain.ExplainResponse
 
exists() - Method in class org.elasticsearch.action.get.GetResponse
Does the document exists.
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(IndicesExistsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
exists(IndicesExistsRequest, ActionListener<IndicesExistsResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
exists() - Method in class org.elasticsearch.common.lucene.Lucene.ExistsCollector
 
exists() - Method in class org.elasticsearch.index.engine.Engine.GetResult
 
exists() - Method in class org.elasticsearch.index.get.GetResult
Does the document exists.
existsCount() - Method in class org.elasticsearch.index.get.GetStats
 
ExistsFieldQueryExtension - Class in org.apache.lucene.queryParser
 
ExistsFieldQueryExtension() - Constructor for class org.apache.lucene.queryParser.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
 
existsTime() - Method in class org.elasticsearch.index.get.GetStats
 
existsTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
 
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.
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
 
expectedNumberOfOperations() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
expectedNumberOfOperations() - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Translog
 
expectedNumberOfOperations(int) - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Translog
 
expectedRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
expectedRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
expectedSuccessfulOps - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
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(int) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
explain(Explanation) - Method in interface org.elasticsearch.script.ExplainableSearchScript
Build the explanation of the current document being scored
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.SearchContext
 
explain(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
 
ExplainableSearchScript - Interface in org.elasticsearch.script
To be implemented by SearchScript which can provided an Explanation of the score
ExplainAction - Class in org.elasticsearch.action.explain
Entry point for the explain feature.
explainFactor(int) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
explainFactor(int) - Method in interface org.elasticsearch.common.lucene.search.function.ScoreFunction
 
explainFactor(int) - Method in class org.elasticsearch.index.query.CustomScoreQueryParser.ScriptScoreFunction
 
ExplainFetchSubPhase - Class in org.elasticsearch.search.fetch.explain
 
ExplainFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.explain.ExplainFetchSubPhase
 
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(boolean) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
 
ExplainResponse(boolean, Explanation) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
 
ExplainResponse(boolean, Explanation, GetResult) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
 
explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
explainScore(int, Explanation) - Method in interface org.elasticsearch.common.lucene.search.function.ScoreFunction
 
explainScore(int, Explanation) - Method in class org.elasticsearch.index.query.CustomScoreQueryParser.ScriptScoreFunction
 
ExplainSourceBuilder - Class in org.elasticsearch.action.explain
 
ExplainSourceBuilder() - Constructor for class org.elasticsearch.action.explain.ExplainSourceBuilder
 
explanation() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
explanation() - Method in class org.elasticsearch.action.explain.ExplainResponse
 
explanation() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
explanation() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
 
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
 
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
 
EXPORT - Static variable in class org.elasticsearch.jmx.JmxService.SettingsConstants
 
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
 
ExtendedIndexSearcher - Class in org.apache.lucene.index
 
ExtendedIndexSearcher(ExtendedIndexSearcher) - Constructor for class org.apache.lucene.index.ExtendedIndexSearcher
 
ExtendedIndexSearcher(IndexReader) - Constructor for class org.apache.lucene.index.ExtendedIndexSearcher
 
extensions() - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService
 
extensions() - Method in class org.elasticsearch.script.NativeScriptEngineService
 
extensions() - Method in interface org.elasticsearch.script.ScriptEngineService
 
externalValue(Object) - Method in class org.elasticsearch.index.mapper.ParseContext
 
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, long, Map<String, Object>, XContentType, BytesReference) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
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.
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.index.search.child.TopChildrenQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.index.search.nested.BlockJoinQuery
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.index.search.nested.IncludeAllChildrenQuery
 
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.InternalSearchRequest
 
extraSource(BytesReference) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
ExtTDoubleObjectHashMap<V> - Class in org.elasticsearch.common.trove
 
ExtTDoubleObjectHashMap() - Constructor for class org.elasticsearch.common.trove.ExtTDoubleObjectHashMap
 
ExtTDoubleObjectHashMap(int) - Constructor for class org.elasticsearch.common.trove.ExtTDoubleObjectHashMap
 
ExtTDoubleObjectHashMap(int, float) - Constructor for class org.elasticsearch.common.trove.ExtTDoubleObjectHashMap
 
ExtTDoubleObjectHashMap(int, float, double) - Constructor for class org.elasticsearch.common.trove.ExtTDoubleObjectHashMap
 
ExtTDoubleObjectHashMap(TDoubleObjectMap<V>) - Constructor for class org.elasticsearch.common.trove.ExtTDoubleObjectHashMap
 
ExtTHashMap<K,V> - Class in org.elasticsearch.common.trove
 
ExtTHashMap() - Constructor for class org.elasticsearch.common.trove.ExtTHashMap
 
ExtTHashMap(int) - Constructor for class org.elasticsearch.common.trove.ExtTHashMap
 
ExtTHashMap(int, float) - Constructor for class org.elasticsearch.common.trove.ExtTHashMap
 
ExtTHashMap(Map<K, V>) - Constructor for class org.elasticsearch.common.trove.ExtTHashMap
 
ExtTHashMap(THashMap<K, V>) - Constructor for class org.elasticsearch.common.trove.ExtTHashMap
 
ExtTIntArrayList - Class in org.elasticsearch.common.trove
 
ExtTIntArrayList() - Constructor for class org.elasticsearch.common.trove.ExtTIntArrayList
 
ExtTIntArrayList(int) - Constructor for class org.elasticsearch.common.trove.ExtTIntArrayList
 
ExtTIntArrayList(int[]) - Constructor for class org.elasticsearch.common.trove.ExtTIntArrayList
 
ExtTLongObjectHashMap<V> - Class in org.elasticsearch.common.trove
 
ExtTLongObjectHashMap() - Constructor for class org.elasticsearch.common.trove.ExtTLongObjectHashMap
 
ExtTLongObjectHashMap(int) - Constructor for class org.elasticsearch.common.trove.ExtTLongObjectHashMap
 
ExtTLongObjectHashMap(int, float) - Constructor for class org.elasticsearch.common.trove.ExtTLongObjectHashMap
 
ExtTLongObjectHashMap(int, float, long) - Constructor for class org.elasticsearch.common.trove.ExtTLongObjectHashMap
 
ExtTLongObjectHashMap(TLongObjectMap<V>) - Constructor for class org.elasticsearch.common.trove.ExtTLongObjectHashMap
 
ExtTObjectIntHasMap<T> - Class in org.elasticsearch.common.trove
 
ExtTObjectIntHasMap() - Constructor for class org.elasticsearch.common.trove.ExtTObjectIntHasMap
 
ExtTObjectIntHasMap(int) - Constructor for class org.elasticsearch.common.trove.ExtTObjectIntHasMap
 
ExtTObjectIntHasMap(int, float) - Constructor for class org.elasticsearch.common.trove.ExtTObjectIntHasMap
 
ExtTObjectIntHasMap(int, float, int) - Constructor for class org.elasticsearch.common.trove.ExtTObjectIntHasMap
 

F

facet() - Method in class org.elasticsearch.index.search.nested.NestedChildrenCollector
 
facet(AbstractFacetBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Add a facet to perform as part of the search.
facet() - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetCollector
 
Facet - Interface in org.elasticsearch.search.facet
A search facet.
facet() - Method in class org.elasticsearch.search.facet.FacetCollector
 
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() - Method in class org.elasticsearch.search.facet.filter.FilterFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedCountHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueScriptHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.histogram.unbounded.CountHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.histogram.unbounded.FullHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.histogram.unbounded.ScriptHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueHistogramFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueScriptHistogramFacetCollector
 
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.
facet() - Method in class org.elasticsearch.search.facet.query.QueryFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.range.KeyValueRangeFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.range.RangeFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.range.ScriptRangeFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.statistical.ScriptStatisticalFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteOrdinalsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.index.IndexNameFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.strings.ScriptTermsStringFieldFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector
 
facet() - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector
 
FacetBinaryParseElement - Class in org.elasticsearch.search.facet
 
FacetBinaryParseElement(FacetProcessors) - Constructor for class org.elasticsearch.search.facet.FacetBinaryParseElement
 
FacetBuilders - Class in org.elasticsearch.search.facet
 
FacetBuilders() - Constructor for class org.elasticsearch.search.facet.FacetBuilders
 
FacetCollector - Class in org.elasticsearch.search.facet
 
FacetCollector() - Constructor for class org.elasticsearch.search.facet.FacetCollector
 
facetCollectors() - Method in class org.elasticsearch.search.facet.SearchContextFacets
 
facetFilter - Variable in class org.elasticsearch.search.facet.AbstractFacetBuilder
 
facetFilter(FilterBuilder) - Method in class org.elasticsearch.search.facet.AbstractFacetBuilder
 
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(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
 
facetName - Variable in class org.elasticsearch.search.facet.AbstractFacetCollector
 
FacetParseElement - Class in org.elasticsearch.search.facet
facets : { facet1: { query : { ...
FacetParseElement(FacetProcessors) - Constructor for class org.elasticsearch.search.facet.FacetParseElement
 
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
 
FacetProcessor - Interface in org.elasticsearch.search.facet
 
FacetProcessors - Class in org.elasticsearch.search.facet
 
FacetProcessors(Set<FacetProcessor>) - Constructor for class org.elasticsearch.search.facet.FacetProcessors
 
facets() - Method in class org.elasticsearch.action.search.SearchResponse
The search facets.
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.InternalFacets
The list of Facets.
facets() - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.StaticAggregatorValueProc
 
facets() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.StaticAggregatorValueProc
 
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.joda.TimeZoneRounding.Builder
 
factor(int) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
factor(int) - Method in interface org.elasticsearch.common.lucene.search.function.ScoreFunction
 
factor(int) - Method in class org.elasticsearch.index.query.CustomScoreQueryParser.ScriptScoreFunction
 
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() - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
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.
factor() - Method in interface org.elasticsearch.search.internal.ScopePhase.TopDocsPhase
 
factorDistance(double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
factorDistance(int, DistanceUnit, double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
factorDistance02(double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
factorDistance13(double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
factorDistanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
factorial(int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns n!.
factorialDouble(int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns n!.
factorialLog(int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the natural logarithm of n!.
FACTORY - Static variable in class org.elasticsearch.search.warmer.IndexWarmersMetaData
 
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.
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
 
failed() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
Is this a failed execution of an operation.
failed() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
Is this a failed execution?
failed(Throwable) - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
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
 
failedContributors() - Method in class org.elasticsearch.monitor.dump.DumpGenerator.Result
 
failedDelete(Engine.Delete) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
failedIndex(Engine.Index) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
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
 
FailedRerouteAllocation(AllocationDeciders, RoutingNodes, DiscoveryNodes, ShardRouting) - Constructor for class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation
 
failedShard() - Method in class org.elasticsearch.cluster.routing.allocation.FailedRerouteAllocation
 
failedShards() - Method in class org.elasticsearch.action.delete.index.IndexDeleteResponse
The failed number of shards the delete by query was executed on.
failedShards() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
The failed number of shards the delete by query was executed on.
failedShards() - Method in class org.elasticsearch.action.search.SearchResponse
The failed number of shards the search was executed on.
failedShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationResponse
The failed shards this request was executed on.
FailedToGenerateSourceMapperException - Exception in org.elasticsearch.index.mapper
 
FailedToGenerateSourceMapperException(String) - Constructor for exception org.elasticsearch.index.mapper.FailedToGenerateSourceMapperException
 
FailedToGenerateSourceMapperException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.FailedToGenerateSourceMapperException
 
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
 
failure() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The actual failure object if there was a failure.
failure() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
The failure if relevant.
failure - Static variable in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappy
 
failureMessage() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The failure message, null if it did not fail.
failureMessage() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
The actual failure message, null if its not a failure.
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
 
FastByteArrayInputStream - Class in org.elasticsearch.common.io
 
FastByteArrayInputStream(byte[]) - Constructor for class org.elasticsearch.common.io.FastByteArrayInputStream
Creates a ByteArrayInputStream so that it uses buf as its buffer array.
FastByteArrayInputStream(byte[], int, int) - Constructor for class org.elasticsearch.common.io.FastByteArrayInputStream
Creates ByteArrayInputStream that uses buf as its buffer array.
FastByteArrayOutputStream - Class in org.elasticsearch.common.io
Similar to ByteArrayOutputStream just not synced.
FastByteArrayOutputStream() - Constructor for class org.elasticsearch.common.io.FastByteArrayOutputStream
Creates a new byte array output stream.
FastByteArrayOutputStream(int) - Constructor for class org.elasticsearch.common.io.FastByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
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.
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.
fetchCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
fetchCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
FetchPhase - Class in org.elasticsearch.search.fetch
 
FetchPhase(HighlightPhase, ScriptFieldsFetchSubPhase, PartialFieldsFetchSubPhase, MatchedFiltersFetchSubPhase, ExplainFetchSubPhase, VersionFetchSubPhase) - 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.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.SearchContext
 
FetchSearchRequest - Class in org.elasticsearch.search.fetch
 
FetchSearchRequest() - Constructor for class org.elasticsearch.search.fetch.FetchSearchRequest
 
FetchSearchRequest(long, ExtTIntArrayList) - Constructor for class org.elasticsearch.search.fetch.FetchSearchRequest
 
FetchSearchRequest(long, int[]) - Constructor for class org.elasticsearch.search.fetch.FetchSearchRequest
 
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
 
FetchSubPhase - Interface in org.elasticsearch.search.fetch
 
FetchSubPhase.HitContext - Class in org.elasticsearch.search.fetch
 
FetchSubPhase.HitContext() - Constructor for class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
fetchTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
fetchTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
field(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
 
field() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
 
field(String) - Method in class org.elasticsearch.action.get.GetResponse
 
field(String, String) - Static method in class org.elasticsearch.common.lucene.DocumentBuilder
 
field(String, String, Field.Store, Field.Index) - Static method in class org.elasticsearch.common.lucene.DocumentBuilder
 
field(String, String, Field.Store, Field.Index, Field.TermVector) - Static method in class org.elasticsearch.common.lucene.DocumentBuilder
 
field(String, byte[], Field.Store) - Static method in class org.elasticsearch.common.lucene.DocumentBuilder
 
field(String, byte[], int, int, Field.Store) - Static method in class org.elasticsearch.common.lucene.DocumentBuilder
 
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
 
field(String, 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...) - 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(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.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() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
field(String) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
field(String) - Method in class org.elasticsearch.search.lookup.DocLookup
 
field(String) - Method in interface org.elasticsearch.search.SearchHit
The hit field matching the given field name.
FIELD_DATA_CACHE_TYPE - Static variable in class org.elasticsearch.index.cache.field.data.FieldDataCacheModule.FieldDataCacheSettings
 
FieldBuilder - Class in org.elasticsearch.common.lucene
 
fieldCaseConversion(XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
fieldData() - Method in class org.elasticsearch.index.cache.IndexCache
 
fieldData - Variable in class org.elasticsearch.index.field.data.DocFieldData
 
FieldData<Doc extends DocFieldData> - Class in org.elasticsearch.index.field.data
 
FieldData(String) - Constructor for class org.elasticsearch.index.field.data.FieldData
 
fieldData - Variable in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
fieldData - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
FieldData.OrdinalInDocProc - Interface in org.elasticsearch.index.field.data
 
FieldData.StringValueInDocProc - Interface in org.elasticsearch.index.field.data
 
FieldData.StringValueProc - Interface in org.elasticsearch.index.field.data
 
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
 
FieldDataCache - Interface in org.elasticsearch.index.cache.field.data
 
fieldDataCache - Variable in class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
fieldDataCache - Variable in class org.elasticsearch.index.field.data.support.NumericFieldDataComparator
 
fieldDataCache - Variable in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
fieldDataCache - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
fieldDataCache() - Method in class org.elasticsearch.search.internal.SearchContext
 
fieldDataCache() - Method in class org.elasticsearch.search.lookup.DocLookup
 
FieldDataCacheModule - Class in org.elasticsearch.index.cache.field.data
 
FieldDataCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.field.data.FieldDataCacheModule
 
FieldDataCacheModule.FieldDataCacheSettings - Class in org.elasticsearch.index.cache.field.data
 
FieldDataCacheModule.FieldDataCacheSettings() - Constructor for class org.elasticsearch.index.cache.field.data.FieldDataCacheModule.FieldDataCacheSettings
 
FieldDataLoader - Class in org.elasticsearch.index.field.data.support
 
FieldDataLoader() - Constructor for class org.elasticsearch.index.field.data.support.FieldDataLoader
 
FieldDataLoader.FreqsTypeLoader<T extends FieldData> - Class in org.elasticsearch.index.field.data.support
 
FieldDataLoader.FreqsTypeLoader() - Constructor for class org.elasticsearch.index.field.data.support.FieldDataLoader.FreqsTypeLoader
 
FieldDataLoader.TypeLoader<T extends FieldData> - Interface in org.elasticsearch.index.field.data.support
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataMissingComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataMissingComparator
 
FieldDataType<T extends FieldData> - Interface in org.elasticsearch.index.field.data
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataMissingComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataMissingComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataMissingComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataMissingComparator
 
fieldDataType() - Method in class org.elasticsearch.index.field.data.support.NumericFieldDataComparator
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
fieldDataType() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.GeoStringFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
fieldDataType() - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
FieldDataType.DefaultTypes - Class in org.elasticsearch.index.field.data
 
FieldDataType.DefaultTypes() - Constructor for class org.elasticsearch.index.field.data.FieldDataType.DefaultTypes
 
FieldDataType.ExtendedFieldComparatorSource - Class in org.elasticsearch.index.field.data
 
FieldDataType.ExtendedFieldComparatorSource() - Constructor for class org.elasticsearch.index.field.data.FieldDataType.ExtendedFieldComparatorSource
 
fieldEvictions() - Method in class org.elasticsearch.index.cache.CacheStats
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Numeric field level filter are basically range queries with same value and included.
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
fieldFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
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 interface org.elasticsearch.index.mapper.FieldMapperListener
 
fieldMapper(String) - Method in class org.elasticsearch.index.query.QueryParseContext
 
FieldMapper.Names - Class in org.elasticsearch.index.mapper
 
FieldMapper.Names(String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Names
 
FieldMapper.Names(String, String, String, String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Names
 
FieldMapper.Names(String, String, String, String, String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Names
 
FieldMapperListener - Interface in org.elasticsearch.index.mapper
 
FieldMapperListener.Aggregator - Class in org.elasticsearch.index.mapper
 
FieldMapperListener.Aggregator() - Constructor for class org.elasticsearch.index.mapper.FieldMapperListener.Aggregator
 
fieldMappers - Variable in class org.elasticsearch.index.mapper.FieldMapperListener.Aggregator
 
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.
FieldMappersFieldSelector - Class in org.elasticsearch.index.mapper.selector
 
FieldMappersFieldSelector() - Constructor for class org.elasticsearch.index.mapper.selector.FieldMappersFieldSelector
 
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.field.data.FieldData
The field name of this field data.
fieldName - Variable in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
fieldName() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
fieldName() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
fieldName() - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
fieldName() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
FieldNameAnalyzer - Class in org.elasticsearch.index.analysis
 
FieldNameAnalyzer(Map<String, Analyzer>, Analyzer) - Constructor for class org.elasticsearch.index.analysis.FieldNameAnalyzer
 
fieldNames() - Method in class org.elasticsearch.search.internal.SearchContext
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Numeric field level query are basically range queries with same value and included.
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
A field query for the specified value.
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
fieldQuery(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
fieldQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, long) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, float) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, double) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, boolean) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that executes the query string against a field.
FieldQueryBuilder - Class in org.elasticsearch.index.query
A query that executes the query string against a field.
FieldQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, boolean) - Constructor for class org.elasticsearch.index.query.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder.Operator - Enum in org.elasticsearch.index.query
 
FieldQueryExtension - Interface in org.apache.lucene.queryParser
 
fieldQueryExtensions - Static variable in class org.apache.lucene.queryParser.MapperQueryParser
 
FieldQueryParser - Class in org.elasticsearch.index.query
 
FieldQueryParser(Settings) - Constructor for class org.elasticsearch.index.query.FieldQueryParser
 
fields() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
fields(List<String>) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
fields(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
fields() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
fields() - Method in class org.elasticsearch.action.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() - Method in class org.elasticsearch.action.get.GetResponse
 
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.get.GetResult
 
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.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() - 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.
fieldSelector() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
fieldSize() - Method in class org.elasticsearch.index.cache.CacheStats
 
fieldSizeInBytes() - Method in class org.elasticsearch.index.cache.CacheStats
 
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
 
FieldsTermsStringFacetCollector - Class in org.elasticsearch.search.facet.terms.strings
 
FieldsTermsStringFacetCollector(String, String[], int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, Pattern, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector
 
FieldsTermsStringFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.strings
 
FieldsTermsStringFacetCollector.AggregatorValueProc(TObjectIntHashMap<String>, ImmutableSet<String>, Pattern, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.AggregatorValueProc
 
FieldsTermsStringFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.strings
 
FieldsTermsStringFacetCollector.StaticAggregatorValueProc(TObjectIntHashMap<String>) - Constructor for class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.StaticAggregatorValueProc
 
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(String) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
FILE_CHUNK - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
 
FileChannelInputStream - Class in org.elasticsearch.common.io
 
FileChannelInputStream(FileChannel, long, long) - Constructor for class org.elasticsearch.common.io.FileChannelInputStream
 
fileChunkSize() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
 
fileExists(String) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
fileExists(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
fileExists(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
fileExists(String) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
fileLength(String) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
fileLength(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
Returns the actual file size, so will work with compound file format when compressed.
fileLength(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
fileModified(String) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
fileModified(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
fileModified(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
filePath() - Method in class org.elasticsearch.common.blobstore.fs.AbstractFsBlobContainer
 
files - Variable in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
files(int, long, int, long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
files(int, long) - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
files() - Method in class org.elasticsearch.monitor.dump.AbstractDump
 
files() - Method in interface org.elasticsearch.monitor.dump.Dump
 
FILES_INFO - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
 
FileSystemUtils - Class in org.elasticsearch.common.io
 
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.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 - Variable in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
 
filter() - Method in class org.elasticsearch.common.lucene.search.NotDeletedFilter
 
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(IndexReader, String, boolean) - Method in interface org.elasticsearch.index.cache.bloom.BloomCache
*Async* loads a bloom filter for the field name.
filter(IndexReader, String, boolean) - Method in class org.elasticsearch.index.cache.bloom.none.NoneBloomCache
 
filter(IndexReader, String, boolean) - Method in class org.elasticsearch.index.cache.bloom.simple.SimpleBloomCache
 
filter() - Method in class org.elasticsearch.index.cache.IndexCache
 
filter(FilterBuilder) - 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).
filter(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).
filter(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).
filter(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).
filter(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).
filter(XContentBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a query from a builder.
filter(Map) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a query from a map.
filter - Variable in class org.elasticsearch.search.facet.AbstractFacetCollector
 
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_PREFIX - Static variable in class org.elasticsearch.index.query.IndexQueryParserService.Defaults
 
filterAll() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
FilterAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
 
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
 
filterBlocks() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
filterBlocks(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
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 - Interface in org.elasticsearch.index.cache.filter
 
filterCache() - Method in class org.elasticsearch.search.internal.SearchContext
 
FilterCache.EntriesStats - Class in org.elasticsearch.index.cache.filter
 
FilterCache.EntriesStats(long, long) - Constructor for class org.elasticsearch.index.cache.filter.FilterCache.EntriesStats
 
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
 
FilterCacheModule.FilterCacheSettings() - Constructor for class org.elasticsearch.index.cache.filter.FilterCacheModule.FilterCacheSettings
 
FilterCacheValue<T> - Class in org.elasticsearch.index.cache.filter.support
 
FilterCacheValue(T) - Constructor for class org.elasticsearch.index.cache.filter.support.FilterCacheValue
 
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.
filterCount() - Method in class org.elasticsearch.index.cache.CacheStats
 
filtered(QueryBuilder, FilterBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated. Use filteredQuery instead (rename)
FilteredCollector - Class in org.elasticsearch.common.lucene.search
 
FilteredCollector(Collector, Filter) - Constructor for class org.elasticsearch.common.lucene.search.FilteredCollector
 
filteredIndexTemplates() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
filteredIndexTemplates(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
filteredIndices() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
filteredIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
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
 
filterEvictions() - Method in class org.elasticsearch.index.cache.CacheStats
 
filterFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
filterFacet(String, FilterBuilder) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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
 
FilterFacetCollector - Class in org.elasticsearch.search.facet.filter
 
FilterFacetCollector(String, Filter, FilterCache) - Constructor for class org.elasticsearch.search.facet.filter.FilterFacetCollector
 
FilterFacetProcessor - Class in org.elasticsearch.search.facet.filter
 
FilterFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.filter.FilterFacetProcessor
 
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.InternalSearchRequest
 
filteringAliases(String[]) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
filterKey() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
filterMemEvictions() - Method in class org.elasticsearch.index.cache.CacheStats
 
filterMetaData() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
filterMetaData(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
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.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
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.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.
filterNodeIds(DiscoveryNodes, String[]) - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
filterNodes() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
filterNodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
FilterParseElement - Class in org.elasticsearch.search.query
 
FilterParseElement() - Constructor for class org.elasticsearch.search.query.FilterParseElement
 
FilterParser - Interface in org.elasticsearch.index.query
 
filterParser(String) - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
FilterParserFactory - Interface in org.elasticsearch.index.query
 
filterParsers() - Method in class org.elasticsearch.indices.query.IndicesQueriesRegistry
 
filterRoutingTable() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
filterRoutingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
filters() - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
filters() - Method in class org.elasticsearch.common.lucene.search.OrFilter
 
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) - Constructor for class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
FiltersFunctionScoreQuery.FilterFunction - Class in org.elasticsearch.common.lucene.search.function
 
FiltersFunctionScoreQuery.FilterFunction(Filter, ScoreFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
 
FiltersFunctionScoreQuery.ScoreMode - Enum in org.elasticsearch.common.lucene.search.function
 
filterSize() - Method in class org.elasticsearch.index.cache.CacheStats
 
filterSizeInBytes() - Method in class org.elasticsearch.index.cache.CacheStats
 
finalize() - Method in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
Overriden to close the stream.
FINALIZE - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
 
findAllIndices() - Method in class org.elasticsearch.env.NodeEnvironment
 
findAllShardIds() - Method in class org.elasticsearch.env.NodeEnvironment
 
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
 
findCommitPoint(String, int) - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
findDeadlockedThreads() - Method in class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
findDeadlocks() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer
 
findEndOffset(StringBuilder, int) - Method in class org.elasticsearch.common.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
findForcedDeletesMerges(SegmentInfos) - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy
 
findForcedDeletesMerges(SegmentInfos) - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy
 
findForcedDeletesMerges(SegmentInfos) - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider
 
findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider
 
findMerges(SegmentInfos) - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy
 
findMerges(SegmentInfos) - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy
 
findMerges(SegmentInfos) - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider
 
findNameFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoint
 
findNameFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoints
 
findNameIndexFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoint
 
findNameTranslogFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoint
 
findPhysicalIndexFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoint
 
findPhysicalIndexFile(String) - Method in class org.elasticsearch.index.gateway.CommitPoints
 
findPrimaryForReplica(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
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.
findStartOffset(StringBuilder, int) - Method in class org.elasticsearch.common.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
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
 
finish() - Method in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
 
finish() - Method in interface org.elasticsearch.monitor.dump.Dump
 
finish() - Method in class org.elasticsearch.monitor.dump.SimpleDump
 
finishConstruction() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
 
FinnishAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
FinnishAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.FinnishAnalyzerProvider
 
firstElement() - Method in class jsr166e.extra.ReadMostlyVector
See Vector.firstElement()
firstOrNull() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
firstOrNull() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
Returns the first shard, or null, without incrementing the iterator.
firstPhaseName() - Method 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
 
FixedBitDocSet - Class in org.elasticsearch.common.lucene.docset
 
FixedBitDocSet(FixedBitSet) - Constructor for class org.elasticsearch.common.lucene.docset.FixedBitDocSet
 
FixedBitDocSet(int) - Constructor for class org.elasticsearch.common.lucene.docset.FixedBitDocSet
 
fixedSourceDistance(double, double, DistanceUnit) - Method in enum org.elasticsearch.index.search.geo.GeoDistance
 
fixedSourceDistance - Variable in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
fixedSourceDistance - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
fixNegativeQueryIfNeeded(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
 
flagsFromString(String) - Static method in class org.elasticsearch.common.regex.Regex
 
flagsToString(int) - Static method in class org.elasticsearch.common.regex.Regex
 
FLOAT - Static variable in class org.elasticsearch.index.field.data.FieldDataType.DefaultTypes
 
FloatDocFieldData - Class in org.elasticsearch.index.field.data.floats
 
FloatDocFieldData(FloatFieldData) - Constructor for class org.elasticsearch.index.field.data.floats.FloatDocFieldData
 
floatField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
FloatFieldData - Class in org.elasticsearch.index.field.data.floats
 
FloatFieldData(String, float[]) - Constructor for class org.elasticsearch.index.field.data.floats.FloatFieldData
 
FloatFieldData.ValueInDocProc - Interface in org.elasticsearch.index.field.data.floats
 
FloatFieldData.ValueProc - Interface in org.elasticsearch.index.field.data.floats
 
FloatFieldDataComparator - Class in org.elasticsearch.index.field.data.floats
 
FloatFieldDataComparator(int, String, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.floats.FloatFieldDataComparator
 
FloatFieldDataMissingComparator - Class in org.elasticsearch.index.field.data.floats
 
FloatFieldDataMissingComparator(int, String, FieldDataCache, float) - Constructor for class org.elasticsearch.index.field.data.floats.FloatFieldDataMissingComparator
 
FloatFieldDataType - Class in org.elasticsearch.index.field.data.floats
 
FloatFieldDataType() - Constructor for class org.elasticsearch.index.field.data.floats.FloatFieldDataType
 
FloatFieldMapper - Class in org.elasticsearch.index.mapper.core
 
FloatFieldMapper(FieldMapper.Names, int, String, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, Float, boolean) - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
FloatFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
FloatFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.Builder
 
FloatFieldMapper.CustomFloatNumericField - Class in org.elasticsearch.index.mapper.core
 
FloatFieldMapper.CustomFloatNumericField(NumberFieldMapper, float) - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericField
 
FloatFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
FloatFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.Defaults
 
FloatFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
FloatFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.FloatFieldMapper.TypeParser
 
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 DoubleAdder.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.extra.AtomicDouble
Returns the value of this AtomicDouble 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() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
floatValue(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
floatValue(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
floatValue(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
floatValue(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
floatValue(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
floatValue(int) - Method in class org.elasticsearch.index.field.data.NumericFieldData
Returns the value of the specified number as a float.
floatValue(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
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() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexOutput
 
flush() - Method in class org.apache.lucene.store.OpenBufferedIndexOutput
Forces any buffered output to be written.
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() - Method 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(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.bzip2.CBZip2OutputStream
 
flush() - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
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.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.BufferedChecksumIndexOutput
 
flush() - Method in class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
flush() - Method in class org.elasticsearch.common.lucene.store.NullIndexOutput
 
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(Engine.Flush) - Method in interface org.elasticsearch.index.engine.Engine
Flushes the state of the engine, clearing memory.
flush() - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
flush(boolean) - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
flush(Engine.Flush) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
flush(Engine.Flush) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
flush(Engine.Flush) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
flush() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
FLUSH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
FlushAction - Class in org.elasticsearch.action.admin.indices.flush
 
flushBase64() - Method in class org.elasticsearch.common.Base64.OutputStream
Method added by PHIL.
flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.OpenBufferedIndexOutput
Expert: implements buffer write.
flushBuffer(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
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
 
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(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() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
flushStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
flushStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
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 interface org.elasticsearch.index.shard.service.IndexShard
 
flushStats() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
flyweight() - Method in class org.elasticsearch.index.mapper.ParseContext
 
flyweight(boolean) - Method in class org.elasticsearch.index.mapper.SourceToParse
 
flyweight() - Method in class org.elasticsearch.index.mapper.SourceToParse
 
fmix(long) - Static method in class org.elasticsearch.common.MurmurHash
 
forAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Scoping
 
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.index.engine.Engine.Flush
 
force(boolean) - Method in class org.elasticsearch.index.engine.Engine.Flush
 
force(boolean) - Method in class org.elasticsearch.index.engine.Engine.Refresh
 
force() - Method in class org.elasticsearch.index.engine.Engine.Refresh
 
forcedAnalyzer() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
forcedAnalyzer(Analyzer) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
forcedQuoteAnalyzer() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
forcedQuoteAnalyzer(Analyzer) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
forceSync(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
forceSync(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
forceSync(String) - Method in interface org.elasticsearch.index.store.support.ForceSyncDirectory
Similar to Directory.sync(String) but forces it even if its disabled.
ForceSyncDirectory - Interface in org.elasticsearch.index.store.support
A custom directory that allows to forceSync (since the actual directory might disable it)
forceTermination() - Method in class jsr166y.Phaser
Forces this phaser to enter termination state.
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.
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.FieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.strings.MultiValueStringFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.field.data.strings.SingleValueStringFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
forEachOrdinalInDoc(int, FieldData.OrdinalInDocProc) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
forEachValue(ByteFieldData.ValueProc) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
forEachValue(DoubleFieldData.ValueProc) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.field.data.FieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
forEachValue(FloatFieldData.ValueProc) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
forEachValue(IntFieldData.ValueProc) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
forEachValue(LongFieldData.ValueProc) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
forEachValue(ShortFieldData.ValueProc) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
forEachValue(FieldData.StringValueProc) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
forEachValue(GeoPointFieldData.PointValueProc) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
forEachValue(GeoPointFieldData.ValueProc) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
forEachValueInDoc(int, ByteFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
forEachValueInDoc(int, ByteFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
forEachValueInDoc(int, ByteFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
forEachValueInDoc(int, DoubleFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
forEachValueInDoc(int, DoubleFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
forEachValueInDoc(int, DoubleFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.FieldData
 
forEachValueInDoc(int, FloatFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
forEachValueInDoc(int, FloatFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
forEachValueInDoc(int, FloatFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
forEachValueInDoc(int, IntFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
forEachValueInDoc(int, IntFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
forEachValueInDoc(int, IntFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
forEachValueInDoc(int, LongFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
forEachValueInDoc(int, LongFieldData.DateValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
forEachValueInDoc(int, MutableDateTime, LongFieldData.DateValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachValueInDoc(int, LongFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachValueInDoc(int, LongFieldData.DateValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachValueInDoc(int, MutableDateTime, LongFieldData.DateValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachValueInDoc(int, LongFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachValueInDoc(int, LongFieldData.DateValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachValueInDoc(int, MutableDateTime, LongFieldData.DateValueInDocProc) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.NumericFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.NumericFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.NumericFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.NumericFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
forEachValueInDoc(int, ShortFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
forEachValueInDoc(int, ShortFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
forEachValueInDoc(int, NumericFieldData.DoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
forEachValueInDoc(int, NumericFieldData.LongValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingDoubleValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
forEachValueInDoc(int, NumericFieldData.MissingLongValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
forEachValueInDoc(int, ShortFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.strings.MultiValueStringFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.field.data.strings.SingleValueStringFieldData
 
forEachValueInDoc(int, GeoPointFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
forEachValueInDoc(int, GeoPointFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
forEachValueInDoc(int, FieldData.StringValueInDocProc) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
forEachValueInDoc(int, GeoPointFieldData.ValueInDocProc) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
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.
fork() - Method in class jsr166y.ForkJoinTask
Arranges to asynchronously execute this task.
ForkJoinPool - Class in jsr166y
An ExecutorService for running ForkJoinTasks.
ForkJoinPool() - Constructor for class jsr166y.ForkJoinPool
Creates a ForkJoinPool with parallelism equal to Runtime.availableProcessors(), using the default thread factory, no UncaughtExceptionHandler, and non-async LIFO processing mode.
ForkJoinPool(int) - Constructor for class jsr166y.ForkJoinPool
Creates a ForkJoinPool with the indicated parallelism level, the default thread factory, no UncaughtExceptionHandler, and non-async LIFO processing mode.
ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class jsr166y.ForkJoinPool
Creates a ForkJoinPool with the given parameters.
ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in jsr166y
Factory for creating new ForkJoinWorkerThreads.
ForkJoinPool.ManagedBlocker - Interface in jsr166y
Interface for extending managed parallelism for tasks running in ForkJoinPools.
ForkJoinTask<V> - Class in jsr166y
Abstract base class for tasks that run within a ForkJoinPool.
ForkJoinTask() - Constructor for class jsr166y.ForkJoinTask
 
ForkJoinWorkerThread - Class in jsr166y
A thread managed by a ForkJoinPool, which executes ForkJoinTasks.
ForkJoinWorkerThread(ForkJoinPool) - Constructor for class jsr166y.ForkJoinWorkerThread
Creates a ForkJoinWorkerThread operating in the given pool.
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(String) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
 
FORMAT - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
format1Decimals(double, String) - Static method in class org.elasticsearch.common.Strings
Format the double value with a single decimal points, trimming trailing '.0'.
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) - Constructor for class org.elasticsearch.common.joda.FormatDateTimeFormatter
 
FormatDateTimeFormatter(String, DateTimeFormatter, DateTimeFormatter) - Constructor for class org.elasticsearch.common.joda.FormatDateTimeFormatter
 
formatInjectionPoint(Formatter, Dependency<?>, InjectionPoint) - Static method in class org.elasticsearch.common.inject.internal.Errors
 
formatSource(Formatter, Object) - Static method in class org.elasticsearch.common.inject.internal.Errors
 
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.
forObject(Object) - Static method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
Returns a module which creates bindings for provider methods from the given object.
forPattern(String) - Static method in class org.elasticsearch.common.joda.Joda
Parses a joda based pattern, including some named ones (similar to the built in Joda ISO ones).
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
 
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
 
fragmentCharSize() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
fragmentCharSize(int) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
fragmentOffset(int) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 
fragmentOffset() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
fragmentOffset(int) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
fragments() - Method in class org.elasticsearch.search.highlight.HighlightField
The highlighted fragments.
fragmentSize(int) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 
free() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
free() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
free() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
 
freeContext(long) - Method in class org.elasticsearch.search.SearchService
 
freePercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
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
 
freqs() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
from(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
from(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
from(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
from(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
from(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
from(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
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(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
From index to start the search from.
from() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
from() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
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.query.QuerySearchResult
 
from(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
fromAsString() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
fromBytes(byte[], DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
 
fromBytes(byte[]) - Static method in class org.elasticsearch.common.Unicode
 
fromBytes(byte[], int, int) - Static method in class org.elasticsearch.common.Unicode
 
fromBytesAsUtf16(byte[]) - Static method in class org.elasticsearch.common.Unicode
 
fromBytesAsUtf16(byte[], int, int) - Static method in class org.elasticsearch.common.Unicode
 
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.SearchOperationThreading
 
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.broadcast.BroadcastOperationThreading
 
fromId(byte) - Static method in enum org.elasticsearch.action.support.IgnoreIndices
 
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.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(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
 
FromParseElement - Class in org.elasticsearch.search.query
 
FromParseElement() - Constructor for class org.elasticsearch.search.query.FromParseElement
 
fromRestContentType(String) - Static method in enum org.elasticsearch.common.xcontent.XContentType
 
fromString(String) - Static method in enum org.apache.lucene.store.StoreRateLimiting.Type
 
fromString(String, SearchOperationThreading) - Static method in enum org.elasticsearch.action.search.SearchOperationThreading
 
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, BroadcastOperationThreading) - Static method in enum org.elasticsearch.action.support.broadcast.BroadcastOperationThreading
 
fromString(String) - Static method in enum org.elasticsearch.action.support.IgnoreIndices
 
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.unit.DistanceUnit
 
fromString(String) - Static method in class org.elasticsearch.common.UUID
Creates a UUID from the string standard representation as described in the UUID.toString() method.
fromString(String) - Static method in enum org.elasticsearch.index.mapper.object.DynamicTemplate.MatchType
 
fromString(String) - Static method in enum org.elasticsearch.index.search.child.TopChildrenQuery.ScoreType
 
fromString(String) - Static method in enum org.elasticsearch.index.search.geo.GeoDistance
 
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.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.transport.TransportRequestOptions.Type
 
fromStringAsBytes(String) - Static method in class org.elasticsearch.common.Unicode
 
fromStringAsUtf8(String) - Static method in class org.elasticsearch.common.Unicode
 
fromStringAsUtf8(String, UnicodeUtil.UTF8Result) - Static method in class org.elasticsearch.common.Unicode
 
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.cluster.health.ClusterHealthStatus
 
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus.Stage
 
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus.Stage
 
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus.Stage
 
fromValue(byte) - Static method in enum org.elasticsearch.cluster.metadata.AliasAction.Type
 
fromValue(byte) - Static method in enum org.elasticsearch.cluster.routing.ShardRoutingState
 
fromValue(byte) - Static method in enum org.elasticsearch.index.VersionType
 
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) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
fromXContent(XContentParser) - Method in interface org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
fromXContent(byte[]) - Static method in class org.elasticsearch.index.gateway.CommitPoints
 
fromXContent(XContentParser) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
fromXContentStandalone(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
fs() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node file system stats be returned.
fs(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should the node file system stats be returned.
fs() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
File system level stats.
FsBlobStore - Class in org.elasticsearch.common.blobstore.fs
 
FsBlobStore(Settings, Executor, 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
 
FsDirectoryService - Class in org.elasticsearch.index.store.fs
 
FsDirectoryService(ShardId, Settings, IndexStore) - Constructor for class org.elasticsearch.index.store.fs.FsDirectoryService
 
FsGateway - Class in org.elasticsearch.gateway.fs
 
FsGateway(Settings, ThreadPool, ClusterService, Environment, ClusterName) - Constructor for class org.elasticsearch.gateway.fs.FsGateway
 
FsGatewayModule - Class in org.elasticsearch.gateway.fs
 
FsGatewayModule() - Constructor for class org.elasticsearch.gateway.fs.FsGatewayModule
 
FsImmutableBlobContainer - Class in org.elasticsearch.common.blobstore.fs
 
FsImmutableBlobContainer(FsBlobStore, BlobPath, File) - Constructor for class org.elasticsearch.common.blobstore.fs.FsImmutableBlobContainer
 
FsIndexGateway - Class in org.elasticsearch.index.gateway.fs
 
FsIndexGateway(Index, Settings, Gateway) - Constructor for class org.elasticsearch.index.gateway.fs.FsIndexGateway
 
FsIndexGatewayModule - Class in org.elasticsearch.index.gateway.fs
 
FsIndexGatewayModule() - Constructor for class org.elasticsearch.index.gateway.fs.FsIndexGatewayModule
 
FsIndexShardGateway - Class in org.elasticsearch.index.gateway.fs
 
FsIndexShardGateway(ShardId, Settings, ThreadPool, IndexGateway, IndexShard, Store) - Constructor for class org.elasticsearch.index.gateway.fs.FsIndexShardGateway
 
FsIndexShardGateway.FsSnapshotLock - Class in org.elasticsearch.index.gateway.fs
 
FsIndexShardGateway.FsSnapshotLock(Lock) - Constructor for class org.elasticsearch.index.gateway.fs.FsIndexShardGateway.FsSnapshotLock
 
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
 
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.Info - Class in org.elasticsearch.monitor.fs
 
FsStats.Info() - Constructor for class org.elasticsearch.monitor.fs.FsStats.Info
 
FsTranslog - Class in org.elasticsearch.index.translog.fs
 
FsTranslog(ShardId, Settings, IndexSettingsService, NodeEnvironment) - 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
 
full() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
Should a "full" flush be performed.
full(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
Should a "full" flush be performed.
full() - Method in class org.elasticsearch.index.engine.Engine.Flush
Should a "full" flush be issued, basically cleaning as much memory as possible.
full(boolean) - Method in class org.elasticsearch.index.engine.Engine.Flush
Should a "full" flush be issued, basically cleaning as much memory as possible.
fullDelete(Directory) - Method in interface org.elasticsearch.index.store.DirectoryService
 
fullDelete(Directory) - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
fullDelete(Directory) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectoryService
 
fullDelete(Directory) - Method in class org.elasticsearch.index.store.ram.RamDirectoryService
 
fullDelete() - Method in class org.elasticsearch.index.store.Store
 
FullHistogramFacetCollector - Class in org.elasticsearch.search.facet.histogram.unbounded
A histogram facet collector that uses the same field as the key as well as the value.
FullHistogramFacetCollector(String, String, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.FullHistogramFacetCollector
 
FullHistogramFacetCollector.HistogramProc - Class in org.elasticsearch.search.facet.histogram.unbounded
 
FullHistogramFacetCollector.HistogramProc(long) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.FullHistogramFacetCollector.HistogramProc
 
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.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
 
fullSearcher() - Method in class org.elasticsearch.indices.warmer.IndicesWarmer.WarmerContext
 
function - Variable in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery.FilterFunction
 
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) - Constructor for class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
FutureTransportResponseHandler<T extends Streamable> - 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
 
fuzziness(Object) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
Sets the minimum similarity used when evaluated to a fuzzy query type.
fuzziness(Object) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
Sets the minimum similarity used when evaluated to a fuzzy query type.
fuzziness - Variable in class org.elasticsearch.index.search.MatchQuery
 
FUZZY_FACTOR - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
 
fuzzyFactor - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
 
fuzzyFactor(String) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
 
fuzzyFactor - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
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.QueryParserSettings
 
fuzzyMaxExpansions(int) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
fuzzyMaxExpansions(int) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
 
fuzzyMaxExpansions(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
 
fuzzyMinSim() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
fuzzyMinSim(float) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
fuzzyMinSim(float) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
Set the minimum similarity for fuzzy queries.
fuzzyMinSim(float) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Set the minimum similarity for fuzzy queries.
fuzzyPrefixLength() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
fuzzyPrefixLength(int) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
fuzzyPrefixLength(int) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
Set the prefix length for fuzzy queries.
fuzzyPrefixLength(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
Set the minimum similarity for fuzzy queries.
fuzzyPrefixLength - Variable in class org.elasticsearch.index.search.MatchQuery
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
fuzzyQuery(String, double, int, int) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
fuzzyQuery(String, double, int, int) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
fuzzyQuery(String, String, int, int) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
fuzzyQuery(String, double, int, int) - 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.
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.FieldQueryBuilder
 
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.QueryParserSettings
 
fuzzyRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
fuzzyRewriteMethod - Variable in class org.elasticsearch.index.search.MatchQuery
 

G

G_SIZE - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
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 interface org.elasticsearch.index.service.IndexService
 
gateway() - Method in class org.elasticsearch.index.service.InternalIndexService
 
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
 
GatewayRecoveryStatus(GatewayRecoveryStatus.Stage, long, long, long, long, long, long) - Constructor for class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
gatewayRecoveryStatus() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Gateway recovery status (null if not applicable).
GatewayRecoveryStatus.Stage - Enum in org.elasticsearch.action.admin.indices.status
 
GatewayService - Class in org.elasticsearch.gateway
 
GatewayService(Settings, Gateway, AllocationService, ClusterService, DiscoveryService, ThreadPool) - Constructor for class org.elasticsearch.gateway.GatewayService
 
gatewaySnapshot(GatewaySnapshotRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Explicitly perform gateway snapshot for one or more indices.
gatewaySnapshot(GatewaySnapshotRequest, ActionListener<GatewaySnapshotResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Explicitly perform gateway snapshot for one or more indices.
gatewaySnapshot(GatewaySnapshotRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
gatewaySnapshot(GatewaySnapshotRequest, ActionListener<GatewaySnapshotResponse>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
GatewaySnapshotAction - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
 
GatewaySnapshotRequest - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
Gateway snapshot allows to explicitly perform a snapshot through the gateway of one or more indices (backup them).
GatewaySnapshotRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotRequest
Constructs a new gateway snapshot against one or more indices.
gatewaySnapshotRequest(String...) - Static method in class org.elasticsearch.client.Requests
Creates a gateway snapshot indices request.
GatewaySnapshotRequestBuilder - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
 
GatewaySnapshotRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotRequestBuilder
 
GatewaySnapshotResponse - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
Response for the gateway snapshot action.
GatewaySnapshotStatus - Class in org.elasticsearch.action.admin.indices.status
 
GatewaySnapshotStatus(GatewaySnapshotStatus.Stage, long, long, long, int) - Constructor for class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
gatewaySnapshotStatus() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The current on going snapshot to the gateway or the last one if none is on going.
GatewaySnapshotStatus.Stage - Enum in org.elasticsearch.action.admin.indices.status
 
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
 
gcd(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Gets the greatest common divisor of the absolute value of two numbers, using the "binary gcd" method which avoids division and modulo operations.
gcd(long, long) - Static method in class org.elasticsearch.common.math.MathUtils
Gets the greatest common divisor of the absolute value of two numbers, using the "binary gcd" method which avoids division and modulo operations.
generateDump(String, Map<String, Object>) - Method in interface org.elasticsearch.monitor.dump.DumpGenerator
 
generateDump(String, Map<String, Object>, String...) - Method in interface org.elasticsearch.monitor.dump.DumpGenerator
 
generateDump(String, Map<String, Object>) - Method in class org.elasticsearch.monitor.dump.DumpMonitorService
 
generateDump(String, Map<String, Object>, String...) - Method in class org.elasticsearch.monitor.dump.DumpMonitorService
 
generateDump(String, Map<String, Object>) - Method in class org.elasticsearch.monitor.dump.SimpleDumpGenerator
 
generateDump(String, Map<String, Object>, String...) - Method in class org.elasticsearch.monitor.dump.SimpleDumpGenerator
 
generation() - Method in class org.elasticsearch.index.engine.Segment
 
generator - Variable in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
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
 
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
 
geoDistance(GeoDistance) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
geoDistance(GeoDistance) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
GeoDistance - Enum in org.elasticsearch.index.search.geo
Geo distance calculation.
geoDistance - Variable in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
geoDistance() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
geoDistance() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
geoDistance(GeoDistance) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The geo distance type used to compute the distance.
geoDistance - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
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.index.search.geo
 
GeoDistance.ArcFixedSourceDistance(double, double, DistanceUnit) - Constructor for class org.elasticsearch.index.search.geo.GeoDistance.ArcFixedSourceDistance
 
GeoDistance.DistanceBoundingCheck - Interface in org.elasticsearch.index.search.geo
 
GeoDistance.FactorFixedSourceDistance - Class in org.elasticsearch.index.search.geo
 
GeoDistance.FactorFixedSourceDistance(double, double, DistanceUnit) - Constructor for class org.elasticsearch.index.search.geo.GeoDistance.FactorFixedSourceDistance
 
GeoDistance.FixedSourceDistance - Interface in org.elasticsearch.index.search.geo
 
GeoDistance.Meridian180DistanceBoundingCheck - Class in org.elasticsearch.index.search.geo
 
GeoDistance.Meridian180DistanceBoundingCheck(Point, Point) - Constructor for class org.elasticsearch.index.search.geo.GeoDistance.Meridian180DistanceBoundingCheck
 
GeoDistance.PlaneFixedSourceDistance - Class in org.elasticsearch.index.search.geo
 
GeoDistance.PlaneFixedSourceDistance(double, double, DistanceUnit) - Constructor for class org.elasticsearch.index.search.geo.GeoDistance.PlaneFixedSourceDistance
 
GeoDistance.SimpleDistanceBoundingCheck - Class in org.elasticsearch.index.search.geo
 
GeoDistance.SimpleDistanceBoundingCheck(Point, Point) - Constructor for class org.elasticsearch.index.search.geo.GeoDistance.SimpleDistanceBoundingCheck
 
GeoDistanceDataComparator - Class in org.elasticsearch.index.search.geo
 
GeoDistanceDataComparator(int, String, double, double, DistanceUnit, GeoDistance, FieldDataCache, MapperService) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
geoDistanceFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
GeoDistanceFacet - Interface in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacet.Entry - Class in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacet.Entry(double, double, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
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.
GeoDistanceFacetCollector - Class in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacetCollector(String, String, double, double, DistanceUnit, GeoDistance, GeoDistanceFacet.Entry[], SearchContext) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
GeoDistanceFacetCollector.Aggregator - Class in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacetCollector.Aggregator(GeoDistance.FixedSourceDistance, GeoDistanceFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector.Aggregator
 
GeoDistanceFacetProcessor - Class in org.elasticsearch.search.facet.geodistance
 
GeoDistanceFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetProcessor
 
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, String, GeoPointFieldMapper, FieldDataCache, String) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
GeoDistanceFilter.GeoDistanceDocSet - Class in org.elasticsearch.index.search.geo
 
GeoDistanceFilter.GeoDistanceDocSet(int, GeoPointFieldData, GeoDistance.FixedSourceDistance, GeoDistance.DistanceBoundingCheck, double) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceFilter.GeoDistanceDocSet
 
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
 
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(double, double, Double, Double, boolean, boolean, GeoDistance, String, GeoPointFieldMapper, FieldDataCache, String) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
GeoDistanceRangeFilter.GeoDistanceRangeDocSet - Class in org.elasticsearch.index.search.geo
 
GeoDistanceRangeFilter.GeoDistanceRangeDocSet(int, GeoPointFieldData, GeoDistance.FixedSourceDistance, GeoDistance.DistanceBoundingCheck, double, double) - Constructor for class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter.GeoDistanceRangeDocSet
 
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.index.mapper.geo.GeoPoint
 
GEOHASH - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
GEOHASH - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.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.search.facet.geodistance.GeoDistanceFacetBuilder
The geohash of the geo point to create the range distance facets from.
geohash(String) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
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
 
geohashDistance(String) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
geohashDistanceInKm(String) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
geohashDistanceWithDefault(String, double) - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
GeohashPrefixTree - Class in org.elasticsearch.common.lucene.spatial.prefix.tree
A SpatialPrefixGrid based on Geohashes.
GeohashPrefixTree(SpatialContext, int) - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.tree.GeohashPrefixTree
 
GeoHashUtils - Class in org.elasticsearch.index.search.geo
Utilities for encoding and decoding geohashes.
GeoJSONShapeParser - Class in org.elasticsearch.common.geo
Parsers which supports reading Shapes in GeoJSON format from a given XContentParser.
GeoJSONShapeSerializer - Class in org.elasticsearch.common.geo
Serializes Shape instances into GeoJSON format

Example of the format used for points:

{ "type": "Point", "coordinates": [100.0, 0.0] }

geoMapper() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.GeoStringFieldMapper
 
GeoPoint - Class in org.elasticsearch.index.mapper.geo
 
GeoPoint(double, double) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPoint
 
GeoPointDocFieldData - Class in org.elasticsearch.index.mapper.geo
 
GeoPointDocFieldData(GeoPointFieldData) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
GeoPointFieldData - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldData(String, double[], double[]) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
GeoPointFieldData.PointValueProc - Interface in org.elasticsearch.index.mapper.geo
 
GeoPointFieldData.ValueInDocProc - Interface in org.elasticsearch.index.mapper.geo
 
GeoPointFieldData.ValueProc - Interface in org.elasticsearch.index.mapper.geo
 
GeoPointFieldDataType - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldDataType() - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldDataType
 
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(String, ContentPath.Type, boolean, boolean, Integer, int, DoubleFieldMapper, DoubleFieldMapper, StringFieldMapper, GeoPointFieldMapper.GeoStringFieldMapper, boolean, boolean, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
GeoPointFieldMapper.Builder - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
GeoPointFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
GeoPointFieldMapper.GeoStringFieldMapper - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.GeoStringFieldMapper(FieldMapper.Names, Field.Index, Field.Store, Field.TermVector, float, boolean, FieldInfo.IndexOptions, String, NamedAnalyzer, NamedAnalyzer) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.GeoStringFieldMapper
 
GeoPointFieldMapper.GeoStringFieldMapper.Builder - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.GeoStringFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.GeoStringFieldMapper.Builder
 
GeoPointFieldMapper.Names - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.Names() - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
GeoPointFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.geo
 
GeoPointFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.TypeParser
 
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(Point[], String, FieldDataCache) - Constructor for class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
GeoPolygonFilter.GeoPolygonDocSet - Class in org.elasticsearch.index.search.geo
 
GeoPolygonFilter.GeoPolygonDocSet(int, GeoPointFieldData, Point[]) - Constructor for class org.elasticsearch.index.search.geo.GeoPolygonFilter.GeoPolygonDocSet
 
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
 
GeoShapeFieldMapper - Class in org.elasticsearch.index.mapper.geo
FieldMapper for indexing Shapes.
GeoShapeFieldMapper(FieldMapper.Names, SpatialPrefixTree, double) - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
GeoShapeFieldMapper.Builder - Class in org.elasticsearch.index.mapper.geo
 
GeoShapeFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
GeoShapeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.geo
 
GeoShapeFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
 
GeoShapeFieldMapper.Names - Class in org.elasticsearch.index.mapper.geo
 
GeoShapeFieldMapper.Names() - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
 
GeoShapeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.geo
 
GeoShapeFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.TypeParser
 
geoShapeFilter(String, Shape) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter to filter based on the relationship between a shape and indexed shapes
GeoShapeFilterBuilder - Class in org.elasticsearch.index.query
FilterBuilder that builds a GeoShape Filter
GeoShapeFilterBuilder(String, Shape) - Constructor for class org.elasticsearch.index.query.GeoShapeFilterBuilder
Creates a new GeoShapeFilterBuilder whose Filter will be against the given field name
GeoShapeFilterParser - Class in org.elasticsearch.index.query
FilterParser for filtering Documents based on Shapes.
GeoShapeFilterParser() - Constructor for class org.elasticsearch.index.query.GeoShapeFilterParser
 
geoShapeQuery(String, Shape) - Static method in class org.elasticsearch.index.query.QueryBuilders
Query that matches Documents based on the relationship between the given shape and indexed shapes
GeoShapeQueryBuilder - Class in org.elasticsearch.index.query
 
GeoShapeQueryBuilder(String, Shape) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
 
GeoShapeQueryParser - Class in org.elasticsearch.index.query
 
GeoShapeQueryParser() - Constructor for class org.elasticsearch.index.query.GeoShapeQueryParser
 
GeoUtils - Class in org.elasticsearch.index.search.geo
 
GeoUtils() - Constructor for class org.elasticsearch.index.search.geo.GeoUtils
 
GermanAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
GermanAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GermanAnalyzerProvider
 
GermanStemTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
GermanStemTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GermanStemTokenFilterFactory
 
get(Object) - Method in class jsr166e.ConcurrentHashMapV8
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get() - Method in class jsr166e.extra.AtomicDouble
Gets the current value.
get(int) - Method in class jsr166e.extra.AtomicDoubleArray
Gets the current value at position i.
get(int) - Method in class jsr166e.extra.ReadMostlyVector
 
get() - Method in class jsr166y.ForkJoinTask
Waits if necessary for the computation to complete, and then retrieves its result.
get(long, TimeUnit) - Method in class jsr166y.ForkJoinTask
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
get() - Method 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(int) - Method in class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
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(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() - 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() - Method in class org.elasticsearch.common.io.BooleanStreamable
 
get() - Method in class org.elasticsearch.common.io.stream.LongStreamable
 
get() - Method in class org.elasticsearch.common.io.stream.StringStreamable
 
get(int) - Method in class org.elasticsearch.common.lucene.docset.AllDocSet
 
get(int) - Method in class org.elasticsearch.common.lucene.docset.AndDocSet
 
get(int) - Method in class org.elasticsearch.common.lucene.docset.DocSet
 
get(int) - Method in class org.elasticsearch.common.lucene.docset.FixedBitDocSet
 
get(int) - Method in class org.elasticsearch.common.lucene.docset.NotDocSet
 
get(int) - Method in class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
get(int) - Method in class org.elasticsearch.common.lucene.docset.OrDocSet
 
get(int) - Method in class org.elasticsearch.common.lucene.search.LimitFilter.LimitDocSet
 
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, 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, String) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value associated with the setting key.
get(int) - Method in class org.elasticsearch.common.util.BigLongArray
 
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() - Method in class org.elasticsearch.common.util.concurrent.ThreadLocals.CleanableValue
 
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.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.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(QueryParserSettings) - Method in class org.elasticsearch.index.cache.query.parser.support.AbstractJvmQueryParserCache
 
get(Engine.Get) - Method in interface org.elasticsearch.index.engine.Engine
 
get(Engine.Get) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
get(String, String, String[], boolean) - Method in class org.elasticsearch.index.get.ShardGetService
 
get(Engine.GetResult, String, String, String[]) - Method in class org.elasticsearch.index.get.ShardGetService
Returns GetResult based on the specified Engine.GetResult argument.
get(int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter.GeoDistanceDocSet
 
get(int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter.GeoDistanceRangeDocSet
 
get(int) - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter.GeoPolygonDocSet
 
get(int) - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.GeoBoundingBoxDocSet
 
get(int) - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.Meridian180GeoBoundingBoxDocSet
 
get() - Method in class org.elasticsearch.index.settings.IndexSettingsProvider
 
get(Engine.Get) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
get(Engine.Get) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
get() - Method in class org.elasticsearch.index.similarity.DefaultSimilarityProvider
 
get() - Method in interface org.elasticsearch.index.similarity.SimilarityProvider
 
get() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
get(Object) - Method in class org.elasticsearch.search.lookup.DocLookup
 
get(Object) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
get(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
GET - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse
 
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
 
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
Has the index creation been acknowledged by all current cluster nodes within the provided CreateIndexRequest.timeout(org.elasticsearch.common.unit.TimeValue).
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexResponse
Has the index deletion been acknowledged by all current cluster nodes within the provided DeleteIndexRequest.timeout(org.elasticsearch.common.unit.TimeValue).
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingResponse
Has the put mapping creation been acknowledged by all current cluster nodes within the provided PutMappingRequest.timeout(org.elasticsearch.common.unit.TimeValue).
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
 
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateResponse
 
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateResponse
 
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerResponse
 
getAcknowledged() - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerResponse
Has the put warmer been ack'ed.
GetAction - Class in org.elasticsearch.action.get
 
getActive() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
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
 
getActiveThreadCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the number of threads that are currently stealing or executing tasks.
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
 
getAlias() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getAliases() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
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.
getAllocationExplanation() - Method in class org.elasticsearch.cluster.ClusterState
 
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
 
getAndAdd(double) - Method in class jsr166e.extra.AtomicDouble
Atomically adds the given value to the current value.
getAndAdd(int, double) - Method in class jsr166e.extra.AtomicDoubleArray
Atomically adds the given value to the element at index i.
getAndClearFilter() - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
getAndSet(double) - Method in class jsr166e.extra.AtomicDouble
Atomically sets to the given value and returns the old value.
getAndSet(int, double) - Method in class jsr166e.extra.AtomicDoubleArray
Atomically sets the element at position i to the given value and returns the old value.
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
 
getArguments() - Method in exception org.elasticsearch.common.math.MathRuntimeException
Gets the arguments used to build the message of this throwable.
getArrivedParties() - Method in class jsr166y.Phaser
Returns the number of registered parties that have arrived at the current phase of this phaser.
getAsArray(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsArray(String, String[]) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
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 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 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 interface org.elasticsearch.common.settings.Settings
Returns the setting value (as double) associated with the setting key.
getAsFloat(String, Float) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsFloat(String, Float) - Method in interface org.elasticsearch.common.settings.Settings
Returns the setting value (as float) associated with the setting key.
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.
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.
getAsMap() - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsMap() - Method in interface org.elasticsearch.common.settings.Settings
The settings as a Map.
getAssignedShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
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.
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.
getAsVersion(String, Version) - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
getAsVersion(String, Version) - Method in interface org.elasticsearch.common.settings.Settings
Retruns a parsed version.
getAsyncMode() - Method in class jsr166y.ForkJoinPool
Returns true if this pool uses local first-in-first-out scheduling mode for forked tasks that are never joined.
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.IndicesStats
 
getAt(int) - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
getAt(int) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
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.
getAttemptFails() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getAttribute(String) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getAttributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The node attributes.
getAttributes(String[]) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getAvailable() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
getBeforeUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
getBindHost() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
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 class org.elasticsearch.common.MurmurHash
 
getBlocks() - Method in class org.elasticsearch.cluster.ClusterState
 
getBlocks() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
getBlockSize() - Method in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
Returns the blocksize parameter specified at construction time.
getBloomSize() - Method in class org.elasticsearch.index.cache.CacheStats
 
getBloomSizeInBytes() - Method in class org.elasticsearch.index.cache.CacheStats
 
getBooleanQuery(List<BooleanClause>, boolean) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
getBoost() - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
getBoostTermsFactor() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getBootClassPath() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
getBottomSlot() - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
getBoundAddress() - Method in class org.elasticsearch.transport.TransportServiceManagement
 
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.
getBytes() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
getByteValue() - Method in class org.elasticsearch.index.field.data.NumericDocFieldData
 
getCache() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
getCacheSize() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getCapacity() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
 
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
 
getCenter() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
getCharArray(int) - Static method in class org.elasticsearch.common.io.stream.CachedStreamInput
 
getChild(String) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
 
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
 
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.state.ClusterStateResponse
 
getClusterName() - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
getCollectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
getCollectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
getCompleter() - Method in class jsr166y.CountedCompleter
Returns the completer established in this task's constructor, or null if none.
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.
getConcreteAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
getConcreteAllOpenIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
getConnectTimeout() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
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.
getCoresPerSocket() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getCount() - Method in class org.elasticsearch.action.count.CountResponse
The count of documents matching the query provided.
getCount() - Method in class org.elasticsearch.index.get.GetStats
 
getCount() - Method in class org.elasticsearch.index.shard.DocsStats
 
getCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
getCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
getCount() - Method in 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 class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
getCount() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
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.unbounded.InternalCountHistogramFacet.CountEntry
 
getCount() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
getCount() - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
The count of the facet.
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.bytes.InternalByteTermsFacet.ByteEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet.FloatEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet.IntEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet.LongEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet.ShortEntry
 
getCount() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.StringEntry
 
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
 
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
 
getCurrent() - Method in class org.elasticsearch.index.get.GetStats
 
getCurrentMerge() - Static method in class org.apache.lucene.index.TrackingMergeScheduler
 
getCurrentReference() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
 
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
 
getData() - Method in class org.elasticsearch.common.lab.LongsLAB.Allocation
 
getDataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getDate() - Method in class org.elasticsearch.index.field.data.longs.LongDocFieldData
 
getDates() - Method in class org.elasticsearch.index.field.data.longs.LongDocFieldData
 
getDays() - Method in class org.elasticsearch.common.unit.TimeValue
 
getDaysFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
getDeclaringClass() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
 
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.
getDelegate() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
Returns the delegate members injector, or null if it has not yet been initialized.
getDelegate() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
Returns the delegate provider, or null if it has not yet been initialized.
getDeleteCount() - Method in class org.elasticsearch.index.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
The number of deleted docs in the index.
getDeletedDocs() - Method in class org.elasticsearch.index.engine.Segment
 
getDeleteTimeInMillis() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
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
 
getDetailedMessage() - Method in exception org.elasticsearch.ElasticSearchException
Return the detail message, including the message from the nested exception if there is one.
getDirectMemoryMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
getDirectory() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
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
 
getDistanceErrorPct() - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Returns the distance error percentage for this Strategy
getDistancePerDegree() - Method in enum org.elasticsearch.common.unit.DistanceUnit
 
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.PublicTermsFilter
 
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.XTermsFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.common.lucene.search.LimitFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MatchAllDocsFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MatchNoDocsFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.common.lucene.search.NotDeletedFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.common.lucene.search.NotFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.common.lucene.search.OrFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.common.lucene.search.TermFilter
 
getDocIdSet(IndexReader) - 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(IndexReader) - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Wrapper
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.query.ScriptFilterParser.ScriptFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.search.child.HasChildFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.search.nested.NestedDocsFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.search.nested.NonNestedDocsFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.index.search.UidFilter
 
getDocIdSet(IndexReader) - Method in class org.elasticsearch.search.scan.ScanContext.ScanFilter
 
getDocs() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
getDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getDocs() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Docs level information for the shard index, null if not applicable.
getDocs() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
GetDocSet - Class in org.elasticsearch.common.lucene.docset
 
GetDocSet(int) - Constructor for class org.elasticsearch.common.lucene.docset.GetDocSet
 
getDoubleValue() - Method in class org.elasticsearch.index.field.data.NumericDocFieldData
 
getDoubleValues() - Method in class org.elasticsearch.index.field.data.NumericDocFieldData
 
getDuration() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
getEarthCircumference() - Method in enum org.elasticsearch.common.unit.DistanceUnit
 
getEarthRadius() - Method in enum org.elasticsearch.common.unit.DistanceUnit
 
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
 
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 class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
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.unbounded.InternalCountHistogramFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.histogram.unbounded.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.bytes.InternalByteTermsFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getEntries() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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.
getError() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
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
 
getException() - Method in class jsr166y.ForkJoinTask
Returns the exception thrown by the base computation, or a CancellationException if cancelled, or null if none or if the method has not yet completed.
getExceptionTypes(Member) - Method in class org.elasticsearch.common.inject.TypeLiteral
Returns the resolved generic exception types thrown by constructor.
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
 
getExpectedRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
getExpectedRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
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.search.internal.InternalSearchHit
 
getExplanation() - Method in interface org.elasticsearch.search.SearchHit
If enabled, the explanation of the search hit.
getExponent(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
getExponent(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
getExposedKeys() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
 
getExposedKeys() - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
Returns the unique exposed keys for these private elements.
getExposedSource(Key<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
 
getExposedSource(Key<?>) - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
Returns an arbitrary object containing information about the "place" where this key was exposed.
getExtension(String) - Static method in class org.elasticsearch.common.compress.CompressedDirectory
Utility method to return a file's extension.
getExtension(String) - Static method in class org.elasticsearch.common.lucene.store.SwitchDirectory
Utility method to return a file's extension.
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 jsr166y.ForkJoinPool
Returns the factory used for constructing new workers.
getFailedShards() - Method in class org.elasticsearch.action.delete.index.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.bulk.BulkItemResponse
The actual failure object if there was a failure.
getFailure() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
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.
getFetchCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
getFetchCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
getFetchTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
getField() - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
GetField - Class in org.elasticsearch.index.get
 
GetField(String, List<Object>) - Constructor for class org.elasticsearch.index.get.GetField
 
getField() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
getFieldEvictions() - Method in class org.elasticsearch.index.cache.CacheStats
 
getFieldName() - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Returns the name of the field this Strategy applies to
getFieldName() - Method in class org.elasticsearch.index.field.data.DocFieldData
 
getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
getFields() - Method in class org.elasticsearch.action.get.GetResponse
 
getFields() - Method in class org.elasticsearch.index.get.GetResult
 
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.
getFieldSize() - Method in class org.elasticsearch.index.cache.CacheStats
 
getFieldSizeInBytes() - Method in class org.elasticsearch.index.cache.CacheStats
 
getFieldType(Field) - Method in class org.elasticsearch.common.inject.TypeLiteral
Returns the resolved generic type of field.
getFilename(String) - Static method in class org.elasticsearch.common.Strings
Extract the filename from the given path, e.g.
getFilenameExtension(String) - Static method in class org.elasticsearch.common.Strings
Extract the filename extension from the given path, e.g.
getFileNames() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
getFilePointer() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexOutput
 
getFilePointer() - Method in class org.apache.lucene.store.OpenBufferedIndexOutput
Returns the current position in this file, where the next write will occur.
getFilePointer() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
 
getFilePointer() - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
getFilePointer() - Method in class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
getFilePointer() - Method in class org.elasticsearch.common.lucene.store.NullIndexOutput
 
getFiles() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommit
 
getFilter() - Method in class org.apache.lucene.search.DeletionAwareConstantScoreQuery
 
getFilter() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
getFilter(long, int) - Static method in class org.elasticsearch.common.bloom.BloomFilterFactory
 
getFilter(long, double) - Static method in class org.elasticsearch.common.bloom.BloomFilterFactory
 
getFilter() - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
getFilterCount() - Method in class org.elasticsearch.index.cache.CacheStats
 
getFilterEvictions() - Method in class org.elasticsearch.index.cache.CacheStats
 
getFilterFunctions() - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
getFilterMemEvictions() - Method in class org.elasticsearch.index.cache.CacheStats
 
getFilterSize() - Method in class org.elasticsearch.index.cache.CacheStats
 
getFilterSizeInBytes() - Method in class org.elasticsearch.index.cache.CacheStats
 
getFirst() - Method in class jsr166y.ConcurrentLinkedDeque
 
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.
getFloatValue() - Method in class org.elasticsearch.index.field.data.NumericDocFieldData
 
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
 
getFlushStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getFlushStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
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.
getForkJoinTaskTag() - Method in class jsr166y.ForkJoinTask
Returns the tag for this task.
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
 
getFreePercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
getFrom() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
getFrom() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getFromAsString() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getFs() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
File system level stats.
getFullObjectName() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getFunction() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
getGatewayRecoveryStatus() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Gateway recovery status (null if not applicable).
getGatewaySnapshotStatus() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
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
 
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.index.mapper.geo.GeoPoint
 
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
 
getGroupName() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getGroups(String) - 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.
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.monitor.jvm.JvmInfo.Mem
 
getHeapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
getHighlightFields() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
getHighlightFields() - Method in interface org.elasticsearch.search.SearchHit
A map of highlighted fields.
getHits() - Method in class org.elasticsearch.action.search.SearchResponse
The search hits.
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).
getHoldCount() - Method in class jsr166e.SequenceLock
Queries the number of holds on this lock by the current thread.
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
 
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.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.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.shard.ShardId
 
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.
getIdle() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
getIndex() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
getIndex() - Method in class org.elasticsearch.action.admin.indices.segments.IndexSegments
 
getIndex() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
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.index.IndexDeleteResponse
The index the delete by query operation was executed against.
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.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.support.broadcast.BroadcastShardOperationResponse
 
getIndex() - Method in class org.elasticsearch.action.update.UpdateResponse
The index the document was indexed into.
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
 
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.IndexServiceManagement
 
getIndex() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getIndex() - Method in class org.elasticsearch.index.shard.ShardId
 
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
 
getIndexCount() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
getIndexCurrent() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
getIndexing() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getIndexing() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
getIndexRecoveryProgress() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
getIndexRecoveryProgress() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
getIndexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
getIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
getIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
getIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
getIndexTimeInMillis() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
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.indices.segments.IndicesSegmentResponse
 
getIndices() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
getIndices() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
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
 
getInErrs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getInfoStream(ESLogger) - Static method in class org.elasticsearch.common.lucene.LoggerInfoStream
Creates a new LoggerInfoStream based on the provided logger by appending to its NAME the LoggerInfoStream.SUFFIX.
getInfoStream(String) - Static method in class org.elasticsearch.common.lucene.LoggerInfoStream
Creates a new LoggerInfoStream based on the provided name by appending to it the LoggerInfoStream.SUFFIX.
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
 
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.
getInputArguments() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
getInSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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.
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
 
getIntValue() - Method in class org.elasticsearch.index.field.data.NumericDocFieldData
 
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
 
GetJmxServiceUrlAction - Class in org.elasticsearch.jmx.action
 
GetJmxServiceUrlAction(Settings, JmxService, TransportService, ClusterService) - Constructor for class org.elasticsearch.jmx.action.GetJmxServiceUrlAction
 
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.
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.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
getKey() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
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.unbounded.InternalCountHistogramFacet.CountEntry
 
getKey() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
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
 
getLast() - Method in class jsr166y.ConcurrentLinkedDeque
 
getLastGc() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
getLastModified() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferFile
 
getLastModified() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferFileOutput
 
getLat() - Method in class org.elasticsearch.index.mapper.geo.GeoPoint
 
getLat() - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
getLats() - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
getLeastSignificantBits() - Method in class org.elasticsearch.common.UUID
Returns the least significant 64 bits of this UUID's 128 bit value.
getLength() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferFile
 
getLength() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferFileOutput
 
getLevel() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
getLevelForDistance(double) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.GeohashPrefixTree
 
getLevelForDistance(double) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
getLevelForDistance(double) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
Returns the level of the smallest grid size with a side length that is greater or equal to the provided distance.
getLikeText() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getLimit() - Method in class org.elasticsearch.common.lucene.search.LimitFilter
 
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.
getLoadAverage() - Method in class org.elasticsearch.monitor.os.OsStats
 
getLocalAddress() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
getLocalhost(NetworkUtils.StackType) - Static method in class org.elasticsearch.common.network.NetworkUtils
 
getLocalizedMessage() - Method in exception org.elasticsearch.common.math.MathRuntimeException
getLocalNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getLocalNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getLockFactory() - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
getLockID() - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
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(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.index.mapper.geo.GeoPoint
 
getLon() - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
getLongValue() - Method in class org.elasticsearch.index.field.data.NumericDocFieldData
 
getLons() - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
getLowerBounds() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
 
getLowerVal() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
getMacAddress() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
getMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getMasterNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getMasterNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getMatchedFilters() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
getMatchedFilters() - Method in interface org.elasticsearch.search.SearchHit
The set of filter names the query matched.
getMatches() - Method in class org.elasticsearch.action.index.IndexResponse
Returns the percolate queries matches.
getMatches() - Method in class org.elasticsearch.action.update.UpdateResponse
Returns the percolate queries matches.
getMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
getMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
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 class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
getMax() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
getMax() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The maximum value.
getMax() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
getMax() - Method in class org.elasticsearch.search.facet.histogram.unbounded.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
 
getMaxDoc() - Method in class org.elasticsearch.action.admin.indices.status.DocsStatus
The max doc.
getMaxDoc() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getMaxDocFreq() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getMaxFileDescriptorCount() - Static method in class org.elasticsearch.monitor.process.JmxProcessProbe
 
getMaxFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessInfo
 
getMaxLevelForPrecision(Shape, double) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
See com.spatial4j.core.query.SpatialArgs#getDistPrecision().
getMaxLevels() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
getMaxLevelsPossible() - Static method in class org.elasticsearch.common.lucene.spatial.prefix.tree.GeohashPrefixTree
Any more than this and there's no point (double lat & lon are the same).
getMaxQueryTerms() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getMaxScore() - Method in class org.elasticsearch.search.internal.InternalSearchHits
 
getMaxScore() - Method in interface org.elasticsearch.search.SearchHits
The maximum score of this query.
getMaxWordLen() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getMb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
getMBeanInfo() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getMbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
getMd5Digest() - Static method in class org.elasticsearch.common.Digest
Returns an MD5 MessageDigest.
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 class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
getMean() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
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.unbounded.InternalCountHistogramFacet.CountEntry
 
getMean() - Method in class org.elasticsearch.search.facet.histogram.unbounded.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.
getMemorySize() - Method in class org.apache.lucene.index.memory.CustomMemoryIndex
Returns a reasonable approximation of the main memory [bytes] consumed by this instance.
getMerge() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getMerge() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
getMergeStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Total merges of this shard replication group.
getMergeStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Total merges of this index.
getMergeStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Index merge statistics.
getMergeThread(IndexWriter, MergePolicy.OneMerge) - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
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 exception org.elasticsearch.common.inject.ConfigurationException
 
getMessage() - Method in exception org.elasticsearch.common.inject.CreationException
 
getMessage() - Method in exception org.elasticsearch.common.inject.ProvisionException
 
getMessage() - Method in class org.elasticsearch.common.inject.spi.Message
Gets the error message text.
getMessage(Locale) - Method in exception org.elasticsearch.common.math.MathRuntimeException
Gets the message in a specified locale.
getMessage() - Method in exception org.elasticsearch.common.math.MathRuntimeException
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
 
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 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 class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
getMin() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
getMin() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The minimum value.
getMin() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
getMin() - Method in class org.elasticsearch.search.facet.histogram.unbounded.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
 
getMinDocFreq() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
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
 
getMissingCount() - Method in class org.elasticsearch.index.get.GetStats
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getMissingCount() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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
 
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
 
getMostSignificantBits() - Method in class org.elasticsearch.common.UUID
Returns the most significant 64 bits of this UUID's 128 bit value.
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.
getMustFilters() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
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.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 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.monitor.dump.cluster.ClusterDumpContributor
 
getName() - Method in interface org.elasticsearch.monitor.dump.DumpContributor
 
getName() - Method in class org.elasticsearch.monitor.dump.heap.HeapDumpContributor
 
getName() - Method in class org.elasticsearch.monitor.dump.summary.SummaryDumpContributor
 
getName() - Method in class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
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.river.RiverName
 
getName() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
getName() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
getName() - Method in interface org.elasticsearch.search.facet.Facet
The "logical" name of the search facet.
getName() - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
getName() - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
getName() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet
 
getName() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
getName() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
getName() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
getName() - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
getName() - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
getName() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getName() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
getName() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getName() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
getName() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
getName() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
getName() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getName() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
getName() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
getName() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
getName() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
getName() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
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.threadpool.ThreadPool.Info
 
getName() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
getNanos() - Method in class org.elasticsearch.common.unit.TimeValue
 
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.
getNode(Point, int) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.GeohashPrefixTree
 
getNode(String) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.GeohashPrefixTree
 
getNode(byte[], int, int) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.GeohashPrefixTree
 
getNode(Point, int) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
getNode(String) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
getNode(byte[], int, int) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
getNode(String) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
The cell for the specified token.
getNode(byte[], int, int) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
getNode(byte[], int, int, Node) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
getNode(Point, int) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
getNodeId() - Method in class org.elasticsearch.search.SearchShardTarget
 
getNodes() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse
 
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
 
getNodes(Shape, int, boolean) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.GeohashPrefixTree
 
getNodes(Shape, int, boolean) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
getNodes(Shape, int, boolean) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
Gets the intersecting & including cells for the specified shape, without exceeding detail level.
getNodesAltPoint(Point, int, boolean) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
Subclasses might override SpatialPrefixTree.getNodes(com.spatial4j.core.shape.Shape, int, boolean) and check if the argument is a shape and if so, delegate to this implementation, which calls SpatialPrefixTree.getNode(com.spatial4j.core.shape.Point, int) and then calls SpatialPrefixTree.getNode(String) repeatedly if inclParents is true.
getNodesMap() - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
getNodesToShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
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
 
getNotFilters() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
getNumberOfDataNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
getNumberOfNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
getNumberOfOutboundConnections() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getNumberOfReplicas() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
getNumberOfReplicas() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getNumberOfShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
getNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getNumDocs() - Method in class org.elasticsearch.action.admin.indices.status.DocsStatus
The number of docs.
getNumDocs() - Method in class org.elasticsearch.index.engine.Segment
 
getNumDocs() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getObjectName() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getOffset() - Method in class org.elasticsearch.common.lab.LongsLAB.Allocation
 
getOffsetGap(Fieldable) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
getOffsetGap(Fieldable) - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
 
getOffsetGap(Fieldable) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
 
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.
getOpenFileDescriptorCount() - Static method in class org.elasticsearch.monitor.process.JmxProcessProbe
 
getOpenFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessStats
 
getOrder() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
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.
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getOtherCount() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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.
getOutRsts() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getOutSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getOwner() - Method in class jsr166e.SequenceLock
Returns the thread that currently owns this lock, or null if not owned.
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
 
getParallelism() - Method in class jsr166y.ForkJoinPool
Returns the targeted parallelism level of this pool.
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 class jsr166y.Phaser
Returns the parent of this phaser, or null if none.
getParent() - Method in interface org.elasticsearch.common.inject.Injector
Returns this injector's parent, or null if this is a top-level injector.
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
 
getPattern() - Method in exception org.elasticsearch.common.math.MathRuntimeException
Gets the pattern used to build the message of this throwable.
getPayloadScore() - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
The score for the payload
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
Peer recovery status (null if not applicable).
getPendingCount() - Method in class jsr166y.CountedCompleter
Returns the current pending count.
getPercent() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu usage.
getPercentTermsToMatch() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getPhase() - Method in class jsr166y.Phaser
Returns the current phase number.
getPid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
The process id.
getPool() - Static method in class jsr166y.ForkJoinTask
Returns the pool hosting the current task execution, or null if this task is executing outside of any ForkJoinPool.
getPool() - Method in class jsr166y.ForkJoinWorkerThread
Returns the pool hosting this thread.
getPoolIndex() - Method in class jsr166y.ForkJoinWorkerThread
Returns the index number of this thread in its pool.
getPoolSize() - Method in class jsr166y.ForkJoinPool
Returns the number of worker threads that have started but not yet terminated.
getPort() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
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.FieldNameAnalyzer
 
getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
 
getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.NamedCustomAnalyzer
 
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.
getPrefix() - Method in interface org.elasticsearch.common.logging.ESLogger
 
getPrefix() - Method in class org.elasticsearch.common.logging.support.AbstractESLogger
 
getPrefixQuery(String, String) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
getPrefixTree() - Method in class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Returns the SpatialPrefixTree used by this Strategy
getPrimaries() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
 
getPrimaries() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
getPrimaryInterface() - Method in class org.elasticsearch.monitor.network.NetworkInfo
 
getPrimaryStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Returns only the primary shards store size in bytes.
getPrimaryStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Returns only the primary shards store size in bytes.
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.
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
getPublishAddress() - Method in class org.elasticsearch.transport.TransportServiceManagement
 
getPublishHost() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
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.
getQueryTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
getQueue() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
getQueuedSubmissionCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing.
getQueuedTaskCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the total number of tasks currently held in queues by worker threads (but not including tasks submitted to the pool that have not begun executing).
getQueuedTaskCount() - Static method in class jsr166y.ForkJoinTask
Returns an estimate of the number of tasks that have been forked by the current worker thread but not yet executed.
getQueuedThreads() - Method in class jsr166e.SequenceLock
Returns a collection containing threads that may be waiting to acquire this lock.
getQueueLength() - Method in class jsr166e.SequenceLock
Returns an estimate of the number of threads waiting to acquire this lock.
getRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
getRateLimiter() - Method in class org.apache.lucene.store.StoreRateLimiting
 
getRawResult() - Method in class jsr166y.CountedCompleter
Always returns null.
getRawResult() - Method in class jsr166y.ForkJoinTask
Returns the result that would be returned by ForkJoinTask.join(), even if this task completed abnormally, or null if this task is not known to have been completed.
getRawResult() - Method in class jsr166y.RecursiveAction
Always returns null.
getRawResult() - Method in class jsr166y.RecursiveTask
 
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.
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
How much of the index has been recovered.
getRecoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
How much of the index has been recovered.
getRecoveredTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
getRecoveredTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
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
 
getRefreshStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getRefreshStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Refresh stats.
getRegisteredParties() - Method in class jsr166y.Phaser
Returns the number of parties registered at this phaser.
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
 
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
 
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(String) - Constructor for class org.elasticsearch.action.get.GetRequest
Constructs a new get request against the specified index.
GetRequest(String, String, String) - Constructor for class org.elasticsearch.action.get.GetRequest
Constructs a new get request against the specified index with the type and id.
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
 
getResident() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
GetResponse - Class in org.elasticsearch.action.get
The response of a get action.
getResponse() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
The actual get response, null if its a failure.
getResponse() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
The actual search response, null if its a failure.
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.
getResult() - Method in class org.elasticsearch.action.explain.ExplainResponse
 
getResult() - Method in class org.elasticsearch.action.update.UpdateResponse
 
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.
getReuseAddress() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getReusedIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
getReusedIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
getRoot() - Method in class jsr166y.Phaser
Returns the root ancestor of this phaser, which is the same as this phaser if it has no parent.
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
 
getRoutingNodes() - Method in class org.elasticsearch.cluster.ClusterState
 
getRoutingState() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getRoutingTable() - Method in class org.elasticsearch.cluster.ClusterState
 
getRoutingTable() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
getRunningThreadCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the number of worker threads that are not blocked waiting to join tasks or for other managed synchronization.
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.elasticsearch.search.internal.InternalSearchHit
 
getScore() - Method in class org.elasticsearch.search.lookup.DocLookup
 
getScore() - Method in interface org.elasticsearch.search.SearchHit
The score.
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.
getSearch() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getSearch() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
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
 
getSegmentCount() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
getSegmentInfo(SegmentReader) - Static method in class org.elasticsearch.common.lucene.Lucene
 
getSegments() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
 
getSegmentsFileName() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
getSequence() - Method in class jsr166e.SequenceLock
Returns the current sequence number of this lock.
getServerOpen() - Method in class org.elasticsearch.http.HttpStats
 
getServerOpen() - Method in class org.elasticsearch.transport.TransportStats
 
getService() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
getService() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
getServiceAttributes() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
The attributes of the node.
getSettings() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
The settings of the node.
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.settings.IndexSettingsService
 
getSettings() - Method in class org.elasticsearch.node.NodeBuilder
Set addition settings simply by working directly against the settings builder.
getShape() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
getShapeRel() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
getShard() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
getShard() - Method in interface org.elasticsearch.search.SearchHit
The shard of the search hit.
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.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
 
getShardId() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationResponse
 
getShardId() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
getShardId() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getShardId() - Method in class org.elasticsearch.search.SearchShardTarget
 
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
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.indices.segments.IndexSegments
 
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.IndicesStats
 
getShards() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
getShards() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getShards() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
getShards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
getShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
getShards(ClusterState, String, String, String, String, String) - Method in 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
 
getShare() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
getShortValue() - Method in class org.elasticsearch.index.field.data.NumericDocFieldData
 
getShouldFilters() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
getSimilarity() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getSingles() - Method in class org.elasticsearch.common.unit.SizeValue
 
getSize() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getSize() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
getSize() - Method in class org.elasticsearch.index.engine.Segment
 
getSize() - Method in class org.elasticsearch.index.store.StoreManagement
 
getSize() - Method in class org.elasticsearch.index.store.StoreStats
 
getSizeInBytes() - Method in class org.elasticsearch.index.engine.Segment
 
getSizeInBytes() - Method in class org.elasticsearch.index.store.StoreManagement
 
getSizeInBytes() - Method in class org.elasticsearch.index.store.StoreStats
 
getSlop() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
Sets the phrase slop for this query.
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.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.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.cluster.metadata.MappingMetaData
Converts the serialized compressed form of the mappings into a parsed map.
getSourceAsString() - Method in class org.elasticsearch.action.get.GetResponse
 
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).
getSourceKey() - Method in interface org.elasticsearch.common.inject.spi.ConvertedConstantBinding
Returns the key for the source binding.
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.
getSpatialContext() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
getStage() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
getStartOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
getStartTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
getStartTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
getStartTime() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
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.state.ClusterStateResponse
 
getState() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The shard state (index/local state).
getState() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getState() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
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 interface org.elasticsearch.index.shard.service.IndexShard
 
getStats() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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 enum org.elasticsearch.rest.RestStatus
 
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.
getStealCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the total number of tasks stolen from one thread's work queue by another.
getStopWords() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
getStore() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getStore() - Method in class org.elasticsearch.indices.NodeIndicesStats
The size of the index storage taken on the node.
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Returns the full store size in bytes, of both primaries and replicas.
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Returns the full store size in bytes, of both primaries and replicas.
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The current size of the shard index storage.
getStoreSize() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getStringValue() - Method in class org.elasticsearch.index.field.data.DocFieldData
 
getSubCell(Point) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
Performant implementations are expected to implement this efficiently by considering the current cell's boundary.
getSubCells(Shape) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
Like Node.getSubCells() but with the results filtered by a shape.
getSubCells() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
Gets the cells at the next grid cell level that cover this cell.
getSubCellsSize() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
Node.getSubCells().size() -- usually a constant.
getSubQuery() - Method in class org.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
getSubQuery() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
getSuccessfulShards() - Method in class org.elasticsearch.action.delete.index.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.
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.
getSupertype(Class<?>) - Method in class org.elasticsearch.common.inject.TypeLiteral
Returns the generic form of supertype.
getSurplusQueuedTaskCount() - Static method in class jsr166y.ForkJoinTask
Returns an estimate of how many more locally queued tasks are held by the current worker thread than there are other worker threads that might steal them.
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.
getTaskName() - Method in class org.elasticsearch.common.StopWatch.TaskInfo
Return the name of this task.
getTcp() - Method in class org.elasticsearch.monitor.network.NetworkStats
 
getTcpKeepAlive() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getTcpNoDelay() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getTcpReceiveBufferSize() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getTcpSendBufferSize() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getTemplate() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
getTemplates() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
getTerm() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
getTerm() - Method in class org.elasticsearch.common.lucene.search.TermFilter
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet.ByteEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet.FloatEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet.IntEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet.LongEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet.ShortEntry
 
getTerm() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.StringEntry
 
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.bytes.InternalByteTermsFacet.ByteEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet.FloatEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet.IntEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet.LongEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet.ShortEntry
 
getTermAsNumber() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.StringEntry
 
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
 
getTerms() - Method in class org.apache.lucene.search.PublicTermsFilter
 
getTerms() - Method in class org.apache.lucene.search.XTermsFilter
 
getTerms() - Method in class org.elasticsearch.index.search.UidFilter
 
getThreadInfo(long[]) - Method in class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
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.
getThreads() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
getThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
getThrottleTime() - Method in class org.elasticsearch.index.store.StoreStats
 
getTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
getTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
getTime() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
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 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
 
getTimeInNanos() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
Returns the elapsed time between two successive barrier executions.
getTimeInSeconds() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
Returns the elapsed time between two successive barrier executions.
getTimestamp() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
getTimestamp() - Method in class org.elasticsearch.common.lucene.IndexCommitDelegate
 
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.facet.geodistance.GeoDistanceFacet.Entry
 
getTo() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getToAsString() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getTokenBytes() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
Note: doesn't contain a trailing leaf byte.
getTokens() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
 
getTokenString() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
Note: doesn't contain a trailing leaf byte.
getTook() - Method in class org.elasticsearch.action.bulk.BulkResponse
How long the bulk execution took.
getTook() - Method in class org.elasticsearch.action.search.SearchResponse
How long the search took.
getTookInMillis() - Method in class org.elasticsearch.action.bulk.BulkResponse
How long the bulk execution took in milliseconds.
getTookInMillis() - Method in class org.elasticsearch.action.search.SearchResponse
How long the search took in milliseconds.
getTotal() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
 
getTotal() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
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 class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
getTotal() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
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.unbounded.InternalCountHistogramFacet.CountEntry
 
getTotal() - Method in class org.elasticsearch.search.facet.histogram.unbounded.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
 
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 class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
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.unbounded.InternalCountHistogramFacet.CountEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getTotalCount() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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.
getTotalNumberOfRequests() - Method in class org.elasticsearch.transport.TransportServiceManagement
 
getTotalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getTotalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
getTotalOpen() - Method in class org.elasticsearch.http.HttpStats
 
getTotalShards() - Method in class org.elasticsearch.action.delete.index.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.
getTotalSockets() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getTotalVirtual() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
getTranslogId() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The transaction log id.
getTranslogId() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getTranslogNumberOfOperations() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
getTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The number of transaction operations in the transaction log.
getTranslogSize() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getTransport() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
 
getTransport() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
getTxCount() - Method in class org.elasticsearch.transport.TransportStats
 
getTxSize() - Method in class org.elasticsearch.transport.TransportStats
 
getType(int) - Static method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterIterator
Computes the type of the given character
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.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.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.field.data.DocFieldData
 
getType() - Method in class org.elasticsearch.index.get.GetResult
The type of the document.
getType() - Method in class org.elasticsearch.river.RiverName
 
getType() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
getType() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
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.bounded.InternalBoundedCountHistogramFacet
 
getType() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
getType() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
getType() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
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.bytes.InternalByteTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
getType() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
getType() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
getType() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
getType() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
getType() - Method in interface org.elasticsearch.search.SearchHit
The type of the document.
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
 
getUnarrivedParties() - Method in class jsr166y.Phaser
Returns the number of registered parties that have not yet arrived at the current phase of this phaser.
getUnassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
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
 
getUncaughtExceptionHandler() - Method in class jsr166y.ForkJoinPool
Returns the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks.
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
 
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
 
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
 
getValid() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
getValid() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
A boolean denoting whether the query is valid.
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.field.data.bytes.ByteDocFieldData
 
getValue() - Method in class org.elasticsearch.index.field.data.doubles.DoubleDocFieldData
 
getValue() - Method in class org.elasticsearch.index.field.data.floats.FloatDocFieldData
 
getValue() - Method in class org.elasticsearch.index.field.data.ints.IntDocFieldData
 
getValue() - Method in class org.elasticsearch.index.field.data.longs.LongDocFieldData
 
getValue() - Method in class org.elasticsearch.index.field.data.shorts.ShortDocFieldData
 
getValue() - Method in class org.elasticsearch.index.field.data.strings.StringDocFieldData
 
getValue() - Method in class org.elasticsearch.index.get.GetField
 
getValue() - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
getValue() - Method in enum org.elasticsearch.index.VersionType
 
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.
getValues() - Method in class org.elasticsearch.index.field.data.bytes.ByteDocFieldData
 
getValues() - Method in class org.elasticsearch.index.field.data.doubles.DoubleDocFieldData
 
getValues() - Method in class org.elasticsearch.index.field.data.floats.FloatDocFieldData
 
getValues() - Method in class org.elasticsearch.index.field.data.ints.IntDocFieldData
 
getValues() - Method in class org.elasticsearch.index.field.data.longs.LongDocFieldData
 
getValues() - Method in class org.elasticsearch.index.field.data.shorts.ShortDocFieldData
 
getValues() - Method in class org.elasticsearch.index.field.data.strings.StringDocFieldData
 
getValues() - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
getValues() - Method in class org.elasticsearch.index.get.GetField
 
getValues() - Method in class org.elasticsearch.index.mapper.geo.GeoPointDocFieldData
 
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.
getVariance() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
getVariance() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
Variance of the values.
getVendor() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getVersion() - Method in class org.elasticsearch.action.delete.DeleteResponse
The version of the delete operation.
getVersion() - Method in class org.elasticsearch.action.get.GetResponse
The version of the doc.
getVersion() - Method in class org.elasticsearch.action.index.IndexResponse
Returns the version of the doc indexed.
getVersion() - Method in class org.elasticsearch.action.update.UpdateResponse
Returns the 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.lucene.IndexCommitDelegate
 
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.
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
 
getWaitingConsumerCount() - Method in class jsr166y.LinkedTransferQueue
 
getWaitingConsumerCount() - Method in interface jsr166y.TransferQueue
Returns an estimate of the number of consumers waiting to receive elements via BlockingQueue.take() or timed poll.
getWarmer() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
getWeightedFragInfoList(List<FieldFragList.WeightedFragInfo>) - Method in class org.apache.lucene.search.vectorhighlight.XScoreOrderFragmentsBuilder
Sort by score the list of WeightedFragInfo
getWeightedFragInfoList(List<FieldFragList.WeightedFragInfo>) - Method in class org.apache.lucene.search.vectorhighlight.XSimpleFragmentsBuilder
do nothing.
getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.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
 
getWorkerCount() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getWorldNode() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
Returns the level 0 cell which encompasses all spatial data.
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(boolean) - Method in class org.elasticsearch.search.facet.AbstractFacetBuilder
Marks the facet to run in a global scope, not bounded by any query.
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(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.
GLOBAL - Static variable in class org.elasticsearch.search.internal.ContextIndexSearcher.Scopes
 
globalBlockedException(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
globalBlockedRaiseException(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
globalFieldCaseConversion - Static variable in class org.elasticsearch.common.xcontent.XContentBuilder
 
globalFieldCaseConversion(XContentBuilder.FieldCaseConversion) - Static method in class org.elasticsearch.common.xcontent.XContentBuilder
 
globalSettings() - Method in class org.elasticsearch.river.RiverSettings
 
GREATER_ICOST - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This constant is accessible by subclasses for historical purposes.
GreekAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
GreekAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GreekAnalyzerProvider
 
gridH - Variable in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
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.
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
 
GroupShardsIterator(Collection<ShardIterator>) - Constructor for class org.elasticsearch.cluster.routing.GroupShardsIterator
 
groupStats() - Method in class org.elasticsearch.index.search.stats.SearchStats
 
groupStats() - Method in class org.elasticsearch.search.internal.SearchContext
 
groupStats(List<String>) - Method in class org.elasticsearch.search.internal.SearchContext
 
gt(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
gt(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
gt(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
gt(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
gt(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
gt(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
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
The from part of the filter query.
gte(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
gte(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
gte(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The from part of the filter query.
gte(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
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.
Guice - Class in org.elasticsearch.common.inject
The entry point to the Guice framework.
GZIP - Static variable in class org.elasticsearch.common.Base64
Specify that data should be gzip-compressed in second bit.

H

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.
handleException(TransportException) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
 
handleException(TransportException) - Method in class org.elasticsearch.transport.PlainTransportFuture
 
handleException(TransportException) - Method in interface org.elasticsearch.transport.TransportResponseHandler
 
handleException(TransportException) - Method in class org.elasticsearch.transport.VoidTransportResponseHandler
 
handleMergeException(Throwable) - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
handler(String) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.health.RestClusterHealthAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.node.hotthreads.RestNodesHotThreadsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.node.info.RestNodesInfoAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.node.restart.RestNodesRestartAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.node.shutdown.RestNodesShutdownAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.node.stats.RestNodesStatsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.reroute.RestClusterRerouteAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.settings.RestClusterGetSettingsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.settings.RestClusterUpdateSettingsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.state.RestClusterStateAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.alias.RestGetIndicesAliasesAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.alias.RestIndicesAliasesAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.close.RestCloseIndexAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.create.RestCreateIndexAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.delete.RestDeleteIndexAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.exists.RestIndicesExistsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.flush.RestFlushAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.gateway.snapshot.RestGatewaySnapshotAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.mapping.delete.RestDeleteMappingAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.mapping.get.RestGetMappingAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.mapping.put.RestPutMappingAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.open.RestOpenIndexAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.optimize.RestOptimizeAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.refresh.RestRefreshAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.segments.RestIndicesSegmentsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.settings.RestGetSettingsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.settings.RestUpdateSettingsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.stats.RestIndicesStatsAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.status.RestIndicesStatusAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.template.delete.RestDeleteIndexTemplateAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.template.get.RestGetIndexTemplateAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.template.put.RestPutIndexTemplateAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.validate.query.RestValidateQueryAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.warmer.delete.RestDeleteWarmerAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.warmer.get.RestGetWarmerAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.indices.warmer.put.RestPutWarmerAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.bulk.RestBulkAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.count.RestCountAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.delete.RestDeleteAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.deletebyquery.RestDeleteByQueryAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.explain.RestExplainAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.get.RestGetAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.get.RestHeadAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.get.RestMultiGetAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.index.RestIndexAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.main.RestMainAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.mlt.RestMoreLikeThisAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.percolate.RestPercolateAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.search.RestSearchAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.update.RestUpdateAction
 
handleRequest(RestRequest, RestChannel) - Method in interface org.elasticsearch.rest.RestHandler
 
handleResponse(T) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
 
handleResponse(V) - Method in class org.elasticsearch.transport.PlainTransportFuture
 
handleResponse(T) - Method in interface org.elasticsearch.transport.TransportResponseHandler
 
handleResponse(VoidStreamable) - Method in class org.elasticsearch.transport.VoidTransportResponseHandler
 
handles() - Method in class org.elasticsearch.common.io.stream.CachedStreamOutput.Entry
 
handles(Compressor) - Method in class org.elasticsearch.common.io.stream.CachedStreamOutput.Entry
 
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
 
HandlesStreamOutput(StreamOutput, int) - Constructor for class org.elasticsearch.common.io.stream.HandlesStreamOutput
 
handleUpstream(ChannelHandlerContext, ChannelEvent) - Method in class org.elasticsearch.common.netty.OpenChannelsHandler
 
hasAlias(String) - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
hasAnalyzer(String) - Method in class org.elasticsearch.indices.analysis.IndicesAnalysisService
 
hasArray() - Method in class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
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
 
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 - Class in org.elasticsearch.index.search.child
 
HasChildFilter(Query, String, String, String, SearchContext) - Constructor for class org.elasticsearch.index.search.child.HasChildFilter
 
HasChildFilterBuilder - Class in org.elasticsearch.index.query
 
HasChildFilterBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.index.query.HasChildFilterBuilder
 
HasChildFilterParser - Class in org.elasticsearch.index.query
 
HasChildFilterParser() - 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() - Constructor for class org.elasticsearch.index.query.HasChildQueryParser
 
hasClauses() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Return true if the query being built has no clause yet
hasCollectors(String) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
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 interface org.elasticsearch.rest.RestRequest
 
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
 
hasDynamicSetting(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
hasDynamicSetting(String) - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
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.
hasFieldNames() - Method in class org.elasticsearch.search.internal.SearchContext
 
hasGlobalBlock(ClusterBlock) - 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(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
 
hash(String, String) - Method in interface org.elasticsearch.cluster.routing.operation.hash.HashFunction
 
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(double) - Static method in class org.elasticsearch.common.math.MathUtils
Returns an integer hash code representing the given double value.
hash(double[]) - Static method in class org.elasticsearch.common.math.MathUtils
Returns an integer hash code representing the given double array.
hash2_64(byte[], int, int, long) - Static method in class org.elasticsearch.common.MurmurHash
 
hash32(byte[], int, int, int) - Static method in class org.elasticsearch.common.MurmurHash
 
hash3_x64_128(byte[], int, int, long) - Static method in class org.elasticsearch.common.MurmurHash
 
hashCode() - Method in class jsr166e.ConcurrentHashMapV8
Returns the hash code value for this Map, i.e., the sum of, for each key-value pair in the map, key.hashCode() ^ value.hashCode().
hashCode() - Method in class jsr166e.extra.ReadMostlyVector
 
hashCode() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
hashCode() - Method in class org.apache.lucene.search.PublicTermsFilter
 
hashCode() - Method in class org.apache.lucene.search.XTermsFilter
 
hashCode() - Method in class org.elasticsearch.action.GenericAction
 
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.node.DiscoveryNode
 
hashCode() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
hashCode() - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
 
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.HashedBytesArray
 
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.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(Object...) - Static method in class org.elasticsearch.common.inject.internal.Objects
Generates a hash code for multiple values.
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.IndexCommitDelegate
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
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.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.TermFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
 
hashCode() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
hashCode() - Method in class org.elasticsearch.common.settings.ImmutableSettings
 
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.SizeValue
 
hashCode() - Method in class org.elasticsearch.common.unit.TimeValue
 
hashCode() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
hashCode() - Method in class org.elasticsearch.common.UUID
Returns a hash code for this UUID.
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.Index
 
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.geo.GeoDistanceFilter
 
hashCode() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
hashCode() - Method in class org.elasticsearch.index.search.geo.Point
 
hashCode() - Method in class org.elasticsearch.index.search.nested.BlockJoinQuery
 
hashCode() - Method in class org.elasticsearch.index.search.nested.IncludeAllChildrenQuery
 
hashCode() - Method in class org.elasticsearch.index.search.nested.NestedDocsFilter
 
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.search.UidFilter
 
hashCode() - Method in class org.elasticsearch.index.shard.ShardId
 
hashCode() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
hashCode() - Method in class org.elasticsearch.river.RiverName
 
hashCode() - Method in class org.elasticsearch.script.ScriptService.CacheKey
 
hashCode() - Method in class org.elasticsearch.search.SearchShardTarget
 
HashedBytesArray - Class in org.elasticsearch.common.bytes
 
HashedBytesArray(byte[]) - Constructor for class org.elasticsearch.common.bytes.HashedBytesArray
 
HashedBytesArray(String) - Constructor for class org.elasticsearch.common.bytes.HashedBytesArray
 
HashFunction - Interface in org.elasticsearch.cluster.routing.operation.hash
 
hasIndex(String) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
hasIndex(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
hasIndex(String) - Method in interface org.elasticsearch.indices.IndicesService
 
hasIndex(String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
hasIndexAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
hasIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
 
hasLength(CharSequence) - Static method in class org.elasticsearch.common.Strings
Check that the given CharSequence is neither null nor of length 0.
hasLength(String) - Static method in class org.elasticsearch.common.Strings
Check that the given String is neither null nor of length 0.
hasMapper(FieldMapper) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
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
 
hasNested() - Method in class org.elasticsearch.index.mapper.MapperService
 
hasNestedObjects() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
hasNext() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
hasNext() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
 
hasNodeFile() - Method in class org.elasticsearch.env.NodeEnvironment
 
hasParam(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
hasParam(String) - Method in interface org.elasticsearch.rest.RestRequest
 
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
 
hasQueuedSubmissions() - Method in class jsr166y.ForkJoinPool
Returns true if there are any tasks submitted to this pool that have not yet begun executing.
hasQueuedThread(Thread) - Method in class jsr166e.SequenceLock
Queries whether the given thread is waiting to acquire this lock.
hasQueuedThreads() - Method in class jsr166e.SequenceLock
Queries whether any threads are waiting to acquire this lock.
hasRiverByName(String) - Method in class org.elasticsearch.river.routing.RiversRouting
 
hasScriptFields() - Method in class org.elasticsearch.search.internal.SearchContext
 
hasSearchAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
hasSearchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
hasShard(int) - Method in interface org.elasticsearch.index.service.IndexService
 
hasShard(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
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
 
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.search.internal.SearchContext
 
hasUnassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.FieldData
Is there a value associated with this document id.
hasValue(int) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.strings.MultiValueStringFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.field.data.strings.SingleValueStringFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
hasValue(int) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
hasVersion() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards
 
hasVersion(long) - Method in class org.elasticsearch.index.gateway.CommitPoints
 
hasWaitingConsumer() - Method in class jsr166y.LinkedTransferQueue
 
hasWaitingConsumer() - Method in interface jsr166y.TransferQueue
Returns true if there is at least one consumer waiting to receive an element via BlockingQueue.take() or timed poll.
hbMakeCodeLengths(char[], int[], int, int) - Static method in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This method is accessible by subclasses for historical purposes.
HEADER - Static variable in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
header(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
header(String) - Method in interface org.elasticsearch.rest.RestRequest
 
HEADER_PLACEHOLDER - Static variable in class org.elasticsearch.transport.support.TransportStreams
 
HEADER_SIZE - Static variable in class org.elasticsearch.transport.support.TransportStreams
 
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
 
HEAP_DUMP - Static variable in class org.elasticsearch.monitor.dump.heap.HeapDumpContributor
 
heapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
HeapDumpContributor - Class in org.elasticsearch.monitor.dump.heap
 
HeapDumpContributor(String, Settings) - Constructor for class org.elasticsearch.monitor.dump.heap.HeapDumpContributor
 
heapInit() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
heapMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
 
heapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
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.
helpQuiesce() - Static method in class jsr166y.ForkJoinTask
Possibly executes tasks until the pool hosting the current task is quiescent.
Hex - Class in org.elasticsearch.common
 
Hex() - Constructor for class org.elasticsearch.common.Hex
 
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() - Method in class org.elasticsearch.search.internal.SearchContext
 
highlight(SearchContextHighlight) - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
highlighter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
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
 
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() - 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.
highlightFilter() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
highlightFilter(boolean) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
highlightFilters - Static variable in class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
 
HighlightPhase - Class in org.elasticsearch.search.highlight
 
HighlightPhase(Settings) - Constructor for class org.elasticsearch.search.highlight.HighlightPhase
 
HighlightPhase.Encoders - Class in org.elasticsearch.search.highlight
 
HighlightPhase.Encoders() - Constructor for class org.elasticsearch.search.highlight.HighlightPhase.Encoders
 
HindiAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
HindiAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.HindiAnalyzerProvider
 
histogramFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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.
HistogramFacetProcessor - Class in org.elasticsearch.search.facet.histogram
 
HistogramFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.histogram.HistogramFacetProcessor
 
histogramScriptFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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
 
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.matchedfilters.MatchedFiltersFetchSubPhase
 
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.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.matchedfilters.MatchedFiltersFetchSubPhase
 
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.version.VersionFetchSubPhase
 
hitExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
hits() - Method in class org.elasticsearch.action.search.SearchResponse
The search hits.
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.matchedfilters.MatchedFiltersFetchSubPhase
 
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.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.matchedfilters.MatchedFiltersFetchSubPhase
 
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.version.VersionFetchSubPhase
 
hitsExecutionNeeded(SearchContext) - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
homeFile() - Method in class org.elasticsearch.env.Environment
The home of the installation.
hostname() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
System's hostname.
hostname() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
hotThreads() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
 
HotThreads - Class in org.elasticsearch.monitor.jvm
 
HotThreads() - Constructor for class org.elasticsearch.monitor.jvm.HotThreads
 
hours() - Method in class org.elasticsearch.common.unit.TimeValue
 
hoursFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
HP - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on HP.
HTML - Static variable in class org.elasticsearch.search.highlight.HighlightPhase.Encoders
 
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.NodeInfo
 
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() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
HttpChannel - Interface in org.elasticsearch.http
 
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.NullProgress() - Constructor for class org.elasticsearch.common.http.client.HttpDownloadHelper.NullProgress
 
HttpDownloadHelper.VerboseProgress - Class in org.elasticsearch.common.http.client
verbose progress system prints to some output stream
HttpDownloadHelper.VerboseProgress(PrintStream) - Constructor for class org.elasticsearch.common.http.client.HttpDownloadHelper.VerboseProgress
Construct a verbose progress reporter.
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) - Constructor for class org.elasticsearch.http.HttpInfo
 
HttpRequest - Interface in org.elasticsearch.http
 
HttpRequestHandler - Class in org.elasticsearch.http.netty
 
HttpRequestHandler(NettyHttpServerTransport) - Constructor for class org.elasticsearch.http.netty.HttpRequestHandler
 
HttpResponse - Interface in org.elasticsearch.http
 
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(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
 
HungarianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
HungarianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.HungarianAnalyzerProvider
 
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

id() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
id() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
 
id() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
The id of the action.
id() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The id of the action.
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.DeleteResponse
The id of the document deleted.
id() - Method in class org.elasticsearch.action.delete.index.IndexDeleteRequest
 
id() - Method in class org.elasticsearch.action.delete.index.ShardDeleteRequest
 
id() - Method in class org.elasticsearch.action.explain.ExplainRequest
 
id(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
id - Variable in class org.elasticsearch.action.get.GetRequest
 
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.GetResponse
The id of the document.
id() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
The id of the document.
id() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
 
id() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
The id of the action.
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.index.IndexResponse
The id of the document indexed.
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.SearchOperationThreading
 
id() - Method in enum org.elasticsearch.action.search.SearchType
The internal id of the type.
id() - Method in enum org.elasticsearch.action.support.broadcast.BroadcastOperationThreading
 
id() - Method in enum org.elasticsearch.action.support.IgnoreIndices
 
id() - Method in enum org.elasticsearch.action.support.replication.ReplicationType
The internal representation of the operation type.
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 class org.elasticsearch.action.update.UpdateResponse
The id of the document indexed.
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.metadata.IndexMetaData.State
 
id() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
 
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 class org.elasticsearch.common.transport.LocalTransportAddress
 
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.Create
 
id() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
id() - Method in class org.elasticsearch.index.engine.Engine.Index
 
id() - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
 
id() - Method in class org.elasticsearch.index.get.GetResult
The id of the document.
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.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 class org.elasticsearch.monitor.process.ProcessInfo
The process id.
id() - Method in class org.elasticsearch.search.count.CountSearchResult
 
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.FetchSearchRequest
 
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.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 - Variable in class org.elasticsearch.Version
 
ID_CACHE_TYPE - Static variable in class org.elasticsearch.index.cache.id.IdCacheModule.IdCacheSettings
 
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 - Interface in org.elasticsearch.index.cache.id
 
idCache() - Method in class org.elasticsearch.index.cache.IndexCache
 
idCache() - Method in class org.elasticsearch.search.internal.SearchContext
 
IdCacheModule - Class in org.elasticsearch.index.cache.id
 
IdCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.id.IdCacheModule
 
IdCacheModule.IdCacheSettings - Class in org.elasticsearch.index.cache.id
 
IdCacheModule.IdCacheSettings() - Constructor for class org.elasticsearch.index.cache.id.IdCacheModule.IdCacheSettings
 
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(Field.Index) - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
IdFieldMapper(String, String, Field.Index) - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
IdFieldMapper(String, String, Field.Index, Field.Store, Field.TermVector, float, boolean, FieldInfo.IndexOptions, String) - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
IdFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
IdFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper.Builder
 
IdFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
IdFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
 
IdFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
IdFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.IdFieldMapper.TypeParser
 
idFromUid(String) - Static method in class org.elasticsearch.index.mapper.Uid
 
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?
IdReaderCache - Interface in org.elasticsearch.index.cache.id
 
IdReaderTypeCache - Interface in org.elasticsearch.index.cache.id
 
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.index.query.IdsFilterBuilder
Adds ids to the filter.
ids(String...) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
Adds ids to the filter.
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
 
ifconfig() - Method in class org.elasticsearch.monitor.network.SigarNetworkProbe
 
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
 
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.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.
ignoreConflicts(boolean) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService.PutRequest
 
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
 
ignoreException(Throwable) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
ignoreException(Throwable) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
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
 
ignoreIndices() - Method in class org.elasticsearch.action.search.MultiSearchRequest
 
ignoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.search.MultiSearchRequest
 
ignoreIndices() - Method in class org.elasticsearch.action.search.SearchRequest
 
ignoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.search.SearchRequest
 
ignoreIndices() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
ignoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
IgnoreIndices - Enum in org.elasticsearch.action.support
Specifies what type of requested indices to exclude.
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
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
IgnoreOnRecoveryEngineException - Interface in org.elasticsearch.index.engine
Exceptions implementing this interface will be ignored during recovery.
ignoreRecoveryAttempt() - Method in interface org.elasticsearch.index.shard.service.IndexShard
Returns true if this shard can ignore a recovery attempt made to it (since the already doing/done it)
ignoreRecoveryAttempt() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
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
 
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
 
ignoreUnmapped(boolean) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
Sets if the field does not exists in the index, it should be ignored and not sorted by or not.
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
 
IllegalShardRoutingStateException(ShardRouting, String) - Constructor for exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
 
IllegalShardRoutingStateException(ShardRouting, String, Throwable) - Constructor for exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
 
immutableBlobContainer(BlobPath) - Method in interface org.elasticsearch.common.blobstore.BlobStore
 
immutableBlobContainer(BlobPath) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
ImmutableBlobContainer - Interface in org.elasticsearch.common.blobstore
 
ImmutableBlobContainer.WriterListener - Interface in org.elasticsearch.common.blobstore
 
immutableMap() - Method in class org.elasticsearch.common.collect.MapBuilder
 
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(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, boolean, ShardRoutingState, long) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
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(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 interface org.elasticsearch.index.engine.Engine
 
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
 
include(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
 
IncludeAllChildrenQuery - Class in org.elasticsearch.index.search.nested
A special query that accepts a top level parent matching query, and returns all the children of that parent as well.
IncludeAllChildrenQuery(Query, Filter) - Constructor for class org.elasticsearch.index.search.nested.IncludeAllChildrenQuery
 
includeFetch() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
includeFetch() - Method in class org.elasticsearch.search.query.QuerySearchResult
 
includeFetch() - Method in interface org.elasticsearch.search.query.QuerySearchResultProvider
If both query and fetch happened on the same call.
includeFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
includeInAll - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.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.Builder
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.GeoStringFieldMapper.Builder
 
includeInAll(Boolean) - Method in interface org.elasticsearch.index.mapper.internal.AllFieldMapper.IncludeInAll
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
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.multifield.MultiFieldMapper
 
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.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 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
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.
includes(String[]) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
 
INCLUDES - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
includes() - Method in class org.elasticsearch.search.fetch.partial.PartialFieldsContext.PartialField
 
includeUpper(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
includeUpper(boolean) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
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.
increment() - Method in class jsr166e.LongAdder
Equivalent to add(1).
increment(K) - Method in class jsr166e.LongAdderTable
Increments the sum associated with the given key.
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.
incrementalFactor() - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
incrementalFactor() - Method in interface org.elasticsearch.search.internal.ScopePhase.TopDocsPhase
 
incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.TrimFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.TruncateTokenFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.UniqueTokenFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.pattern.PatternReplaceFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.pattern.PatternTokenizer
 
incrementToken() - Method in class org.elasticsearch.common.lucene.all.AllTokenStream
 
incrementToken() - Method in class org.elasticsearch.common.lucene.spatial.prefix.NodeTokenStream
 
incrementToken() - Method in class org.elasticsearch.common.lucene.uid.UidField.UidPayloadTokenStream
 
incrementToken() - Method in class org.elasticsearch.index.analysis.NumericTokenizer
 
index() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
index(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
 
index() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
 
index(String) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
 
index(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
 
index(String) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
 
index() - Method in class org.elasticsearch.action.admin.indices.segments.IndexSegments
 
index() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
 
index(String) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
index() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
index(String) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
index() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
index() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
The index name of the action.
index() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The index name of the action.
index(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
Sets the index the delete will happen on.
index() - Method in class org.elasticsearch.action.delete.DeleteResponse
The index the document was deleted from.
index() - Method in class org.elasticsearch.action.delete.index.IndexDeleteResponse
The index the delete by query operation was executed against.
index(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryResponse
The response of a specific index.
index() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
The index the delete by query operation was executed against.
index(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
index(String) - Method in class org.elasticsearch.action.get.GetRequest
Sets the index of the document to fetch.
index() - Method in class org.elasticsearch.action.get.GetResponse
The index the document was fetched from.
index() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
The index name of the document.
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.get.MultiGetResponse.Failure
The index name of the action.
index(String) - Method in class org.elasticsearch.action.index.IndexRequest
Sets the index the index operation will happen on.
index() - Method in class org.elasticsearch.action.index.IndexResponse
The index the document was indexed into.
index() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The index to load the document from which the "like" query will run with.
index(String) - Method in class org.elasticsearch.action.percolate.PercolateRequest
 
index() - Method in class org.elasticsearch.action.percolate.PercolateRequest
 
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.broadcast.BroadcastShardOperationRequest
 
index() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardOperationResponse
 
index() - Method in class org.elasticsearch.action.support.DefaultShardOperationFailedException
 
index - Variable in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
index() - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
index(String) - 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 - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
index() - 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.update.UpdateRequest
Sets the index the document will exists on.
index() - Method in class org.elasticsearch.action.update.UpdateResponse
The index the document was indexed into.
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.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
index() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
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
 
index(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
index() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
The index name.
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() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
index(Engine.Index) - Method in interface org.elasticsearch.index.engine.Engine
 
index(Engine.Index) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
index() - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
index() - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
index() - Method in class org.elasticsearch.index.get.GetResult
The index the document was fetched from.
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 - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
index(Field.Index) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
INDEX - Static variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
index - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
index() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
index(Field.Index) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
index(Field.Index) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
INDEX - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
 
index() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
 
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.query.QueryParseContext
 
index(Engine.Index) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
index(Engine.Index) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
index() - Method in class org.elasticsearch.index.shard.ShardId
 
index() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
index() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
index() - Method in interface org.elasticsearch.search.SearchHit
The index of the hit.
index() - Method in class org.elasticsearch.search.SearchShardTarget
 
INDEX - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
INDEX_CLOSED_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.MetaDataStateIndexService
 
INDEX_CONTENT_TYPE - Static variable in class org.elasticsearch.client.Requests
The default content type to use to generate source documents when indexing.
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.percolator.PercolatorService
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Defaults
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
 
INDEX_OPTIONS - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
 
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_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_TOTAL_SHARDS_PER_NODE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
 
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
 
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(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
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.
indexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Builder
 
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, FieldDataCache, QueryParserCache, IdCache, BloomCache) - Constructor for class org.elasticsearch.index.cache.IndexCache
 
indexCache() - Method in class org.elasticsearch.index.query.QueryParseContext
 
IndexCacheModule - Class in org.elasticsearch.index.cache
 
IndexCacheModule(Settings) - Constructor for class org.elasticsearch.index.cache.IndexCacheModule
 
indexChanged() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
Indicates that the index has changed from the latest snapshot.
indexCommit() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
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
 
indexCount() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
IndexCreationException - Exception in org.elasticsearch.indices
 
IndexCreationException(Index, Throwable) - Constructor for exception org.elasticsearch.indices.IndexCreationException
 
indexCurrent() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
IndexDeleteByQueryRequest - Class in org.elasticsearch.action.deletebyquery
Delete by query request to execute on a specific index.
IndexDeleteByQueryResponse - Class in org.elasticsearch.action.deletebyquery
Delete by query response executed on a specific index.
IndexDeleteRequest - Class in org.elasticsearch.action.delete.index
 
IndexDeleteRequest(DeleteRequest) - Constructor for class org.elasticsearch.action.delete.index.IndexDeleteRequest
 
IndexDeleteResponse - Class in org.elasticsearch.action.delete.index
Delete by query response executed on a specific index.
indexed() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
indexed() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
IndexedGeoBoundingBoxFilter - Class in org.elasticsearch.index.search.geo
 
IndexedGeoBoundingBoxFilter() - Constructor for class org.elasticsearch.index.search.geo.IndexedGeoBoundingBoxFilter
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
indexedValue(String) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the indexed value.
indexedValue(String) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
indexedValue(String) - 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
 
IndexEngineModule.EngineSettings() - Constructor for class org.elasticsearch.index.engine.IndexEngineModule.EngineSettings
 
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
 
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
 
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, Field.Store, Field.TermVector, float, boolean, FieldInfo.IndexOptions, boolean) - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
IndexFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
IndexFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Builder
 
IndexFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
IndexFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
IndexFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
IndexFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.IndexFieldMapper.TypeParser
 
indexFieldName - Variable in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
indexFieldName - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
indexFiles() - Method in class org.elasticsearch.index.gateway.CommitPoint
 
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
 
indexing() - Method 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
 
indexing() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
IndexingMemoryController - Class in org.elasticsearch.indices.memory
 
IndexingMemoryController(Settings, ThreadPool, IndicesService) - Constructor for class org.elasticsearch.indices.memory.IndexingMemoryController
 
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 interface org.elasticsearch.index.shard.service.IndexShard
 
indexingService() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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 interface org.elasticsearch.index.shard.service.IndexShard
 
indexingStats(String...) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
IndexingStats.Stats - Class in org.elasticsearch.index.indexing
 
IndexingStats.Stats(long, long, long, long, long, long) - Constructor for class org.elasticsearch.index.indexing.IndexingStats.Stats
 
indexInput(IndexInput) - Method in interface org.elasticsearch.common.compress.Compressor
 
indexInput(IndexInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
indexInput(IndexInput) - Method in class org.elasticsearch.common.compress.snappy.UnavailableSnappyCompressor
 
indexInput(IndexInput) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressor
 
indexLocations(Index) - Method in class org.elasticsearch.env.NodeEnvironment
 
IndexMetaData - Class in org.elasticsearch.cluster.metadata
 
indexMetaData() - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Response
 
indexMetaData(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
IndexMetaData.Builder - Class in org.elasticsearch.cluster.metadata
 
IndexMetaData.Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
IndexMetaData.Builder(IndexMetaData) - Constructor for class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
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.core.AbstractFieldMapper.OpenBuilder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.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 - Variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
 
indexName - Variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper.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.
IndexNameFacetCollector - Class in org.elasticsearch.search.facet.terms.index
 
IndexNameFacetCollector(String, String, TermsFacet.ComparatorType, int) - Constructor for class org.elasticsearch.search.facet.terms.index.IndexNameFacetCollector
 
IndexNameModule - Class in org.elasticsearch.index
 
IndexNameModule(Index) - Constructor for class org.elasticsearch.index.IndexNameModule
 
indexNameTerm() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The index name term that can be used as a factory.
indexOf(Object) - Method in class jsr166e.extra.ReadMostlyVector
 
indexOf(Object, int) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.indexOf(Object, int)
indexOptions - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
indexOptions(FieldInfo.IndexOptions) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
indexOptions - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
indexOptions() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
indexOptions(FieldInfo.IndexOptions) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
indexOptions() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
indexOptionToString(FieldInfo.IndexOptions) - Static method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
indexOutput(IndexOutput) - Method in interface org.elasticsearch.common.compress.Compressor
 
indexOutput(IndexOutput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
indexOutput(IndexOutput) - Method in class org.elasticsearch.common.compress.snappy.UnavailableSnappyCompressor
 
indexOutput(IndexOutput) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressor
 
IndexPluginsModule - Class in org.elasticsearch.plugins
 
IndexPluginsModule(Settings, PluginsService) - Constructor for class org.elasticsearch.plugins.IndexPluginsModule
 
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() - Constructor for class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor
 
IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings - Class in org.elasticsearch.index.query
 
IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings(MapBinder<String, FilterParserFactory>, Map<String, Settings>) - Constructor for class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentFilterParsersBindings
 
IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings - Class in org.elasticsearch.index.query
 
IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings(MapBinder<String, QueryParserFactory>, Map<String, Settings>) - Constructor for class org.elasticsearch.index.query.IndexQueryParserModule.QueryParsersProcessor.XContentQueryParsersBindings
 
IndexQueryParserService - Class in org.elasticsearch.index.query
 
IndexQueryParserService(Index, Settings, IndicesQueriesRegistry, ScriptService, AnalysisService, MapperService, IndexCache, IndexEngine, SimilarityService, Map<String, QueryParserFactory>, Map<String, FilterParserFactory>) - Constructor for class org.elasticsearch.index.query.IndexQueryParserService
 
IndexQueryParserService.Defaults - Class in org.elasticsearch.index.query
 
IndexQueryParserService.Defaults() - Constructor for class org.elasticsearch.index.query.IndexQueryParserService.Defaults
 
indexRecoveryProgress() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
indexRecoveryProgress() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
IndexReplicationOperationRequest - Class in org.elasticsearch.action.support.replication
 
IndexReplicationOperationRequest() - 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(String) - Constructor for class org.elasticsearch.action.index.IndexRequest
Constructs a new index request against the specific index.
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) - Constructor for class org.elasticsearch.action.index.IndexResponse
 
indexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
indexRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
indexRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
 
indexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
IndexRoutingTable - Class in org.elasticsearch.cluster.routing
 
indexRoutingTable(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
indexRoutingTable(String) - Static method in class org.elasticsearch.cluster.routing.RoutingBuilders
 
IndexRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
 
IndexRoutingTable.Builder(String) - Constructor for class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
indexRoutingTableChanged(String) - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
IndexSegments - Class in org.elasticsearch.action.admin.indices.segments
 
IndexService - Interface in org.elasticsearch.index.service
 
indexService - Variable in class org.elasticsearch.index.store.support.AbstractIndexStore
 
indexService(String) - Method in interface org.elasticsearch.indices.IndicesService
 
indexService(String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
IndexServiceManagement - Class in org.elasticsearch.index
 
IndexServiceManagement(Index, Settings, JmxService, IndexService) - Constructor for class org.elasticsearch.index.IndexServiceManagement
 
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 interface org.elasticsearch.indices.IndicesService
 
indexServiceSafe(String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
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 - 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
 
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 - Variable in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
IndexShard - Interface in org.elasticsearch.index.shard.service
 
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
 
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
 
IndexShardGateway.Snapshot - Class in org.elasticsearch.index.gateway
 
IndexShardGateway.Snapshot(SnapshotIndexCommit, Translog.Snapshot, long, long, long, int) - Constructor for class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
IndexShardGateway.SnapshotLock - 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, IndexSettingsService, ThreadPool, IndexShard, IndexShardGateway) - 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
 
IndexShardManagement - Class in org.elasticsearch.index.shard
 
IndexShardManagement(ShardId, Settings, JmxService, IndexShard, Store, Translog) - Constructor for class org.elasticsearch.index.shard.IndexShardManagement
 
IndexShardMissingException - Exception in org.elasticsearch.index
 
IndexShardMissingException(ShardId) - Constructor for exception org.elasticsearch.index.IndexShardMissingException
 
IndexShardModule - Class in org.elasticsearch.index.shard
 
IndexShardModule(Settings, ShardId) - 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
 
IndexShardRoutingTable - Class in org.elasticsearch.cluster.routing
 
IndexShardRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
 
IndexShardRoutingTable.Builder(IndexShardRoutingTable) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
IndexShardRoutingTable.Builder(ShardId, boolean) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
indexShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
 
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
 
IndexShardStartedException - Exception in org.elasticsearch.index.shard
 
IndexShardStartedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardStartedException
 
IndexShardState - Enum in org.elasticsearch.index.shard
 
IndexShardStats - Class in org.elasticsearch.action.admin.indices.stats
 
IndexShardStatus - Class in org.elasticsearch.action.admin.indices.status
 
indexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
indexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
indexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
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
 
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.
indexStore() - Method in class org.elasticsearch.index.store.Store
 
IndexStoreModule - Class in org.elasticsearch.index.store
 
IndexStoreModule(Settings) - Constructor for class org.elasticsearch.index.store.IndexStoreModule
 
IndexTemplateAlreadyExistsException - Exception in org.elasticsearch.indices
 
IndexTemplateAlreadyExistsException(String) - Constructor for exception org.elasticsearch.indices.IndexTemplateAlreadyExistsException
 
IndexTemplateMetaData - Class in org.elasticsearch.cluster.metadata
 
IndexTemplateMetaData(String, int, String, Settings, ImmutableMap<String, CompressedString>, ImmutableMap<String, IndexMetaData.Custom>) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
IndexTemplateMetaData.Builder - Class in org.elasticsearch.cluster.metadata
 
IndexTemplateMetaData.Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
IndexTemplateMetaData.Builder(IndexTemplateMetaData) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
IndexTemplateMissingException - Exception in org.elasticsearch.indices
 
IndexTemplateMissingException(String) - Constructor for exception org.elasticsearch.indices.IndexTemplateMissingException
 
indexTime() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
indexTimeInMillis() - Method in class org.elasticsearch.index.indexing.IndexingStats.Stats
 
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.Entry(String, String[], BytesReference) - Constructor for class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
 
IndexWarmersMetaData.Factory - Class in org.elasticsearch.search.warmer
 
IndexWarmersMetaData.Factory() - Constructor for class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
indicator(byte) - Static method in class org.elasticsearch.common.math.MathUtils
For a byte value x, this method returns (byte)(+1) if x >= 0 and (byte)(-1) if x < 0.
indicator(double) - Static method in class org.elasticsearch.common.math.MathUtils
For a double precision value x, this method returns +1.0 if x >= 0 and -1.0 if x < 0.
indicator(float) - Static method in class org.elasticsearch.common.math.MathUtils
For a float value x, this method returns +1.0F if x >= 0 and -1.0F if x < 0.
indicator(int) - Static method in class org.elasticsearch.common.math.MathUtils
For an int value x, this method returns +1 if x >= 0 and -1 if x < 0.
indicator(long) - Static method in class org.elasticsearch.common.math.MathUtils
For a long value x, this method returns +1L if x >= 0 and -1L if x < 0.
indicator(short) - Static method in class org.elasticsearch.common.math.MathUtils
For a short value x, this method returns (short)(+1) if x >= 0 and (short)(-1) if x < 0.
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.health.ClusterHealthResponse
 
indices() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should indices stats be returned.
indices(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
Should indices stats be returned.
indices() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
Indices level stats.
indices(String...) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
 
indices() - Method in class org.elasticsearch.action.admin.indices.exists.IndicesExistsRequest
 
indices(String[]) - Method in class org.elasticsearch.action.admin.indices.exists.IndicesExistsRequest
 
indices(String[]) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
Sets the indices this put mapping operation will execute on.
indices() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
The indices the mappings will be put.
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.segments.IndicesSegmentResponse
 
indices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
 
indices() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
indices(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
indices() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
indices(String...) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
 
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(String...) - Method in class org.elasticsearch.action.count.CountRequest
 
indices(String...) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The indices the delete by query will run against.
indices() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryResponse
The responses from all the different indices.
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 - 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
 
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.node.NodeAdminClient
 
indices() - Method in class org.elasticsearch.client.transport.support.InternalTransportAdminClient
 
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 interface org.elasticsearch.indices.IndicesService
 
indices() - Method in class org.elasticsearch.indices.InternalIndicesService
 
IndicesAction<Request extends ActionRequest,Response extends ActionResponse,RequestBuilder extends ActionRequestBuilder<Request,Response>> - Class in org.elasticsearch.action.admin.indices
Indices action (used with IndicesAdminClient API.
IndicesAction(String) - Constructor for class org.elasticsearch.action.admin.indices.IndicesAction
 
IndicesAdminClient - Interface in org.elasticsearch.client
Administrative actions/operations against indices.
indicesAliases(MetaDataIndexAliasesService.Request, MetaDataIndexAliasesService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService
 
IndicesAliasesAction - Class in org.elasticsearch.action.admin.indices.alias
 
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
 
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, NodeIndexCreatedAction, NodeIndexDeletedAction, NodeMappingCreatedAction, NodeMappingRefreshAction, NodeAliasesUpdatedAction) - Constructor for class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
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
 
IndicesExistsRequest - Class in org.elasticsearch.action.admin.indices.exists
 
IndicesExistsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.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
 
IndicesExistsRequestBuilder(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.IndicesExistsRequestBuilder
 
IndicesExistsResponse - Class in org.elasticsearch.action.admin.indices.exists
 
IndicesExistsResponse(boolean) - Constructor for class org.elasticsearch.action.admin.indices.exists.IndicesExistsResponse
 
indicesFailures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
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, 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 - 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 interface org.elasticsearch.indices.IndicesService
 
indicesLifecycle() - Method in class org.elasticsearch.indices.InternalIndicesService
 
IndicesLifecycle.Listener - Class in org.elasticsearch.indices
A listener for index and index shard lifecycle events (create/closed).
IndicesLifecycle.Listener() - Constructor for class org.elasticsearch.indices.IndicesLifecycle.Listener
 
indicesLocations() - Method in class org.elasticsearch.env.NodeEnvironment
 
IndicesModule - Class in org.elasticsearch.indices
 
IndicesModule(Settings) - Constructor for class org.elasticsearch.indices.IndicesModule
 
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, ClusterService) - 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
 
IndicesQueryParser - Class in org.elasticsearch.index.query
 
IndicesQueryParser(ClusterService) - Constructor for class org.elasticsearch.index.query.IndicesQueryParser
 
IndicesReplicationOperationRequest - Class in org.elasticsearch.action.support.replication
 
IndicesReplicationOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
 
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 - Interface in org.elasticsearch.indices
 
IndicesStats - Class in org.elasticsearch.action.admin.indices.stats
 
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
 
IndicesStatusAction - Class in org.elasticsearch.action.admin.indices.status
 
IndicesStatusRequest - Class in org.elasticsearch.action.admin.indices.status
 
IndicesStatusRequest() - Constructor for class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
 
IndicesStatusRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
 
indicesStatusRequest(String...) - Static method in class org.elasticsearch.client.Requests
Creates an indices status request.
IndicesStatusRequestBuilder - Class in org.elasticsearch.action.admin.indices.status
 
IndicesStatusRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
 
IndicesStatusResponse - Class in org.elasticsearch.action.admin.indices.status
 
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, ThreadPool) - Constructor for class org.elasticsearch.indices.store.IndicesStore
 
IndicesTTLService - Class in org.elasticsearch.indices.ttl
A node level service that delete expired docs on node primary shards.
IndicesTTLService(Settings, ClusterService, IndicesService, NodeSettingsService, Client) - Constructor for class org.elasticsearch.indices.ttl.IndicesTTLService
 
IndicesWarmer - Interface in org.elasticsearch.indices.warmer
 
IndicesWarmer.Listener - Interface in org.elasticsearch.indices.warmer
 
IndicesWarmer.WarmerContext - Class in org.elasticsearch.indices.warmer
 
IndicesWarmer.WarmerContext(ShardId, Engine.Searcher, Engine.Searcher) - Constructor for class org.elasticsearch.indices.warmer.IndicesWarmer.WarmerContext
 
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 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) - Method in class org.elasticsearch.node.service.NodeService
 
info() - Method in class org.elasticsearch.threadpool.ThreadPool
 
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
 
inForkJoinPool() - Static method in class jsr166y.ForkJoinTask
Returns true if the current thread is a ForkJoinWorkerThread executing as a ForkJoinPool computation.
init(String[]) - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
init() - Method in class org.elasticsearch.index.field.data.support.FieldDataLoader.FreqsTypeLoader
 
init() - Method in interface org.elasticsearch.index.field.data.support.FieldDataLoader.TypeLoader
 
initCounter() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
 
initialize(BlobStore, ClusterName, ByteSizeValue) - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
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.
initializeEmpty(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
Initializes a new empty index, as if it was created from an API.
initializeEmpty(IndexMetaData, boolean) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
Initializes a new empty index, with an option to control if its from an API or not.
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).
initializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
initializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
initializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
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
 
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 interface org.elasticsearch.index.service.IndexService
 
injector() - Method in class org.elasticsearch.index.service.InternalIndexService
 
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(Point, Point, String, FieldDataCache) - Constructor for class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
InMemoryGeoBoundingBoxFilter.GeoBoundingBoxDocSet - Class in org.elasticsearch.index.search.geo
 
InMemoryGeoBoundingBoxFilter.GeoBoundingBoxDocSet(int, GeoPointFieldData, Point, Point) - Constructor for class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.GeoBoundingBoxDocSet
 
InMemoryGeoBoundingBoxFilter.Meridian180GeoBoundingBoxDocSet - Class in org.elasticsearch.index.search.geo
 
InMemoryGeoBoundingBoxFilter.Meridian180GeoBoundingBoxDocSet(int, GeoPointFieldData, Point, Point) - Constructor for class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.Meridian180GeoBoundingBoxDocSet
 
innerGet(String, String, String[], boolean) - Method in class org.elasticsearch.index.get.ShardGetService
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
innerParseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
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
 
inputBuffer - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexInput
 
inputBuffer - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamInput
 
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
A filer for a field based on several terms matching on any of them.
inQuery(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.
inQuery(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.
inQuery(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.
inQuery(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.
inQuery(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.
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
 
insertElementAt(E, int) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.insertElementAt(E, int)
inspect() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
Inspects if the barrier is broken.
install(K) - Method in class jsr166e.LongAdderTable
If the given key does not already exist in the table, inserts the key with initial sum of zero; in either case returning the adder associated with this key.
install(Module) - Method in class org.elasticsearch.common.inject.AbstractModule
 
install(Module) - Method in interface org.elasticsearch.common.inject.Binder
Uses the given module to configure more bindings.
install(Module) - Method in class org.elasticsearch.common.inject.PrivateModule
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.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.reroute.ClusterRerouteAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
 
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.IndicesExistsAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.flush.FlushAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotAction
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingAction
 
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.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.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
 
INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
 
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.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.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.mlt.MoreLikeThisAction
 
INSTANCE - Static variable in class org.elasticsearch.action.percolate.PercolateAction
 
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.update.UpdateAction
 
INSTANCE - Static variable in class org.elasticsearch.common.compress.lzf.LZFCompressorContext
 
INSTANCE - Static variable in class org.elasticsearch.common.io.stream.VoidStreamable
 
INSTANCE - Static variable in class org.elasticsearch.common.lucene.search.MatchNoDocsQuery
 
INSTANCE - Static variable in class org.elasticsearch.common.transport.DummyTransportAddress
 
INSTANCE - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldSelector
 
INSTANCE - Static variable in class org.elasticsearch.index.mapper.selector.AllButSourceFieldSelector
 
INSTANCE - Static variable in class org.elasticsearch.index.mapper.selector.UidFieldSelector
 
INSTANCE - Static variable in class org.elasticsearch.index.search.nested.NestedDocsFilter
 
INSTANCE - Static variable in class org.elasticsearch.index.search.nested.NonNestedDocsFilter
 
INSTANCE_SAME - Static variable in class org.elasticsearch.transport.VoidTransportResponseHandler
 
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 - 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
 
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 - Static variable in class org.elasticsearch.index.field.data.FieldDataType.DefaultTypes
 
IntDocFieldData - Class in org.elasticsearch.index.field.data.ints
 
IntDocFieldData(IntFieldData) - Constructor for class org.elasticsearch.index.field.data.ints.IntDocFieldData
 
integerField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
IntegerFieldMapper - Class in org.elasticsearch.index.mapper.core
 
IntegerFieldMapper(FieldMapper.Names, int, String, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, Integer, boolean) - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
IntegerFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
IntegerFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Builder
 
IntegerFieldMapper.CustomIntegerNumericField - Class in org.elasticsearch.index.mapper.core
 
IntegerFieldMapper.CustomIntegerNumericField(NumberFieldMapper, int) - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.CustomIntegerNumericField
 
IntegerFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
IntegerFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.Defaults
 
IntegerFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
IntegerFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.IntegerFieldMapper.TypeParser
 
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).
internalAddListener(Object) - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
 
InternalBoundedCountHistogramFacet - Class in org.elasticsearch.search.facet.histogram.bounded
 
InternalBoundedCountHistogramFacet(String, HistogramFacet.ComparatorType, long, long, int, int[], boolean) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet
 
InternalBoundedCountHistogramFacet.CountEntry - Class in org.elasticsearch.search.facet.histogram.bounded
A histogram entry representing a single entry within the result of a histogram facet.
InternalBoundedCountHistogramFacet.CountEntry(long, long) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
InternalBoundedFullHistogramFacet - Class in org.elasticsearch.search.facet.histogram.bounded
 
InternalBoundedFullHistogramFacet(String, HistogramFacet.ComparatorType, long, long, int, Object[], boolean) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
InternalBoundedFullHistogramFacet.FullEntry - Class in org.elasticsearch.search.facet.histogram.bounded
A histogram entry representing a single entry within the result of a histogram facet.
InternalBoundedFullHistogramFacet.FullEntry(long, long, double, double, long, double) - Constructor for class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
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.
InternalByteTermsFacet - Class in org.elasticsearch.search.facet.terms.bytes
 
InternalByteTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalByteTermsFacet.ByteEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
InternalByteTermsFacet.ByteEntry - Class in org.elasticsearch.search.facet.terms.bytes
 
InternalByteTermsFacet.ByteEntry(byte, int) - Constructor for class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet.ByteEntry
 
InternalClient - Interface in org.elasticsearch.client.internal
 
InternalClusterAdminClient - Interface in org.elasticsearch.client.internal
 
InternalClusterService - Class in org.elasticsearch.cluster.service
 
InternalClusterService(Settings, DiscoveryService, OperationRouting, TransportService, NodeSettingsService, ThreadPool) - 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, TLongLongHashMap, boolean) - 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.
InternalCountDateHistogramFacet.CountEntry(long, long) - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
InternalCountHistogramFacet - Class in org.elasticsearch.search.facet.histogram.unbounded
 
InternalCountHistogramFacet(String, HistogramFacet.ComparatorType, TLongLongHashMap, boolean) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
InternalCountHistogramFacet.CountEntry - Class in org.elasticsearch.search.facet.histogram.unbounded
A histogram entry representing a single entry within the result of a histogram facet.
InternalCountHistogramFacet.CountEntry(long, long) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
InternalDateHistogramFacet - Class in org.elasticsearch.search.facet.datehistogram
 
InternalDateHistogramFacet() - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalDateHistogramFacet
 
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
 
InternalDoubleTermsFacet.DoubleEntry(double, int) - Constructor for class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
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
 
InternalFacet - Interface in org.elasticsearch.search.facet
 
InternalFacet.Stream - Interface in org.elasticsearch.search.facet
 
InternalFacet.Streams - Class in org.elasticsearch.search.facet
 
InternalFacet.Streams() - Constructor for class org.elasticsearch.search.facet.InternalFacet.Streams
 
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.
InternalFilterFacet - Class in org.elasticsearch.search.facet.filter
 
InternalFilterFacet(String, long) - Constructor for class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
InternalFloatTermsFacet - Class in org.elasticsearch.search.facet.terms.floats
 
InternalFloatTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalFloatTermsFacet.FloatEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
InternalFloatTermsFacet.FloatEntry - Class in org.elasticsearch.search.facet.terms.floats
 
InternalFloatTermsFacet.FloatEntry(float, int) - Constructor for class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet.FloatEntry
 
InternalFullDateHistogramFacet - Class in org.elasticsearch.search.facet.datehistogram
 
InternalFullDateHistogramFacet(String, DateHistogramFacet.ComparatorType, ExtTLongObjectHashMap<InternalFullDateHistogramFacet.FullEntry>, boolean) - 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.
InternalFullDateHistogramFacet.FullEntry(long, long, double, double, long, double) - Constructor for class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
InternalFullHistogramFacet - Class in org.elasticsearch.search.facet.histogram.unbounded
 
InternalFullHistogramFacet(String, HistogramFacet.ComparatorType, ExtTLongObjectHashMap<InternalFullHistogramFacet.FullEntry>, boolean) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
InternalFullHistogramFacet.FullEntry - Class in org.elasticsearch.search.facet.histogram.unbounded
A histogram entry representing a single entry within the result of a histogram facet.
InternalFullHistogramFacet.FullEntry(long, long, double, double, long, double) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
InternalGeoDistanceFacet - Class in org.elasticsearch.search.facet.geodistance
 
InternalGeoDistanceFacet(String, GeoDistanceFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
internalHighlightFields() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
InternalHistogramFacet - Class in org.elasticsearch.search.facet.histogram
 
InternalHistogramFacet() - Constructor for class org.elasticsearch.search.facet.histogram.InternalHistogramFacet
 
internalHits() - Method in class org.elasticsearch.search.internal.InternalSearchHits
 
InternalIndexService - Class in org.elasticsearch.index.service
 
InternalIndexService(Injector, Index, Settings, NodeEnvironment, ThreadPool, PercolatorService, AnalysisService, MapperService, IndexQueryParserService, SimilarityService, IndexAliasesService, IndexCache, IndexEngine, IndexGateway, IndexStore, IndexSettingsService) - Constructor for class org.elasticsearch.index.service.InternalIndexService
 
InternalIndexShard - Class in org.elasticsearch.index.shard.service
 
InternalIndexShard(ShardId, Settings, IndexSettingsService, IndicesLifecycle, Store, Engine, MergeSchedulerProvider, Translog, ThreadPool, MapperService, IndexQueryParserService, IndexCache, IndexAliasesService, ShardIndexingService, ShardGetService, ShardSearchService, ShardIndexWarmerService) - Constructor for class org.elasticsearch.index.shard.service.InternalIndexShard
 
InternalIndicesAdminClient - Interface in org.elasticsearch.client.internal
 
InternalIndicesLifecycle - Class in org.elasticsearch.indices
 
InternalIndicesLifecycle(Settings) - Constructor for class org.elasticsearch.indices.InternalIndicesLifecycle
 
InternalIndicesService - Class in org.elasticsearch.indices
 
InternalIndicesService(Settings, NodeEnvironment, ThreadPool, IndicesLifecycle, IndicesAnalysisService, IndicesStore, Injector) - Constructor for class org.elasticsearch.indices.InternalIndicesService
 
InternalIndicesWarmer - Class in org.elasticsearch.indices.warmer
 
InternalIndicesWarmer(Settings, ThreadPool, ClusterService, IndicesService) - Constructor for class org.elasticsearch.indices.warmer.InternalIndicesWarmer
 
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
 
InternalIntTermsFacet - Class in org.elasticsearch.search.facet.terms.ints
 
InternalIntTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalIntTermsFacet.IntEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
InternalIntTermsFacet.IntEntry - Class in org.elasticsearch.search.facet.terms.ints
 
InternalIntTermsFacet.IntEntry(int, int) - Constructor for class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet.IntEntry
 
InternalIpTermsFacet - Class in org.elasticsearch.search.facet.terms.ip
 
InternalIpTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalIpTermsFacet.LongEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
InternalIpTermsFacet.LongEntry - Class in org.elasticsearch.search.facet.terms.ip
 
InternalIpTermsFacet.LongEntry(long, int) - Constructor for class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet.LongEntry
 
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
 
InternalLongTermsFacet.LongEntry(long, int) - Constructor for class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
internalMap() - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
 
InternalMapper - Interface in org.elasticsearch.index.mapper
A marker interface for internal mappings.
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
 
InternalQueryFacet - Class in org.elasticsearch.search.facet.query
 
InternalQueryFacet(String, long) - Constructor for class org.elasticsearch.search.facet.query.InternalQueryFacet
 
InternalRangeFacet - Class in org.elasticsearch.search.facet.range
 
InternalRangeFacet(String, RangeFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.range.InternalRangeFacet
 
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(long) - Constructor for class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
InternalSearchHit - Class in org.elasticsearch.search.internal
 
InternalSearchHit(int, String, String, byte[], Map<String, SearchHitField>) - Constructor for class org.elasticsearch.search.internal.InternalSearchHit
 
InternalSearchHit.Fields - Class in org.elasticsearch.search.internal
 
InternalSearchHit.Fields() - Constructor for class org.elasticsearch.search.internal.InternalSearchHit.Fields
 
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() - Constructor for class org.elasticsearch.search.internal.InternalSearchHits.StreamContext
 
InternalSearchHits.StreamContext.ShardTargetType - Enum in org.elasticsearch.search.internal
 
internalSearchRequest(ShardRouting, int, SearchRequest, String[], long) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
InternalSearchRequest - Class in org.elasticsearch.search.internal
Source structure:

InternalSearchRequest() - Constructor for class org.elasticsearch.search.internal.InternalSearchRequest
 
InternalSearchRequest(ShardRouting, int, SearchType) - Constructor for class org.elasticsearch.search.internal.InternalSearchRequest
 
InternalSearchRequest(String, int, int, SearchType) - Constructor for class org.elasticsearch.search.internal.InternalSearchRequest
 
InternalSearchResponse - Class in org.elasticsearch.search.internal
 
InternalSearchResponse(InternalSearchHits, InternalFacets, boolean) - Constructor for class org.elasticsearch.search.internal.InternalSearchResponse
 
InternalSettingsPerparer - Class in org.elasticsearch.node.internal
 
InternalSettingsPerparer() - Constructor for class org.elasticsearch.node.internal.InternalSettingsPerparer
 
InternalShortTermsFacet - Class in org.elasticsearch.search.facet.terms.shorts
 
InternalShortTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalShortTermsFacet.ShortEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
InternalShortTermsFacet.ShortEntry - Class in org.elasticsearch.search.facet.terms.shorts
 
InternalShortTermsFacet.ShortEntry(short, int) - Constructor for class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet.ShortEntry
 
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....
InternalStatisticalFacet - Class in org.elasticsearch.search.facet.statistical
 
InternalStatisticalFacet(String, double, double, double, double, long) - Constructor for class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
InternalStringTermsFacet - Class in org.elasticsearch.search.facet.terms.strings
 
InternalStringTermsFacet(String, TermsFacet.ComparatorType, int, Collection<InternalStringTermsFacet.StringEntry>, long, long) - Constructor for class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
InternalStringTermsFacet.StringEntry - Class in org.elasticsearch.search.facet.terms.strings
 
InternalStringTermsFacet.StringEntry(String, int) - Constructor for class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.StringEntry
 
InternalTermsFacet - Class in org.elasticsearch.search.facet.terms
 
InternalTermsFacet() - 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
 
InternalTermsStatsDoubleFacet.DoubleEntry(double, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
InternalTermsStatsFacet - Class in org.elasticsearch.search.facet.termsstats
 
InternalTermsStatsFacet() - 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
 
InternalTermsStatsLongFacet.LongEntry(long, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
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
 
InternalTermsStatsStringFacet.StringEntry(String, long, long, double, double, double) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
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, TransportClientNodesService, 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>) - 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>) - 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>) - Constructor for class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
internalValues() - Method in class org.elasticsearch.common.trove.ExtTDoubleObjectHashMap
Internal method to get the actual values associated.
internalValues() - Method in class org.elasticsearch.common.trove.ExtTHashMap
Internal method to get the actual values associated.
internalValues() - Method in class org.elasticsearch.common.trove.ExtTLongObjectHashMap
Internal method to get the actual values associated.
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
 
interruptTask() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
Subclasses can override this method to implement interruption of the future's computation.
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(TimeValue) - Method in class org.elasticsearch.monitor.jvm.HotThreads
 
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
 
IntFieldData - Class in org.elasticsearch.index.field.data.ints
 
IntFieldData(String, int[]) - Constructor for class org.elasticsearch.index.field.data.ints.IntFieldData
 
IntFieldData.ValueInDocProc - Interface in org.elasticsearch.index.field.data.ints
 
IntFieldData.ValueProc - Interface in org.elasticsearch.index.field.data.ints
 
IntFieldDataComparator - Class in org.elasticsearch.index.field.data.ints
 
IntFieldDataComparator(int, String, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.ints.IntFieldDataComparator
 
IntFieldDataMissingComparator - Class in org.elasticsearch.index.field.data.ints
 
IntFieldDataMissingComparator(int, String, FieldDataCache, int) - Constructor for class org.elasticsearch.index.field.data.ints.IntFieldDataMissingComparator
 
IntFieldDataType - Class in org.elasticsearch.index.field.data.ints
 
IntFieldDataType() - Constructor for class org.elasticsearch.index.field.data.ints.IntFieldDataType
 
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 DoubleAdder.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.extra.AtomicDouble
Returns the value of this AtomicDouble 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() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
intValue(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
intValue(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
intValue(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
intValue(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
intValue(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
intValue(int) - Method in class org.elasticsearch.index.field.data.NumericFieldData
Returns the value of the specified number as an int.
intValue(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
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
 
invalidateCache() - Method in class org.elasticsearch.index.cache.IndexCache
 
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
 
InvalidTypeNameException - Exception in org.elasticsearch.indices
 
InvalidTypeNameException(String) - Constructor for exception org.elasticsearch.indices.InvalidTypeNameException
 
invoke(ForkJoinTask<T>) - Method in class jsr166y.ForkJoinPool
Performs the given task, returning its result upon completion.
invoke() - Method in class jsr166y.ForkJoinTask
Commences performing this task, awaits its completion if necessary, and returns its result, or throws an (unchecked) RuntimeException or Error if the underlying computation did so.
invoke(String, Object[], String[]) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
invokeAll(Collection<? extends Callable<T>>) - Method in class jsr166y.ForkJoinPool
 
invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class jsr166y.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(ForkJoinTask<?>...) - Static method in class jsr166y.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(Collection<T>) - Static method in class jsr166y.ForkJoinTask
Forks all tasks in the specified collection, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
ipField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
IpFieldMapper - Class in org.elasticsearch.index.mapper.ip
 
IpFieldMapper(FieldMapper.Names, int, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, String, boolean) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
IpFieldMapper.Builder - Class in org.elasticsearch.index.mapper.ip
 
IpFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.Builder
 
IpFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.ip
 
IpFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.Defaults
 
IpFieldMapper.NumericIpAnalyzer - Class in org.elasticsearch.index.mapper.ip
 
IpFieldMapper.NumericIpAnalyzer() - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.NumericIpAnalyzer
 
IpFieldMapper.NumericIpAnalyzer(int) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.NumericIpAnalyzer
 
IpFieldMapper.NumericIpTokenizer - Class in org.elasticsearch.index.mapper.ip
 
IpFieldMapper.NumericIpTokenizer(Reader, int) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.NumericIpTokenizer
 
IpFieldMapper.NumericIpTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.NumericIpTokenizer
 
IpFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.ip
 
IpFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.ip.IpFieldMapper.TypeParser
 
ipToLong(String) - Static method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
IPv4_SETTING - Static variable in class org.elasticsearch.common.network.NetworkUtils
 
IPv6_SETTING - Static variable in class org.elasticsearch.common.network.NetworkUtils
 
isAllNodes(String...) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
isArray(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
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.elasticsearch.common.lucene.docset.AllDocSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.AndDocIdSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.AndDocSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.FixedBitDocSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.NotDocSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet
 
isCacheable() - Method in class org.elasticsearch.common.lucene.docset.OrDocSet
 
isCacheable() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter.GeoDistanceDocSet
 
isCacheable() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter.GeoDistanceRangeDocSet
 
isCacheable() - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter.GeoPolygonDocSet
 
isCacheable() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.GeoBoundingBoxDocSet
 
isCacheable() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter.Meridian180GeoBoundingBoxDocSet
 
isCached(Filter) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
isCached(Filter) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
isCached(Filter) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
isCancelled() - Method in class jsr166y.ForkJoinTask
 
isCancelled() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
 
isChecksum(String) - Static method in class org.elasticsearch.index.store.Store
 
isClientNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
isCloseConnectionException(Throwable) - Static method in class org.elasticsearch.common.transport.NetworkExceptionHelper
 
isClosed() - Method in class org.elasticsearch.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
 
isCompletedAbnormally() - Method in class jsr166y.ForkJoinTask
Returns true if this task threw an exception or was cancelled.
isCompletedNormally() - Method in class jsr166y.ForkJoinTask
Returns true if this task completed without throwing an exception and was not cancelled.
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
 
isCompressed(byte[], int, int) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
isCompressed(BytesReference) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
isCompressed(ChannelBuffer) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
isCompressed(IndexInput) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
isConcrete(Class<?>) - Static method in class org.elasticsearch.common.Classes
 
isConcrete(Class<?>) - Static method in class org.elasticsearch.common.inject.internal.Classes
 
isConnectException(Throwable) - Static method in class org.elasticsearch.common.transport.NetworkExceptionHelper
 
isConstant() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
Is this a constant binding? This returns true for constant bindings as well as toInstance() bindings.
isConstructing() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
 
isDangling(String) - Method in class org.elasticsearch.gateway.local.state.meta.LocalGatewayMetaState
 
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 jsr166y.ForkJoinTask
 
isDone() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
 
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 jsr166e.ConcurrentHashMapV8
isEmpty() - Method in class jsr166e.extra.ReadMostlyVector
 
isEmpty() - Method in class jsr166y.ConcurrentLinkedDeque
Returns true if this collection contains no elements.
isEmpty() - Method in class jsr166y.LinkedTransferQueue
Returns true if this queue contains no elements.
isEmpty() - Method in class org.elasticsearch.common.collect.IdentityHashSet
Returns true if this set contains no elements.
isEmpty() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
isEmpty() - Method in class org.elasticsearch.index.field.data.DocFieldData
 
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.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
 
isEnableLatLon() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
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
 
isExists() - Method in class org.elasticsearch.action.admin.indices.exists.IndicesExistsResponse
 
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.index.get.GetResult
Does the document exists.
isExplicitlyScoped() - Method in class org.elasticsearch.common.inject.internal.Scoping
Returns true if this scope was explicitly applied.
isFailed() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
Is this a failed execution of an operation.
isFailed() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
Is this a failed execution?
isFailure() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
Is it a failed search?
isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
 
isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
 
isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
 
isGlobalStateEquals(MetaData, MetaData) - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
isHeldByCurrentThread() - Method in class jsr166e.SequenceLock
Queries if this lock is held by the current thread.
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
 
isIncludeUpper() - Method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
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
 
isInnerClass(Class<?>) - Static method in class org.elasticsearch.common.inject.internal.Classes
 
isIPv4() - Static method in class org.elasticsearch.common.network.NetworkUtils
 
isLastGcEnabled() - Static method in class org.elasticsearch.monitor.jvm.JvmStats
 
isLeaf() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
isLocked() - Method in class jsr166e.SequenceLock
Queries if this lock is held by any thread.
isManagedResource() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
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
 
isMatchAllQuery(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
 
isMergeEnabled() - Method in interface org.elasticsearch.index.merge.policy.EnableMergePolicy
 
isMergeEnabled() - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy
 
isMergeEnabled() - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy
 
isMergeEnabled() - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider
 
isMultiValued() - Method in class org.elasticsearch.index.field.data.DocFieldData
 
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
 
isNotFound() - Method in class org.elasticsearch.action.delete.DeleteResponse
Returns true if there was no doc found to delete.
isNullable() - Method in class org.elasticsearch.common.inject.spi.Dependency
Returns true if null is a legal value for this dependency.
isObject(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
 
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.
isPresent(byte[], int, int) - Method in interface org.elasticsearch.common.bloom.BloomFilter
 
isPresent(byte[], int, int) - Method in class org.elasticsearch.common.bloom.ObsBloomFilter
 
isPrimary() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
isPrimaryActive() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
isQuiescent() - Method in class jsr166y.ForkJoinPool
Returns true if all worker threads are currently idle.
isReleasable() - Method in interface jsr166y.ForkJoinPool.ManagedBlocker
Returns true if blocking is unnecessary.
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.store.StoreFileMetaData
 
isScopeAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Annotations
 
isSearch() - Method in class org.elasticsearch.index.engine.Segment
 
isShutdown() - Method in class jsr166y.ForkJoinPool
Returns true if this pool has been shut down.
isSimpleMatchPattern(String) - Static method in class org.elasticsearch.common.regex.Regex
Is the str a simple match pattern.
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
 
isSynthetic() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
 
isTerminated() - Method in class jsr166y.ForkJoinPool
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class jsr166y.Phaser
Returns true if this phaser has been terminated.
isTerminating() - Method in class jsr166y.ForkJoinPool
Returns true if the process of termination has commenced but not yet completed.
isTimedOut() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
isTimedOut() - Method in class org.elasticsearch.action.search.SearchResponse
Has the search operation timed out.
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
 
isValue() - Method in enum org.elasticsearch.common.xcontent.XContentParser.Token
 
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.index.search.geo.GeoDistance.DistanceBoundingCheck
 
isWithin(double, double) - Method in class org.elasticsearch.index.search.geo.GeoDistance.Meridian180DistanceBoundingCheck
 
isWithin(double, double) - Method in class org.elasticsearch.index.search.geo.GeoDistance.SimpleDistanceBoundingCheck
 
ItalianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ItalianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ItalianAnalyzerProvider
 
itemId() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The numeric order of the item matching the same request order in the bulk request.
items() - Method in class org.elasticsearch.action.bulk.BulkResponse
The items representing each action performed in the bulk operation (in the same order!).
iterate(PortsRange.PortCallback) - Method in class org.elasticsearch.common.transport.PortsRange
 
iterator() - Method in class jsr166e.extra.ReadMostlyVector
 
iterator() - Method in class jsr166y.ConcurrentLinkedDeque
Returns an iterator over the elements in this deque in proper sequence.
iterator() - Method in class jsr166y.LinkedTransferQueue
Returns an iterator over the elements in this queue in proper sequence.
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.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
 
iterator() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
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.MultiGetResponse
 
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.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.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.MapBackedSet
 
iterator() - Method in class org.elasticsearch.common.inject.ModulesBuilder
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.AllDocSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.AndDocIdSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.AndDocSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.FixedBitDocSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.GetDocSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet
 
iterator() - Method in class org.elasticsearch.common.lucene.docset.OrDocSet
 
iterator() - Method in class org.elasticsearch.index.aliases.IndexAliasesService
 
iterator() - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdCache
 
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.mapper.DocumentFieldMappers
 
iterator() - Method in class org.elasticsearch.index.mapper.FieldMappers
 
iterator() - Method in class org.elasticsearch.index.mapper.MapperService
 
iterator() - Method in class org.elasticsearch.index.mapper.ObjectMappers
 
iterator() - Method in class org.elasticsearch.index.service.InternalIndexService
 
iterator() - Method in class org.elasticsearch.indices.InternalIndicesService
 
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.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.bounded.InternalBoundedCountHistogramFacet
 
iterator() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
iterator() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
iterator() - Method in class org.elasticsearch.search.facet.histogram.unbounded.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.bytes.InternalByteTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
iterator() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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.threadpool.ThreadPoolInfo
 
iterator() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
 
iterators() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
itoa(int) - Static method in class org.elasticsearch.common.Bytes
Blatant copy of Integer.toString, but returning a byte array instead of a String, as string charset decoding/encoding was killing us on performance.

J

JdkESLogger - Class in org.elasticsearch.common.logging.jdk
 
JdkESLogger(String, 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
 
JmxClusterService - Class in org.elasticsearch.jmx
 
JmxClusterService(Settings, ClusterService, JmxService, GetJmxServiceUrlAction) - Constructor for class org.elasticsearch.jmx.JmxClusterService
 
JmxConnectorCreationException - Exception in org.elasticsearch.jmx
 
JmxConnectorCreationException(String) - Constructor for exception org.elasticsearch.jmx.JmxConnectorCreationException
 
JmxConnectorCreationException(String, Throwable) - Constructor for exception org.elasticsearch.jmx.JmxConnectorCreationException
 
JmxException - Exception in org.elasticsearch.jmx
 
JmxException(String) - Constructor for exception org.elasticsearch.jmx.JmxException
 
JmxException(String, Throwable) - Constructor for exception org.elasticsearch.jmx.JmxException
 
JmxFsProbe - Class in org.elasticsearch.monitor.fs
 
JmxFsProbe(Settings, NodeEnvironment) - Constructor for class org.elasticsearch.monitor.fs.JmxFsProbe
 
JmxModule - Class in org.elasticsearch.jmx
 
JmxModule(Settings) - Constructor for class org.elasticsearch.jmx.JmxModule
 
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
 
JmxRegistrationException - Exception in org.elasticsearch.jmx
 
JmxRegistrationException(String) - Constructor for exception org.elasticsearch.jmx.JmxRegistrationException
 
JmxRegistrationException(String, Throwable) - Constructor for exception org.elasticsearch.jmx.JmxRegistrationException
 
JMXRMI_PUBLISH_URI_PATTERN - Static variable in class org.elasticsearch.jmx.JmxService
 
JMXRMI_URI_PATTERN - Static variable in class org.elasticsearch.jmx.JmxService
 
JmxService - Class in org.elasticsearch.jmx
 
JmxService(ESLogger, Settings) - Constructor for class org.elasticsearch.jmx.JmxService
 
JmxService.SettingsConstants - Class in org.elasticsearch.jmx
 
JmxService.SettingsConstants() - Constructor for class org.elasticsearch.jmx.JmxService.SettingsConstants
 
Joda - Class in org.elasticsearch.common.joda
 
Joda() - Constructor for class org.elasticsearch.common.joda.Joda
 
join() - Method in class jsr166y.ForkJoinTask
Returns the result of the computation when it is done.
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.JoinException - Exception in org.elasticsearch.common.inject.internal
Exception thrown in response to an IOException from the supplied Appendable.
JRE_IS_64BIT - Static variable in class org.elasticsearch.monitor.jvm.JvmUtils
True iff running on a 64bit JVM
JRE_IS_MINIMUM_JAVA6 - Static variable in class org.elasticsearch.monitor.jvm.JvmUtils
 
JRE_IS_MINIMUM_JAVA7 - Static variable in class org.elasticsearch.monitor.jvm.JvmUtils
 
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.
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
 
jsr166e.extra - package jsr166e.extra
 
jsr166y - package jsr166y
Preview versions of classes targeted for Java 7.
JTS_AVAILABLE - Static variable in class org.elasticsearch.common.geo.ShapesAvailability
 
jvm() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
JVM level information.
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.
jvm() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
JVM level statistics.
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, DumpMonitorService) - 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.BufferPool(String, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
 
JvmStats.GarbageCollector - Class in org.elasticsearch.monitor.jvm
 
JvmStats.GarbageCollector.LastGc - Class in org.elasticsearch.monitor.jvm
 
JvmStats.GarbageCollector.LastGc(long, long, long, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
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.MemoryPool(String, long, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
 
JvmStats.Threads - Class in org.elasticsearch.monitor.jvm
 
JvmUtils - Class in org.elasticsearch.monitor.jvm
 
JvmUtils() - Constructor for class org.elasticsearch.monitor.jvm.JvmUtils
 

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.search.internal.SearchContext
 
keepAlive(long) - Method in class org.elasticsearch.search.internal.SearchContext
 
keepAlive() - Method in class org.elasticsearch.search.Scroll
How long the resources will be kept open to support the scroll request.
keepAlive() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
 
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.
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(T) - Method in class org.elasticsearch.common.trove.ExtTObjectIntHasMap
Returns an already existing key, or null if it does not exists.
key() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
key() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
key() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The key value of the histogram.
key() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
key() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
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 jsr166e.ConcurrentHashMapV8
Returns an enumeration of the keys in this table.
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 jsr166e.ConcurrentHashMapV8
Returns a Set view of the keys contained in this map.
keySet() - Method in class jsr166e.LongAdderTable
Returns the current set of keys.
keySet() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
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
 
keyTypeIsSet() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
KeyValueRangeFacetCollector - Class in org.elasticsearch.search.facet.range
 
KeyValueRangeFacetCollector(String, String, String, RangeFacet.Entry[], SearchContext) - Constructor for class org.elasticsearch.search.facet.range.KeyValueRangeFacetCollector
 
KeyValueRangeFacetCollector.RangeProc - Class in org.elasticsearch.search.facet.range
 
KeyValueRangeFacetCollector.RangeProc(RangeFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.range.KeyValueRangeFacetCollector.RangeProc
 
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
 
keywordTokenStream(Collection<T>) - Method in class org.apache.lucene.index.memory.CustomMemoryIndex
Convenience method; Creates and returns a token stream that generates a token for each keyword in the given collection, "as is", without any transforming text analysis.
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

lang(String) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
Sets the language of the script.
lang(String) - Method in class org.elasticsearch.index.query.CustomScoreQueryBuilder
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 - Variable in class org.elasticsearch.script.ScriptService.CacheKey
 
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
The language of the GeoDistanceFacetBuilder.valueScript(String) script.
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.
largeBufferSizeInBytes - Variable in class org.apache.lucene.store.bytebuffer.PlainByteBufferAllocator
 
lastAccessTime() - Method in class org.elasticsearch.search.internal.SearchContext
 
lastElement() - Method in class jsr166e.extra.ReadMostlyVector
See Vector.lastElement()
lastGc() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
lastIndexOf(Object) - Method in class jsr166e.extra.ReadMostlyVector
 
lastIndexOf(Object, int) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.lastIndexOf(Object, int)
lastIndexVersion() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
lastModified() - Method in class org.elasticsearch.index.store.StoreFileMetaData
 
lastSnapshotStatus() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
lastSnapshotStatus() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
The last snapshot status performed.
lastSnapshotStatus() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
lastSnapshotStatus() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
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.
lastTotalTranslogOperations() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
lastTranslogId() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
lastTranslogLength() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
lat() - Method in class org.elasticsearch.index.mapper.geo.GeoPoint
 
lat - Variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
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 - Variable in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
lat() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
lat() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
lat - Variable in class org.elasticsearch.index.search.geo.Point
 
lat(double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The latitude to create the range distance facets from.
lat - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
LAT_SUFFIX - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
latMapper() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
latValue(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
latValue(int) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
latValue(int) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
latValues(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
latValues(int) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
latValues(int) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
LatvianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
LatvianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LatvianAnalyzerProvider
 
lazySet(double) - Method in class jsr166e.extra.AtomicDouble
Eventually sets to the given value.
lazySet(int, double) - Method in class jsr166e.extra.AtomicDoubleArray
Eventually sets the element at position i to the given value.
lcm(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the least common multiple of the absolute value of two numbers, using the formula lcm(a,b) = (a / gcd(a,b)) * b.
lcm(long, long) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the least common multiple of the absolute value of two numbers, using the formula lcm(a,b) = (a / gcd(a,b)) * b.
LEAF_BYTE - Static variable in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
length() - Method in class jsr166e.extra.AtomicDoubleArray
Returns the length of the array.
length() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
length() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexOutput
 
length() - Method in class org.apache.lucene.store.OpenBufferedIndexOutput
The number of bytes in the 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.ByteBufferBytesReference
 
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.compress.CompressedIndexInput
 
length() - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
length() - Method in class org.elasticsearch.common.io.FastStringReader
 
length() - Method in class org.elasticsearch.common.lucene.docset.AllDocSet
 
length() - Method in class org.elasticsearch.common.lucene.docset.AndDocSet
 
length() - Method in class org.elasticsearch.common.lucene.docset.FixedBitDocSet
 
length() - Method in class org.elasticsearch.common.lucene.docset.GetDocSet
 
length() - Method in class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
length() - Method in class org.elasticsearch.common.lucene.docset.OrDocSet
 
length() - Method in class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
length() - Method in class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
length() - Method in class org.elasticsearch.common.lucene.store.NullIndexOutput
 
length - Variable in class org.elasticsearch.common.Unicode.UTF16Result
 
length() - Method in class org.elasticsearch.index.gateway.CommitPoint.FileInfo
 
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.
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.QueryParserSettings
 
lenient() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
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 - Variable in class org.elasticsearch.index.search.MatchQuery
 
LESSER_ICOST - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This constant is accessible by subclasses for historical purposes.
lessThan(ShardFieldDoc, ShardFieldDoc) - Method in class org.apache.lucene.search.ShardFieldDocSortedHitQueue
Returns whether a is less relevant than b.
lessThan(ShardScoreDoc, ShardScoreDoc) - Method in class org.elasticsearch.search.controller.ScoreDocQueue
 
lessThan(TermsByteOrdinalsFacetCollector.ReaderAggregator, TermsByteOrdinalsFacetCollector.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteOrdinalsFacetCollector.AggregatorPriorityQueue
 
lessThan(TermsDoubleOrdinalsFacetCollector.ReaderAggregator, TermsDoubleOrdinalsFacetCollector.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector.AggregatorPriorityQueue
 
lessThan(TermsFloatOrdinalsFacetCollector.ReaderAggregator, TermsFloatOrdinalsFacetCollector.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector.AggregatorPriorityQueue
 
lessThan(TermsIntOrdinalsFacetCollector.ReaderAggregator, TermsIntOrdinalsFacetCollector.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector.AggregatorPriorityQueue
 
lessThan(TermsIpOrdinalsFacetCollector.ReaderAggregator, TermsIpOrdinalsFacetCollector.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector.AggregatorPriorityQueue
 
lessThan(TermsLongOrdinalsFacetCollector.ReaderAggregator, TermsLongOrdinalsFacetCollector.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector.AggregatorPriorityQueue
 
lessThan(TermsShortOrdinalsFacetCollector.ReaderAggregator, TermsShortOrdinalsFacetCollector.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector.AggregatorPriorityQueue
 
lessThan(TermsStringOrdinalsFacetCollector.ReaderAggregator, TermsStringOrdinalsFacetCollector.ReaderAggregator) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector.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
 
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 - Interface in org.elasticsearch.common.component
 
lifecycleState() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
lifecycleState() - Method in interface org.elasticsearch.common.component.LifecycleComponent
 
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
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 - Static variable in class org.elasticsearch.search.facet.terms.support.EntryPriorityQueue
 
LIMIT_PORTS_COUNT - Static variable in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
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.LimitDocSet - Class in org.elasticsearch.common.lucene.search
 
LimitFilter.LimitDocSet(int, int) - Constructor for class org.elasticsearch.common.lucene.search.LimitFilter.LimitDocSet
 
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
 
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
 
LinkedTransferQueue<E> - Class in jsr166y
An unbounded TransferQueue based on linked nodes.
LinkedTransferQueue() - Constructor for class jsr166y.LinkedTransferQueue
Creates an initially empty LinkedTransferQueue.
LinkedTransferQueue(Collection<? extends E>) - Constructor for class jsr166y.LinkedTransferQueue
Creates a LinkedTransferQueue initially containing the elements of the given collection, added in traversal order of the collection's iterator.
LINUX - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on Linux.
list(Set<String>, TimeValue) - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
list(ShardId, Set<String>, TimeValue) - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
list() - Method in class org.elasticsearch.index.store.Store
 
list(ShardId, boolean, Set<String>, TimeValue) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
listAll() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
listAll() - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
listAll() - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
listBlobs() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
listBlobs() - Method in class org.elasticsearch.common.blobstore.fs.AbstractFsBlobContainer
 
listBlobsByPrefix(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
listBlobsByPrefix(String) - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
 
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.search.type.TransportSearchTypeAction.BaseAsyncAction
 
listener() - Method in class org.elasticsearch.index.mapper.ParseContext
 
listenerThreaded() - Method in interface org.elasticsearch.action.ActionRequest
Should the response listener be executed on a thread or not.
listenerThreaded(boolean) - Method in interface org.elasticsearch.action.ActionRequest
Sets if the response listener be executed on a thread or not.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.bulk.BulkRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.bulk.BulkRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.count.CountRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.delete.DeleteRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.get.GetRequest
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.get.MultiGetRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.index.IndexRequest
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.search.MultiSearchRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.search.MultiSearchRequest
 
listenerThreaded() - Method in class org.elasticsearch.action.search.SearchRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.search.SearchRequest
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.search.SearchScrollRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.search.SearchScrollRequest
Should the listener be called on a separate thread if needed.
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
 
listenerThreaded() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
listenerThreaded() - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
listenerThreaded() - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
listenerThreaded() - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.replication.IndicesReplicationOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded() - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
listenerThreaded() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
 
listenerThreaded() - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequest
 
listIterator() - Method in class jsr166e.extra.ReadMostlyVector
 
listIterator(int) - Method in class jsr166e.extra.ReadMostlyVector
 
listOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
Returns a type modelling a List whose elements are of type elementType.
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(IndexReader, String) - Static method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
load(IndexReader, String) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataType
 
load(IndexReader, String) - Static method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
load(IndexReader, String) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataType
 
load(FieldDataType, IndexReader, String) - Static method in class org.elasticsearch.index.field.data.FieldData
 
load(IndexReader, String) - Method in interface org.elasticsearch.index.field.data.FieldDataType
 
load(IndexReader, String) - Static method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
load(IndexReader, String) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataType
 
load(IndexReader, String) - Static method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
load(IndexReader, String) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataType
 
load(IndexReader, String) - Static method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
load(IndexReader, String) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataType
 
load(IndexReader, String) - Static method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
load(IndexReader, String) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataType
 
load(IndexReader, String) - Static method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
load(IndexReader, String) - Method in class org.elasticsearch.index.field.data.strings.StringFieldDataType
 
load(IndexReader, String, FieldDataLoader.TypeLoader<T>) - Static method in class org.elasticsearch.index.field.data.support.FieldDataLoader
 
load(IndexReader, String) - Static method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
load(IndexReader, String) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldDataType
 
loadAverage() - Method in class org.elasticsearch.monitor.os.OsStats
 
loadClass(String) - Method in class org.elasticsearch.common.io.ThrowableObjectInputStream
 
loadConfigSettings(boolean) - Method in class org.elasticsearch.node.NodeBuilder
Should the node builder automatically try and load config settings from the file system / classpath.
loadDocIdAndVersion(IndexReader, int, Term) - Static method in class org.elasticsearch.common.lucene.uid.UidField
 
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.
loadFromClasspath(String) - Method in class org.elasticsearch.common.settings.ImmutableSettings.Builder
Loads settings from classpath that represents them using the SettingsLoaderFactory.loaderFromSource(String).
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).
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.UidField
Load the version for the uid from the reader, returning -1 if no doc exists, or -2 if no version is available (for backward comp.)
loadWordList(Reader, String) - Static method in class org.elasticsearch.index.analysis.Analysis
 
local(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
local() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
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.
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) - Constructor for class org.elasticsearch.discovery.local.LocalDiscovery
 
LocalDiscoveryModule - Class in org.elasticsearch.discovery.local
 
LocalDiscoveryModule() - Constructor for class org.elasticsearch.discovery.local.LocalDiscoveryModule
 
localExecute(ClusterStateRequest) - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
localExecute(Request) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
LocalGateway - Class in org.elasticsearch.gateway.local
 
LocalGateway(Settings, ClusterService, NodeEnvironment, LocalGatewayShardsState, LocalGatewayMetaState, TransportNodesListGatewayMetaState) - 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) - 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, LocalGatewayMetaState) - Constructor for class org.elasticsearch.gateway.local.state.shards.LocalGatewayShardsState
 
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, IndexShard) - Constructor for class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
localNode() - Method in interface org.elasticsearch.cluster.ClusterService
The local node.
localNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
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
 
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(ThreadPool) - Constructor for class org.elasticsearch.transport.local.LocalTransport
 
LocalTransport(Settings, ThreadPool) - 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, LocalTransport, String, long) - Constructor for class org.elasticsearch.transport.local.LocalTransportChannel
 
LocalTransportManagement - Class in org.elasticsearch.transport.local
 
LocalTransportManagement(Transport) - Constructor for class org.elasticsearch.transport.local.LocalTransportManagement
 
LocalTransportModule - Class in org.elasticsearch.transport.local
 
LocalTransportModule(Settings) - Constructor for class org.elasticsearch.transport.local.LocalTransportModule
 
location() - Method in class org.elasticsearch.monitor.dump.DumpGenerator.Result
 
locations() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
lock() - Method in class jsr166e.SequenceLock
Acquires the lock.
lock() - Method in class org.elasticsearch.cluster.metadata.MetaDataService.MdLock
 
lockInterruptibly() - Method in class jsr166e.SequenceLock
Acquires the lock unless the current thread is interrupted.
log(double, double) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the logarithm for base b of x.
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
 
LogByteSizeMergePolicyProvider.CustomLogByteSizeMergePolicy - Class in org.elasticsearch.index.merge.policy
 
LogByteSizeMergePolicyProvider.CustomLogByteSizeMergePolicy(LogByteSizeMergePolicyProvider) - Constructor for class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.CustomLogByteSizeMergePolicy
 
LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy - Class in org.elasticsearch.index.merge.policy
 
LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy(LogByteSizeMergePolicyProvider) - Constructor for class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider.EnableMergeLogByteSizeMergePolicy
 
LogConfigurator - Class in org.elasticsearch.common.logging.log4j
 
LogConfigurator() - Constructor for class org.elasticsearch.common.logging.log4j.LogConfigurator
 
LogDocMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
LogDocMergePolicyProvider(Store, IndexSettingsService) - Constructor for class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
LogDocMergePolicyProvider.CustomLogDocMergePolicy - Class in org.elasticsearch.index.merge.policy
 
LogDocMergePolicyProvider.CustomLogDocMergePolicy(LogDocMergePolicyProvider) - Constructor for class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.CustomLogDocMergePolicy
 
LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy - Class in org.elasticsearch.index.merge.policy
 
LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy(LogDocMergePolicyProvider) - Constructor for class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider.EnableMergeLogDocMergePolicy
 
logger - Variable in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
logger - Variable in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
logger - Variable in class org.elasticsearch.common.component.AbstractComponent
 
logger - Variable in class org.elasticsearch.index.AbstractIndexComponent
 
logger - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
logger() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
 
logger - Variable in class org.elasticsearch.river.AbstractRiverComponent
 
LoggerInfoStream - Class in org.elasticsearch.common.lucene
A PrintStream that logs each LoggerInfoStream.println(String) into a logger under trace level.
LoggerInfoStream(ESLogger) - Constructor for class org.elasticsearch.common.lucene.LoggerInfoStream
Constucts a new instance based on the provided logger.
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.index.mapper.geo.GeoPoint
 
lon - Variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
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 - Variable in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
lon() - Method in class org.elasticsearch.index.search.geo.GeoDistanceFilter
 
lon() - Method in class org.elasticsearch.index.search.geo.GeoDistanceRangeFilter
 
lon - Variable in class org.elasticsearch.index.search.geo.Point
 
lon(double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The longitude to create the range distance facets from.
lon - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
LON_SUFFIX - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Names
 
LONG - Static variable in class org.elasticsearch.index.field.data.FieldDataType.DefaultTypes
 
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.
LongAdderTable<K> - Class in jsr166e
A keyed table of adders, that may be useful in computing frequency counts and histograms, or may be used as a form of multiset.
LongAdderTable() - Constructor for class jsr166e.LongAdderTable
Creates a new empty table.
LongDocFieldData - Class in org.elasticsearch.index.field.data.longs
 
LongDocFieldData(LongFieldData) - Constructor for class org.elasticsearch.index.field.data.longs.LongDocFieldData
 
longField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
LongFieldData - Class in org.elasticsearch.index.field.data.longs
 
LongFieldData(String, long[]) - Constructor for class org.elasticsearch.index.field.data.longs.LongFieldData
 
LongFieldData.DateValueInDocProc - Interface in org.elasticsearch.index.field.data.longs
 
LongFieldData.ValueInDocProc - Interface in org.elasticsearch.index.field.data.longs
 
LongFieldData.ValueProc - Interface in org.elasticsearch.index.field.data.longs
 
LongFieldDataComparator - Class in org.elasticsearch.index.field.data.longs
 
LongFieldDataComparator(int, String, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.longs.LongFieldDataComparator
 
LongFieldDataMissingComparator - Class in org.elasticsearch.index.field.data.longs
 
LongFieldDataMissingComparator(int, String, FieldDataCache, long) - Constructor for class org.elasticsearch.index.field.data.longs.LongFieldDataMissingComparator
 
LongFieldDataType - Class in org.elasticsearch.index.field.data.longs
 
LongFieldDataType() - Constructor for class org.elasticsearch.index.field.data.longs.LongFieldDataType
 
LongFieldMapper - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper(FieldMapper.Names, int, String, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, Long, boolean) - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper
 
LongFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.Builder
 
LongFieldMapper.CustomLongNumericField - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper.CustomLongNumericField(NumberFieldMapper, long) - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.CustomLongNumericField
 
LongFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.Defaults
 
LongFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
LongFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.LongFieldMapper.TypeParser
 
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.
LongsLAB - Class in org.elasticsearch.common.lab
 
LongsLAB(int, int) - Constructor for class org.elasticsearch.common.lab.LongsLAB
 
LongsLAB.Allocation - Class in org.elasticsearch.common.lab
The result of a single allocation.
LongStreamable - Class in org.elasticsearch.common.io.stream
 
LongStreamable() - Constructor for class org.elasticsearch.common.io.stream.LongStreamable
 
LongStreamable(long) - Constructor for class org.elasticsearch.common.io.stream.LongStreamable
 
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 DoubleAdder.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.extra.AtomicDouble
Returns the value of this AtomicDouble 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() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
longValue(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
longValue(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
longValue(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
longValue(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
longValue(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
longValue(int) - Method in class org.elasticsearch.index.field.data.NumericFieldData
Returns the value of the specified number as a long.
longValue(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
lonMapper() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
lonValue(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
lonValue(int) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
lonValue(int) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
lonValues(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
lonValues(int) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
lonValues(int) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
lookup() - Method in class org.elasticsearch.index.query.QueryParseContext
 
lookup() - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
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
 
LOWER - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
lowercaseExpandedTerms() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
lowercaseExpandedTerms(boolean) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
lowercaseExpandedTerms(boolean) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
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.QueryStringQueryBuilder
Whether terms of wildcard, prefix, fuzzy and range queries are to be automatically lower-cased or not.
LowerCaseTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
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
 
lt(Object) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
lt(Object) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
lt(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
lt(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
lt(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
lt(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
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
The to part of the filter query.
lte(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
lte(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
lte(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
lte(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
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.
ltoa(long) - Static method in class org.elasticsearch.common.Bytes
 
Lucene - Class in org.elasticsearch.common.lucene
 
Lucene.ExistsCollector - Class in org.elasticsearch.common.lucene
 
Lucene.ExistsCollector() - Constructor for class org.elasticsearch.common.lucene.Lucene.ExistsCollector
 
LZFCompressedIndexInput - Class in org.elasticsearch.common.compress.lzf
 
LZFCompressedIndexInput(IndexInput, ChunkDecoder) - Constructor for class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
 
LZFCompressedIndexOutput - Class in org.elasticsearch.common.compress.lzf
 
LZFCompressedIndexOutput(IndexOutput) - Constructor for class org.elasticsearch.common.compress.lzf.LZFCompressedIndexOutput
 
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
 
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.common.bloom.BloomFilterFactory
 
main(String[]) - Static method in class org.elasticsearch.node.internal.InternalNode
 
main(String[]) - Static method in class org.elasticsearch.plugins.PluginManager
 
MAIN - Static variable in class org.elasticsearch.search.internal.ContextIndexSearcher.Scopes
 
main(String[]) - Static method in class org.elasticsearch.Version
 
major - Variable in class org.elasticsearch.Version
 
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.
makeLock(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
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.
ManagedAttribute - Annotation Type in org.elasticsearch.jmx
 
managedBlock(ForkJoinPool.ManagedBlocker) - Static method in class jsr166y.ForkJoinPool
Blocks in accord with the given blocker.
ManagedGroupName - Annotation Type in org.elasticsearch.jmx
 
ManagedOperation - Annotation Type in org.elasticsearch.jmx
 
MANAGEMENT - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
managementGroupName() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
map(K) - Method in interface jsr166e.ConcurrentHashMapV8.MappingFunction
Returns a non-null value for the given key.
map() - Method in class org.elasticsearch.common.collect.MapBuilder
 
map() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
map(Map<String, Object>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
map() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
mapAndClose() - Method in class org.elasticsearch.common.xcontent.support.AbstractXContentParser
 
mapAndClose() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
MapBackedSet<E> - Class in org.elasticsearch.common.collect
 
MapBackedSet(Map<E, Boolean>) - Constructor for class org.elasticsearch.common.collect.MapBackedSet
Creates a new instance which wraps the specified map.
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
 
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.lookup.FieldLookup
 
Mapper.Builder<T extends Mapper.Builder,Y extends Mapper> - Class in org.elasticsearch.index.mapper
 
Mapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.Mapper.Builder
 
Mapper.BuilderContext - Class in org.elasticsearch.index.mapper
 
Mapper.BuilderContext(Settings, ContentPath) - Constructor for class org.elasticsearch.index.mapper.Mapper.BuilderContext
 
Mapper.TypeParser - Interface in org.elasticsearch.index.mapper
 
Mapper.TypeParser.ParserContext - Class in org.elasticsearch.index.mapper
 
Mapper.TypeParser.ParserContext(AnalysisService, ImmutableMap<String, Mapper.TypeParser>) - Constructor for class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
 
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
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.MapperQueryParser
 
MapperQueryParser(QueryParserSettings, QueryParseContext) - Constructor for class org.apache.lucene.queryParser.MapperQueryParser
 
mappers() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
mappers() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
mappers() - Method in class org.elasticsearch.index.mapper.FieldMappers
 
mappers() - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
mappers() - Method in class org.elasticsearch.index.mapper.ObjectMappers
 
mappersAdded() - Method in class org.elasticsearch.index.percolator.PercolatorExecutor.Response
 
mappersBuilders - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
MapperService - Class in org.elasticsearch.index.mapper
 
MapperService(Index, Settings, Environment, AnalysisService) - Constructor for class org.elasticsearch.index.mapper.MapperService
 
mapperService() - Method in class org.elasticsearch.index.query.QueryParseContext
 
mapperService() - Method in interface org.elasticsearch.index.service.IndexService
 
mapperService() - Method in class org.elasticsearch.index.service.InternalIndexService
 
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.SmartNameFieldMappers(MapperService, FieldMappers, DocumentMapper, boolean) - Constructor for class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
 
MapperService.SmartNameObjectMapper - Class in org.elasticsearch.index.mapper
 
MapperService.SmartNameObjectMapper(ObjectMapper, DocumentMapper) - Constructor for class org.elasticsearch.index.mapper.MapperService.SmartNameObjectMapper
 
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, 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) - 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
 
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) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData
 
MappingMetaData.Id - Class in org.elasticsearch.cluster.metadata
 
MappingMetaData.Id(String) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.Id
 
MappingMetaData.ParseContext - Class in org.elasticsearch.cluster.metadata
 
MappingMetaData.ParseContext(boolean, boolean, boolean) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
 
MappingMetaData.Routing - Class in org.elasticsearch.cluster.metadata
 
MappingMetaData.Routing(boolean, String) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
 
MappingMetaData.Timestamp - Class in org.elasticsearch.cluster.metadata
 
MappingMetaData.Timestamp(boolean, String, String) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetaData.Timestamp
 
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() - 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.MetaDataCreateIndexService.Request
 
mappings(Map<String, String>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
 
mappingsCompressed(Map<String, CompressedString>) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Request
 
mappingsMetaData(Map<String, MappingMetaData>) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Request
 
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) - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
MappingUpdatedAction.MappingUpdatedRequest - Class in org.elasticsearch.cluster.action.index
 
MappingUpdatedAction.MappingUpdatedRequest(String, String, CompressedString) - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
MappingUpdatedAction.MappingUpdatedResponse - Class in org.elasticsearch.cluster.action.index
 
MappingUpdatedAction.MappingUpdatedResponse() - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedResponse
 
mark - Variable in class org.elasticsearch.common.io.FastByteArrayInputStream
The currently marked position in the stream.
mark(int) - Method in class org.elasticsearch.common.io.FastByteArrayInputStream
Set the current marked position in the stream.
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.FileChannelInputStream
 
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
 
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.
markSupported() - Method in class org.elasticsearch.common.io.FastByteArrayInputStream
Tests if this InputStream supports mark/reset.
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.FileChannelInputStream
 
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
 
masterAndDataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
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, DiscoveryNodesProvider) - 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
 
masterNode() - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
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
 
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
 
masterNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
masterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
A timeout value in case the master has not been discovered yet or disconnected.
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
 
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) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
masterOperation(NodesShutdownRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
masterOperation(ClusterRerouteRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
 
masterOperation(ClusterUpdateSettingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
masterOperation(ClusterStateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
masterOperation(IndicesAliasesRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
masterOperation(CloseIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
 
masterOperation(CreateIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
masterOperation(DeleteIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
masterOperation(IndicesExistsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.exists.TransportIndicesExistsAction
 
masterOperation(DeleteMappingRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
masterOperation(PutMappingRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
masterOperation(OpenIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
 
masterOperation(UpdateSettingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.settings.TransportUpdateSettingsAction
 
masterOperation(DeleteIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
masterOperation(PutIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
 
masterOperation(DeleteWarmerRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
 
masterOperation(PutWarmerRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
 
masterOperation(Request, ClusterState) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
masterOperation(MappingUpdatedAction.MappingUpdatedRequest, ClusterState) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
match() - Method in class org.elasticsearch.action.explain.ExplainResponse
 
match(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
 
match(String) - Method in class org.elasticsearch.common.transport.DummyTransportAddress
 
match(String) - Method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
match(String) - Method in class org.elasticsearch.common.transport.LocalTransportAddress
 
match(String) - Method in interface org.elasticsearch.common.transport.TransportAddress
 
match(ContentPath, String, String) - Method in class org.elasticsearch.index.mapper.object.DynamicTemplate
 
MATCH_ALL_FILTER - Static variable in class org.elasticsearch.common.lucene.search.Queries
A match all docs filter.
MATCH_ALL_PARSED_QUERY - Static variable in class org.elasticsearch.index.query.ParsedQuery
 
MATCH_ALL_QUERY - Static variable in class org.elasticsearch.common.lucene.search.Queries
 
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
 
matchedFilters(String[]) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
matchedFilters() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
matchedFilters() - Method in interface org.elasticsearch.search.SearchHit
The set of filter names the query matched.
MatchedFiltersFetchSubPhase - Class in org.elasticsearch.search.fetch.matchedfilters
 
MatchedFiltersFetchSubPhase() - Constructor for class org.elasticsearch.search.fetch.matchedfilters.MatchedFiltersFetchSubPhase
 
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.index.IndexResponse
Returns the percolate queries matches.
matches(List<String>) - Method in class org.elasticsearch.action.index.IndexResponse
Internal.
matches() - Method in class org.elasticsearch.action.percolate.PercolateResponse
 
matches() - Method in class org.elasticsearch.action.update.UpdateResponse
Returns the percolate queries matches.
matches(List<String>) - Method in class org.elasticsearch.action.update.UpdateResponse
Internal.
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.index.percolator.PercolatorExecutor.Response
 
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
 
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
 
MatchQueryParser - Class in org.elasticsearch.index.query
 
MatchQueryParser() - Constructor for class org.elasticsearch.index.query.MatchQueryParser
 
MathRuntimeException - Exception in org.elasticsearch.common.math
Base class for commons-math unchecked exceptions.
MathRuntimeException(String, Object...) - Constructor for exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new MathRuntimeException with specified formatted detail message.
MathRuntimeException(Throwable) - Constructor for exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new MathRuntimeException with specified nested Throwable root cause.
MathRuntimeException(Throwable, String, Object...) - Constructor for exception org.elasticsearch.common.math.MathRuntimeException
Constructs a new MathRuntimeException with specified formatted detail message and nested Throwable root cause.
MathUtils - Class in org.elasticsearch.common.math
Some useful additions to the built-in functions in 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() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The maximum value.
max() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
max() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
max() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
max() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
max() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
max() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The maximum value.
max() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
max() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
max() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
max() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
max() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The maximum value.
max() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector.StatsProc
 
max() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector.StatsProc
 
max() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
max() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
max() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
max() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
max() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
 
MAX_ALPHA_SIZE - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
MAX_BLOCKSIZE - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
The maximum supported blocksize == 9.
MAX_CODE_LEN - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
MAX_LEVELS_POSSIBLE - Static variable in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
MAX_NUM_SEGMENTS - Static variable in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
MAX_SELECTORS - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
maxBoost(float) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
 
maxCompressedChunkLength - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexInput
 
maxCompressedChunkLength - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamInput
 
maxCompressedLength(int) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
maxCompressedLength(int) - Method in class org.elasticsearch.common.compress.snappy.UnavailableSnappyCompressor
 
maxCompressedLength(int) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressor
 
maxDoc() - Method in class org.elasticsearch.action.admin.indices.status.DocsStatus
The max doc.
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
 
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
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.
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
 
maxLevels - Variable in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
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.
maxNumSegments() - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
maxNumSegments(int) - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
maxOpenFiles(File) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
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
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.
maxScan - Variable in class org.elasticsearch.common.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
maxScore - Variable in class org.elasticsearch.index.search.child.TopChildrenQuery.ParentDoc
 
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
 
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().
maxWordLen(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The maximum word length above which words will be ignored.
maxWordLen() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The maximum word length above which words will be ignored.
maxWordLen(int) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Sets the maximum word length above which words will be ignored.
maxWordLen(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the maximum word length above which words will be ignored.
maybeMerge() - Method in interface org.elasticsearch.index.engine.Engine
 
maybeMerge() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
mb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
 
MBean - Annotation Type in org.elasticsearch.jmx
 
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
 
md5(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the MD5 digest and returns the value as a 16 element byte[].
md5(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the MD5 digest and returns the value as a 16 element byte[].
md5(String) - Static method in class org.elasticsearch.common.Digest
Calculates the MD5 digest and returns the value as a 16 element byte[].
md5Hex(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the MD5 digest and returns the value as a 32 character hex string.
md5Hex(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the MD5 digest and returns the value as a 32 character hex string.
md5Hex(String) - Static method in class org.elasticsearch.common.Digest
Calculates the MD5 digest and returns the value as a 32 character hex string.
md5HexFromByteArray(byte[]) - Static method in class org.elasticsearch.common.Digest
 
md5HexToByteArray(String) - Static method in class org.elasticsearch.common.Digest
 
mean() - Method in class org.elasticsearch.common.metrics.MeanMetric
 
mean() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The mean of this facet interval.
mean() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
mean() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
mean() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
The mean of this facet interval.
mean() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
mean() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
mean() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The mean of this facet interval.
mean() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
mean() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
mean() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
The mean of this facet interval.
mean() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
mean() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The mean (average) of the values.
mean() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
mean() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
mean() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
mean() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
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() - 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, TransportService, DiscoveryNodesProvider, MembershipAction.MembershipListener) - Constructor for class org.elasticsearch.discovery.zen.membership.MembershipAction
 
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
 
MemoryIndexStoreModule - Class in org.elasticsearch.index.store.memory
 
MemoryIndexStoreModule(Settings) - Constructor for class org.elasticsearch.index.store.memory.MemoryIndexStoreModule
 
memorySizeInBytes() - Method in class org.elasticsearch.index.translog.fs.FsTranslog
 
memorySizeInBytes() - Method in interface org.elasticsearch.index.translog.Translog
The estimated memory size this translog is taking.
merge(IndexWriter) - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
Just do the merges in sequence.
merge() - Method 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.BinaryFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
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(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.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.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.ip.IpFieldMapper
 
merge(Mapper, MergeContext) - Method in interface org.elasticsearch.index.mapper.Mapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
merge(Mapper, MergeContext) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
merge(IndexWriter) - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider.CustomConcurrentMergeScheduler
 
merge(IndexWriter) - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider.CustomSerialMergeScheduler
 
merge() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
merge(ShardDoc[], Map<SearchShardTarget, ? extends QuerySearchResultProvider>, Map<SearchShardTarget, ? extends FetchSearchResultProvider>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
merge(IndexWarmersMetaData, IndexWarmersMetaData) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
MERGE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
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() - Static method in class org.elasticsearch.index.mapper.DocumentMapper.MergeFlags
 
mergeFlags() - Method in class org.elasticsearch.index.mapper.MergeContext
 
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
 
mergeScheduler() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
MergeSchedulerModule - Class in org.elasticsearch.index.merge.scheduler
 
MergeSchedulerModule(Settings) - Constructor for class org.elasticsearch.index.merge.scheduler.MergeSchedulerModule
 
MergeSchedulerModule.MergeSchedulerSettings - Class in org.elasticsearch.index.merge.scheduler
 
MergeSchedulerModule.MergeSchedulerSettings() - Constructor for class org.elasticsearch.index.merge.scheduler.MergeSchedulerModule.MergeSchedulerSettings
 
MergeSchedulerProvider<T extends org.apache.lucene.index.MergeScheduler> - Interface in org.elasticsearch.index.merge.scheduler
 
mergeStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Total merges of this shard replication group.
mergeStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Total merges of this index.
mergeStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Index merge statistics.
MergeStats - Class in org.elasticsearch.index.merge
 
MergeStats() - Constructor for class org.elasticsearch.index.merge.MergeStats
 
mergeStats() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
mergeStats() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
mergeStringArrays(String[], String[]) - Static method in class org.elasticsearch.common.Strings
Merge the given String arrays into one, with overlapping array elements only included once.
message() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
The failure message.
message() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
The failure message.
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
 
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) - 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.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(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(MetaData) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
metaData() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
metaData() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
metaData() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState
 
metaData(String) - Method in class org.elasticsearch.index.store.Store
 
MetaData.Builder - Class in org.elasticsearch.cluster.metadata
 
MetaData.Builder() - Constructor for class org.elasticsearch.cluster.metadata.MetaData.Builder
 
MetaData.Custom - Interface in org.elasticsearch.cluster.metadata
 
MetaData.Custom.Factory<T extends MetaData.Custom> - Interface in org.elasticsearch.cluster.metadata
 
metaDataChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
MetaDataCreateIndexService - Class in org.elasticsearch.cluster.metadata
 
MetaDataCreateIndexService(Settings, Environment, ThreadPool, ClusterService, IndicesService, AllocationService, NodeIndexCreatedAction, MetaDataService, String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService
 
MetaDataCreateIndexService.Listener - Interface in org.elasticsearch.cluster.metadata
 
MetaDataCreateIndexService.Request - Class in org.elasticsearch.cluster.metadata
 
MetaDataCreateIndexService.Request(String, String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Request
 
MetaDataCreateIndexService.Response - Class in org.elasticsearch.cluster.metadata
 
MetaDataCreateIndexService.Response(boolean, IndexMetaData) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Response
 
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.Request(String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Request
 
MetaDataDeleteIndexService.Response - Class in org.elasticsearch.cluster.metadata
 
MetaDataDeleteIndexService.Response(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Response
 
MetaDataIndexAliasesService - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexAliasesService(Settings, ClusterService, IndicesService, NodeAliasesUpdatedAction) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService
 
MetaDataIndexAliasesService.Listener - Interface in org.elasticsearch.cluster.metadata
 
MetaDataIndexAliasesService.Request - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexAliasesService.Request(AliasAction[], TimeValue) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService.Request
 
MetaDataIndexAliasesService.Response - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexAliasesService.Response(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService.Response
 
MetaDataIndexTemplateService - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService(Settings, ClusterService) - 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.PutRequest(String, String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
 
MetaDataIndexTemplateService.PutResponse - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.PutResponse(boolean, IndexTemplateMetaData) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutResponse
 
MetaDataIndexTemplateService.RemoveListener - Interface in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.RemoveRequest - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.RemoveRequest(String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveRequest
 
MetaDataIndexTemplateService.RemoveResponse - Class in org.elasticsearch.cluster.metadata
 
MetaDataIndexTemplateService.RemoveResponse(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveResponse
 
MetaDataMappingService - Class in org.elasticsearch.cluster.metadata
 
MetaDataMappingService(Settings, ClusterService, IndicesService, NodeMappingCreatedAction) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataMappingService
 
MetaDataMappingService.Listener - Interface in org.elasticsearch.cluster.metadata
 
MetaDataMappingService.PutRequest - Class in org.elasticsearch.cluster.metadata
 
MetaDataMappingService.PutRequest(String[], String, String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataMappingService.PutRequest
 
MetaDataMappingService.RemoveRequest - Class in org.elasticsearch.cluster.metadata
 
MetaDataMappingService.RemoveRequest(String[], String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataMappingService.RemoveRequest
 
MetaDataMappingService.Response - Class in org.elasticsearch.cluster.metadata
 
MetaDataMappingService.Response(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataMappingService.Response
 
MetaDataService - Class in org.elasticsearch.cluster.metadata
 
MetaDataService(Settings) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataService
 
MetaDataService.MdLock - Class in org.elasticsearch.cluster.metadata
 
MetaDataService.MdLock() - Constructor for class org.elasticsearch.cluster.metadata.MetaDataService.MdLock
 
MetaDataStateIndexService - Class in org.elasticsearch.cluster.metadata
 
MetaDataStateIndexService(Settings, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataStateIndexService
 
MetaDataStateIndexService.Listener - Interface in org.elasticsearch.cluster.metadata
 
MetaDataStateIndexService.Request - Class in org.elasticsearch.cluster.metadata
 
MetaDataStateIndexService.Request(String) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataStateIndexService.Request
 
MetaDataStateIndexService.Response - Class in org.elasticsearch.cluster.metadata
 
MetaDataStateIndexService.Response(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataStateIndexService.Response
 
MetaDataUpdateSettingsService - Class in org.elasticsearch.cluster.metadata
 
MetaDataUpdateSettingsService(Settings, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService
 
MetaDataUpdateSettingsService.Listener - Interface in org.elasticsearch.cluster.metadata
 
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 interface org.elasticsearch.rest.RestRequest
 
Metric - Interface in org.elasticsearch.common.metrics
 
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
 
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() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The minimum value.
min() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
min() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
min() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
min() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
min() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
min() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The minimum value.
min() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
min() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
min() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
min() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
min() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The minimum value.
min() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector.StatsProc
 
min() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector.StatsProc
 
min() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
min() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
min() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
min() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
min() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
 
MIN_BLOCKSIZE - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
The minimum supported blocksize == 1.
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
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.
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.search.internal.SearchContext
 
minimumScore() - Method in class org.elasticsearch.search.internal.SearchContext
 
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.QueryParserSettings
 
minimumShouldMatch(String) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
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.FieldQueryBuilder
 
minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
 
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.TermsQueryBuilder
 
minor - Variable in class org.elasticsearch.Version
 
minScore(float) - 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.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
 
minSimilarity(float) - Method in class org.elasticsearch.index.query.FuzzyLikeThisFieldQueryBuilder
 
minSimilarity(float) - Method in class org.elasticsearch.index.query.FuzzyLikeThisQueryBuilder
 
minSimilarity(float) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
 
minSimilarity(String) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
 
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
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.
minutes() - Method in class org.elasticsearch.common.unit.TimeValue
 
minutesFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
minWordLen(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The minimum word length below which words will be ignored.
minWordLen() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The minimum word length below which words will be ignored.
minWordLen(int) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
Sets the minimum word length below which words will be ignored.
minWordLen(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Sets the minimum word length below which words will be ignored.
minWordSize - Variable in class org.elasticsearch.index.analysis.compound.AbstractCompoundWordTokenFilterFactory
 
misplacedBindingAnnotation(Member, Annotation) - Method in class org.elasticsearch.common.inject.internal.Errors
 
missing() - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.StaticAggregatorValueProc
 
missing() - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.StaticAggregatorValueProc
 
missing() - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.StaticAggregatorValueProc
 
missing() - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.StaticAggregatorValueProc
 
missing() - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.StaticAggregatorValueProc
 
missing() - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.StaticAggregatorValueProc
 
missing() - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.StaticAggregatorValueProc
 
missing() - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.StaticAggregatorValueProc
 
missing() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.StaticAggregatorValueProc
 
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.
missingConstantValues() - Method in class org.elasticsearch.common.inject.internal.Errors
 
missingConstructor(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
missingCount() - Method in class org.elasticsearch.index.get.GetStats
 
missingCount() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
missingCount() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet
The number of docs missing a value.
missingCount() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
missingCount() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
missingCount() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet
The number of docs missing a value.
MissingFieldQueryExtension - Class in org.apache.lucene.queryParser
 
MissingFieldQueryExtension() - Constructor for class org.apache.lucene.queryParser.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.
missingRuntimeRetention(Object) - Method in class org.elasticsearch.common.inject.internal.Errors
 
missingScopeAnnotation() - Method in class org.elasticsearch.common.inject.internal.Errors
 
missingTime() - Method in class org.elasticsearch.index.get.GetStats
 
missingTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
 
mkdirs(File) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
mlockall(int) - Static method in class org.elasticsearch.common.jna.CLibrary
 
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
 
model() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
Module - Interface in org.elasticsearch.common.inject
A module contributes configuration information, typically interface bindings, which will be used to create an Injector.
Modules - Class in org.elasticsearch.common.inject
 
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
 
MonitorModule.MonitorSettings() - Constructor for class org.elasticsearch.monitor.MonitorModule.MonitorSettings
 
MonitorService - Class in org.elasticsearch.monitor
 
MonitorService(Settings, JvmMonitorService, OsService, ProcessService, JvmService, NetworkService, FsService) - Constructor for class org.elasticsearch.monitor.MonitorService
 
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
 
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
A more like this query that runs against a specific field.
MoreLikeThisFieldQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
A more like this query that runs against a specific field.
MoreLikeThisFieldQueryParser - Class in org.elasticsearch.index.query
 
MoreLikeThisFieldQueryParser() - Constructor for class org.elasticsearch.index.query.MoreLikeThisFieldQueryParser
 
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.
MoreLikeThisQueryParser - Class in org.elasticsearch.index.query
 
MoreLikeThisQueryParser() - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryParser
 
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.GenericArrayTypeImpl(Type) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
 
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.ParameterizedTypeImpl(Type, Type, Type...) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
 
MoreTypes.WildcardTypeImpl - Class in org.elasticsearch.common.inject.internal
The WildcardType interface supports multiple upper bounds and multiple lower bounds.
MoreTypes.WildcardTypeImpl(Type[], Type[]) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
 
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
 
move(MutableShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocators
 
moveFromPrimary() - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
moveToClosed() - Method in class org.elasticsearch.common.component.Lifecycle
 
moveToPrimary() - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
moveToSecondPhase() - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
moveToStarted() - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
moveToStarted() - Method in class org.elasticsearch.common.component.Lifecycle
 
moveToStopped() - Method in class org.elasticsearch.common.component.Lifecycle
 
mulAndCheck(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Multiply two integers, checking for overflow.
mulAndCheck(long, long) - Static method in class org.elasticsearch.common.math.MathUtils
Multiply two long integers, checking for overflow.
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.
MulticastZenPing - Class in org.elasticsearch.discovery.zen.ping.multicast
 
MulticastZenPing(ThreadPool, TransportService, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
MulticastZenPing(Settings, ThreadPool, TransportService, ClusterName, NetworkService) - 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
 
multiField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
MultiFieldMapper - Class in org.elasticsearch.index.mapper.multifield
 
MultiFieldMapper(String, ContentPath.Type, Mapper) - Constructor for class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
MultiFieldMapper(String, ContentPath.Type, Map<String, Mapper>, Mapper) - Constructor for class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
MultiFieldMapper.Builder - Class in org.elasticsearch.index.mapper.multifield
 
MultiFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.multifield.MultiFieldMapper.Builder
 
MultiFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.multifield
 
MultiFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.multifield.MultiFieldMapper.Defaults
 
MultiFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.multifield
 
MultiFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.multifield.MultiFieldMapper.TypeParser
 
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.Item - Class in org.elasticsearch.action.get
A single get item.
MultiGetRequest.Item(String, String, String) - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
Constructs 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.
MultiGetResponse.Failure(String, String, String, String) - Constructor for class org.elasticsearch.action.get.MultiGetResponse.Failure
 
MultiGetShardRequest - Class in org.elasticsearch.action.get
 
MultiGetShardResponse - Class in org.elasticsearch.action.get
 
multiMatchQuery(Object, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
Creates a match query with type "BOOLEAN" for the provided field name and text.
MultiMatchQuery - Class in org.elasticsearch.index.search
 
MultiMatchQuery(QueryParseContext) - Constructor for class org.elasticsearch.index.search.MultiMatchQuery
 
MultiMatchQueryBuilder - Class in org.elasticsearch.index.query
Same as MatchQueryBuilder but supports multiple fields.
MultiMatchQueryBuilder(Object, String...) - Constructor for class org.elasticsearch.index.query.MultiMatchQueryBuilder
Constructs a new text query.
MultiMatchQueryParser - Class in org.elasticsearch.index.query
Same ad MatchQueryParser but has support for multiple fields.
MultiMatchQueryParser() - Constructor for class org.elasticsearch.index.query.MultiMatchQueryParser
 
MultiPhrasePrefixQuery - Class in org.elasticsearch.common.lucene.search
 
MultiPhrasePrefixQuery() - Constructor for class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
 
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.
MultiSearchResponse.Item(SearchResponse, String) - Constructor for class org.elasticsearch.action.search.MultiSearchResponse.Item
 
MultiValueByteFieldData - Class in org.elasticsearch.index.field.data.bytes
 
MultiValueByteFieldData(String, int[][], byte[]) - Constructor for class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.FieldData
Is the field data a multi valued one (has multiple values / terms per document id) or not.
multiValued() - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.strings.MultiValueStringFieldData
 
multiValued() - Method in class org.elasticsearch.index.field.data.strings.SingleValueStringFieldData
 
multiValued() - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
multiValued() - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
MultiValueDoubleFieldData - Class in org.elasticsearch.index.field.data.doubles
 
MultiValueDoubleFieldData(String, int[][], double[]) - Constructor for class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
MultiValueFloatFieldData - Class in org.elasticsearch.index.field.data.floats
 
MultiValueFloatFieldData(String, int[][], float[]) - Constructor for class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
MultiValueGeoPointFieldData - Class in org.elasticsearch.index.mapper.geo
 
MultiValueGeoPointFieldData(String, int[][], double[], double[]) - Constructor for class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
MultiValueIntFieldData - Class in org.elasticsearch.index.field.data.ints
 
MultiValueIntFieldData(String, int[][], int[]) - Constructor for class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
MultiValueLongFieldData - Class in org.elasticsearch.index.field.data.longs
 
MultiValueLongFieldData(String, int[][], long[]) - Constructor for class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
MultiValueShortFieldData - Class in org.elasticsearch.index.field.data.shorts
 
MultiValueShortFieldData(String, int[][], short[]) - Constructor for class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
MultiValueStringFieldData - Class in org.elasticsearch.index.field.data.strings
 
MultiValueStringFieldData(String, int[][], String[]) - Constructor for class org.elasticsearch.index.field.data.strings.MultiValueStringFieldData
 
munlockall() - Static method in class org.elasticsearch.common.jna.CLibrary
 
MurmurHash - Class in org.elasticsearch.common
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
MurmurHash() - Constructor for class org.elasticsearch.common.MurmurHash
 
must(FilterBuilder) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds a filter that must appear in the matching documents.
must(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Adds a query that must appear in the matching documents.
mustNot(FilterBuilder) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds a filter that must not appear in the matching documents.
mustNot(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Adds a query that must not appear in the matching documents.
MutableShardRouting - Class in org.elasticsearch.cluster.routing
 
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
 
MvelScriptEngineService - Class in org.elasticsearch.script.mvel
 
MvelScriptEngineService(Settings) - Constructor for class org.elasticsearch.script.mvel.MvelScriptEngineService
 
MvelScriptEngineService.MvelExecutableScript - Class in org.elasticsearch.script.mvel
 
MvelScriptEngineService.MvelExecutableScript(Object, Map) - Constructor for class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelExecutableScript
 
MvelScriptEngineService.MvelSearchScript - Class in org.elasticsearch.script.mvel
 
MvelScriptEngineService.MvelSearchScript(Object, SearchLookup, Map<String, Object>) - Constructor for class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 

N

N_GROUPS - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
N_ITERS - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
NA - Static variable in class org.elasticsearch.search.internal.ContextIndexSearcher.Scopes
 
NA_INTERFACE - Static variable in class org.elasticsearch.monitor.network.NetworkInfo
 
NAME - Static variable in class org.apache.lucene.queryParser.ExistsFieldQueryExtension
 
NAME - Static variable in class org.apache.lucene.queryParser.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.reroute.ClusterRerouteAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
 
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.IndicesExistsAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.flush.FlushAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotAction
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingAction
 
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.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.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
 
NAME - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
 
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(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.
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 - 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.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.mlt.MoreLikeThisAction
 
NAME - Static variable in class org.elasticsearch.action.percolate.PercolateAction
 
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.update.UpdateAction
 
name() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
 
name() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The name of the node.
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.lucene.all.AllEntries.Entry
 
name(String) - Method in class org.elasticsearch.common.lucene.document.SingleFieldSelector
 
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 interface org.elasticsearch.index.analysis.TokenFilterFactory
 
name() - Method in interface org.elasticsearch.index.analysis.TokenizerFactory
 
name() - Method in class org.elasticsearch.index.engine.Segment
 
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.get.GetField
 
name() - Method in class org.elasticsearch.index.Index
 
name() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
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() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
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.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 - 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.multifield.MultiFieldMapper
 
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.ConstantScoreQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.CustomBoostFactorQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.CustomFiltersScoreQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.CustomScoreQueryParser
 
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.FieldQueryParser
 
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.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.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.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
 
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
 
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.ScriptFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.SpanFirstQueryParser
 
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.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
 
name() - Method in interface org.elasticsearch.index.similarity.SimilarityProvider
 
name() - Method in class org.elasticsearch.index.store.StoreFileMetaData
 
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 exception org.elasticsearch.monitor.dump.DumpContributionFailedException
 
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() - Method in class org.elasticsearch.river.RiverName
 
name - Variable in class org.elasticsearch.search.facet.AbstractFacetBuilder
 
name() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
name() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
name() - Method in interface org.elasticsearch.search.facet.Facet
The "logical" name of the search facet.
name() - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
The "logical" name of the facet.
name() - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
name() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet
 
name() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
name() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
name() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
name() - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
The "logical" name of the facet.
name() - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
name() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
name() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
name() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
name() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
name() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
name() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
name() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
name() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
name() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
name() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
name() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
name() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
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() - Method in interface org.elasticsearch.search.SearchHitField
The name of the field.
name() - Method in exception org.elasticsearch.search.warmer.IndexWarmerMissingException
 
name() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
 
name() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
 
name() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
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(String, Analyzer) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
 
NamedAnalyzer(String, AnalyzerScope, Analyzer) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
 
NamedCustomAnalyzer - Class in org.elasticsearch.index.analysis
 
NamedCustomAnalyzer(NamedAnalyzer, int) - Constructor for class org.elasticsearch.index.analysis.NamedCustomAnalyzer
 
namedFilters() - Method in class org.elasticsearch.index.query.ParsedQuery
 
namedStopWords - Static variable in class org.elasticsearch.index.analysis.Analysis
 
Names - Class in org.elasticsearch.common.inject.name
Utility methods for use with @Named.
Names - Class in org.elasticsearch.common
 
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() - 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.ConstantScoreQueryParser
 
names() - Method in class org.elasticsearch.index.query.CustomBoostFactorQueryParser
 
names() - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryParser
 
names() - Method in class org.elasticsearch.index.query.CustomScoreQueryParser
 
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.FieldQueryParser
 
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() - 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.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.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
 
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
 
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.ScriptFilterParser
 
names() - Method in class org.elasticsearch.index.query.SpanFirstQueryParser
 
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.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 class org.elasticsearch.search.sort.GeoDistanceSortParser
 
names() - Method in class org.elasticsearch.search.sort.ScriptSortParser
 
names() - Method in interface org.elasticsearch.search.sort.SortParser
 
nameUUIDFromBytes(byte[]) - Static method in class org.elasticsearch.common.UUID
Static factory to retrieve a type 3 (name based) UUID based on the specified byte array.
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.
nativeValue(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
negative(QueryBuilder) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
 
negativeBoost(float) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
 
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 - Variable in class org.elasticsearch.search.facet.AbstractFacetBuilder
 
nested(String) - Method in class org.elasticsearch.search.facet.AbstractFacetBuilder
Sets the nested path the facet will execute on.
nested(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
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
 
NestedChildrenCollector - Class in org.elasticsearch.index.search.nested
A collector that accepts parent docs, and calls back the collect on child docs of that parent.
NestedChildrenCollector(FacetCollector, Filter, Filter) - Constructor for class org.elasticsearch.index.search.nested.NestedChildrenCollector
 
NestedDocsFilter - Class in org.elasticsearch.index.search.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() - Constructor for class org.elasticsearch.index.query.NestedFilterParser
 
nestedQueries() - Method in class org.elasticsearch.search.internal.SearchContext
 
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() - Constructor for class org.elasticsearch.index.query.NestedQueryParser
 
nestedTypeFilter() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
nestedTypePath() - Method in class org.elasticsearch.index.mapper.object.ObjectMapper
 
NettyHttpChannel - Class in org.elasticsearch.http.netty
 
NettyHttpChannel(NettyHttpServerTransport, Channel, HttpRequest) - Constructor for class org.elasticsearch.http.netty.NettyHttpChannel
 
NettyHttpRequest - Class in org.elasticsearch.http.netty
 
NettyHttpRequest(HttpRequest) - Constructor for class org.elasticsearch.http.netty.NettyHttpRequest
 
NettyHttpServerTransport - Class in org.elasticsearch.http.netty
 
NettyHttpServerTransport(Settings, NetworkService) - Constructor for class org.elasticsearch.http.netty.NettyHttpServerTransport
 
NettyHttpServerTransportModule - Class in org.elasticsearch.http.netty
 
NettyHttpServerTransportModule() - Constructor for class org.elasticsearch.http.netty.NettyHttpServerTransportModule
 
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
 
NettyStaticSetup - Class in org.elasticsearch.common.netty
 
NettyStaticSetup() - Constructor for class org.elasticsearch.common.netty.NettyStaticSetup
 
NettyStaticSetup.EsThreadNameDeterminer - Class in org.elasticsearch.common.netty
 
NettyStaticSetup.EsThreadNameDeterminer() - Constructor for class org.elasticsearch.common.netty.NettyStaticSetup.EsThreadNameDeterminer
 
NettyTransport - Class in org.elasticsearch.transport.netty
There are 3 types of connections per node, low/med/high.
NettyTransport(ThreadPool) - Constructor for class org.elasticsearch.transport.netty.NettyTransport
 
NettyTransport(Settings, ThreadPool) - Constructor for class org.elasticsearch.transport.netty.NettyTransport
 
NettyTransport(Settings, ThreadPool, NetworkService) - Constructor for class org.elasticsearch.transport.netty.NettyTransport
 
NettyTransport.CacheFutureListener - Class in org.elasticsearch.transport.netty
 
NettyTransport.CacheFutureListener(CachedStreamOutput.Entry) - Constructor for class org.elasticsearch.transport.netty.NettyTransport.CacheFutureListener
 
NettyTransport.NodeChannels - Class in org.elasticsearch.transport.netty
 
NettyTransport.NodeChannels(Channel[], Channel[], Channel[]) - Constructor for class org.elasticsearch.transport.netty.NettyTransport.NodeChannels
 
NettyTransportChannel - Class in org.elasticsearch.transport.netty
 
NettyTransportChannel(NettyTransport, String, Channel, long) - Constructor for class org.elasticsearch.transport.netty.NettyTransportChannel
 
NettyTransportManagement - Class in org.elasticsearch.transport.netty
 
NettyTransportManagement(Transport) - Constructor for class org.elasticsearch.transport.netty.NettyTransportManagement
 
NettyTransportModule - Class in org.elasticsearch.transport.netty
 
NettyTransportModule(Settings) - Constructor for class org.elasticsearch.transport.netty.NettyTransportModule
 
network() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
Network level information.
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.
network() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
Network level statistics.
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() - Method in class org.elasticsearch.monitor.network.SigarNetworkProbe
 
NetworkInfo.Interface - Class in org.elasticsearch.monitor.network
 
NetworkInfo.Interface(String, String, String) - Constructor for class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
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() - 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.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
 
NetworkService.TcpSettings() - Constructor for class org.elasticsearch.common.network.NetworkService.TcpSettings
 
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() - Method in class org.elasticsearch.monitor.network.SigarNetworkProbe
 
NetworkStats.Tcp - Class in org.elasticsearch.monitor.network
 
NetworkStats.Tcp() - Constructor for class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
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
 
newAliasMetaDataBuilder(String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetaData
 
newBlockingExecutorService(int, int, long, TimeUnit, ThreadFactory, int, long, TimeUnit) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
newBlockingQueue() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newByteRange(FieldDataCache, String, Byte, Byte, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newClusterStateBuilder() - Static method in class org.elasticsearch.cluster.ClusterState
 
newConcurrentMap() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newConcurrentMapLong() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newConcurrentSet() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
 
newCondition() - Method in class jsr166e.SequenceLock
Throws UnsupportedOperationException.
newDoubleRange(FieldDataCache, String, Double, Double, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
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
 
newFieldComparatorSource(FieldDataCache, String) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataType
 
newFieldComparatorSource(FieldDataCache, String) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataType
 
newFieldComparatorSource(FieldDataCache, String) - Method in interface org.elasticsearch.index.field.data.FieldDataType
 
newFieldComparatorSource(FieldDataCache, String) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataType
 
newFieldComparatorSource(FieldDataCache, String) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataType
 
newFieldComparatorSource(FieldDataCache, String) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataType
 
newFieldComparatorSource(FieldDataCache, String) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataType
 
newFieldComparatorSource(FieldDataCache, String) - Method in class org.elasticsearch.index.field.data.strings.StringFieldDataType
 
newFieldComparatorSource(FieldDataCache, String) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldDataType
 
newFloatRange(FieldDataCache, String, Float, Float, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newFuture() - Static method in class org.elasticsearch.action.support.PlainActionFuture
 
newFuzzyQuery(Term, float, int) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
newIndexMetaDataBuilder(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
newIndexMetaDataBuilder(IndexMetaData) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
newIndexRequestInstance(DeleteByQueryRequest, String, Set<String>) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
newIndexRequestInstance(Request, String, Set<String>) - 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(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.
newInstance() - Method in class org.elasticsearch.transport.VoidTransportResponseHandler
 
newIntRange(FieldDataCache, String, Integer, Integer, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newLongRange(FieldDataCache, String, Long, Long, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newMap() - Method in interface org.elasticsearch.common.xcontent.support.XContentMapConverter.MapFactory
 
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.MapperQueryParser
 
newMergePolicy() - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
newMergePolicy() - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
newMergePolicy() - Method in interface org.elasticsearch.index.merge.policy.MergePolicyProvider
 
newMergePolicy() - Method in class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
newMergeScheduler() - Method in class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
newMergeScheduler() - Method in interface org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
newMergeScheduler() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
 
newMetaDataBuilder() - Static method in class org.elasticsearch.cluster.metadata.MetaData
 
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.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.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
 
newNodesBuilder() - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
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.
newPoint(double, double) - Static method in class org.elasticsearch.common.geo.ShapeBuilder
Creates a new Point
newPolygon() - Static method in class org.elasticsearch.common.geo.ShapeBuilder
Creates a new ShapeBuilder.PolygonBuilder to build a Polygon
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
 
newRectangle() - Static method in class org.elasticsearch.common.geo.ShapeBuilder
Creates a new ShapeBuilder.RectangleBuilder to build a Rectangle
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.index.TransportShardDeleteAction
 
newReplicaRequestInstance() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
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.reroute.TransportClusterRerouteAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
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.TransportIndicesExistsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
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.refresh.TransportRefreshAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.settings.TransportUpdateSettingsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
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.put.TransportPutWarmerAction
 
newRequest() - Method in class org.elasticsearch.action.count.TransportCountAction
 
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.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.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
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.ClusterAction
 
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.reroute.ClusterRerouteAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
 
newRequestBuilder(ClusterAdminClient) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
 
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.IndicesExistsAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.flush.FlushAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.IndicesAction
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingAction
 
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.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.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
 
newRequestBuilder(IndicesAdminClient) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
 
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.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.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.mlt.MoreLikeThisAction
 
newRequestBuilder(Client) - Method in class org.elasticsearch.action.percolate.PercolateAction
 
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.update.UpdateAction
 
newRequestInstance() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
newRequestInstance() - Method in class org.elasticsearch.action.delete.index.TransportIndexDeleteAction
 
newRequestInstance() - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
newRequestInstance() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
newRequestInstance() - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
newRequestInstance() - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
newRequestInstance() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
newRequestInstance() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
newRequestInstance() - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
newRequestInstance() - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
newRequestInstance() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
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.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.state.ClusterStateAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
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.IndicesExistsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.exists.TransportIndicesExistsAction
 
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.gateway.snapshot.GatewaySnapshotAction
 
newResponse(GatewaySnapshotRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
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.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.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.TransportUpdateSettingsAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.settings.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
 
newResponse(IndicesStatusRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
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.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.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.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.mlt.MoreLikeThisAction
 
newResponse() - Method in class org.elasticsearch.action.percolate.PercolateAction
 
newResponse() - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
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(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.update.TransportUpdateAction
 
newResponse() - Method in class org.elasticsearch.action.update.UpdateAction
 
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(IndexDeleteRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.delete.index.TransportIndexDeleteAction
 
newResponseInstance() - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
newResponseInstance() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
newResponseInstance(DeleteByQueryRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
newResponseInstance(IndexDeleteByQueryRequest, AtomicReferenceArray) - 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, AtomicReferenceArray) - 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
 
newScalingExecutorService(int, int, long, TimeUnit, ThreadFactory) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
newScript(Map<String, Object>) - Method in interface org.elasticsearch.script.NativeScriptFactory
Creates a new instance of either a ExecutableScript or a SearchScript.
newScript(Map<String, Object>) - Method in class org.elasticsearch.script.ScriptService.DocScoreNativeScriptFactory
 
newSearcher() - Method in class org.elasticsearch.indices.warmer.IndicesWarmer.WarmerContext
 
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(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(ShardRouting, FlushRequest) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
newShardRequest(ShardRouting, GatewaySnapshotRequest) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newShardRequest(ShardRouting, OptimizeRequest) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newShardRequest(ShardRouting, RefreshRequest) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
newShardRequest(ShardRouting, IndicesSegmentsRequest) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
newShardRequest(ShardRouting, IndicesStatsRequest) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
newShardRequest(ShardRouting, IndicesStatusRequest) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
newShardRequest() - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
newShardRequest(ShardRouting, ValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
newShardRequest() - Method in class org.elasticsearch.action.count.TransportCountAction
 
newShardRequest(ShardRouting, CountRequest) - Method in class org.elasticsearch.action.count.TransportCountAction
 
newShardRequest() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
newShardRequest(ShardRouting, Request) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
newShardRequestInstance(IndexDeleteRequest, int) - Method in class org.elasticsearch.action.delete.index.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.gateway.snapshot.TransportGatewaySnapshotAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
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
 
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.support.broadcast.TransportBroadcastOperationAction
 
newShortRange(FieldDataCache, String, Short, Short, boolean, boolean) - Static method in class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
newTaskFor(Runnable, T) - Method in class jsr166y.ForkJoinPool
 
newTaskFor(Callable<T>) - Method in class jsr166y.ForkJoinPool
 
newTermQuery(Term) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
newThread(ForkJoinPool) - Method in interface jsr166y.ForkJoinPool.ForkJoinWorkerThreadFactory
Returns a new worker thread operating in the given pool.
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.
newTranslogCreated() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
Indicates that a new transaction log has been created.
next(int) - Method in class jsr166y.ThreadLocalRandom
 
next() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
next() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
 
nextAfter(double, double) - Static method in class org.elasticsearch.common.math.MathUtils
Get the next machine representable number after a number, moving in the direction of another number.
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.AllDocSet.AllDocIdSetIterator
 
nextDoc() - Method in class org.elasticsearch.common.lucene.docset.NotDocIdSet.NotDocIdSetIterator
 
nextDoc() - Method in class org.elasticsearch.common.lucene.docset.OrDocIdSet.OrDocIdSetIterator
 
nextDoc() - Method in class org.elasticsearch.common.lucene.docset.OrDocSet.OrDocIdSetIterator
 
nextDoc() - Method in class org.elasticsearch.common.lucene.search.EmptyScorer
 
nextDouble(double) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed double value between 0 (inclusive) and the specified value (exclusive).
nextDouble(double, double) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextInt(int, int) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextLong(long) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between 0 (inclusive) and the specified value (exclusive).
nextLong(long, long) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
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.bytes.TermsByteOrdinalsFacetCollector.ReaderAggregator
 
nextPosition() - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector.ReaderAggregator
 
nextPosition() - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector.ReaderAggregator
 
nextPosition() - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector.ReaderAggregator
 
nextPosition() - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector.ReaderAggregator
 
nextPosition() - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector.ReaderAggregator
 
nextPosition() - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector.ReaderAggregator
 
nextPosition() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector.ReaderAggregator
 
nextPossibleMasters(Iterable<DiscoveryNode>, int) - Method in class org.elasticsearch.discovery.zen.elect.ElectMasterService
Returns a list of the next possible masters.
nextToken() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentParser
 
nextToken() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
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.index.mapper.object.ObjectMapper.Nested
 
NO_DECODER - Static variable in class org.elasticsearch.common.path.PathTrie
 
NO_DOC - Static variable in class org.elasticsearch.common.lucene.Lucene
 
NO_FILTERS - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
 
NO_MASTER_BLOCK - Static variable in interface org.elasticsearch.discovery.Discovery
 
NO_MATCH_QUERY - Static variable in class org.elasticsearch.common.lucene.search.Queries
 
NO_OPTIONS - Static variable in class org.elasticsearch.common.Base64
No options specified.
NO_SCOPE - Static variable in class org.elasticsearch.common.inject.Scopes
No scope; the same as not applying any scope at all.
NO_SNAPSHOT_LOCK - Static variable in interface org.elasticsearch.index.gateway.IndexShardGateway
 
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
 
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.action.support.nodes.NodeOperationResponse
The node this information relates to.
node() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation.NodeExplanation
 
node() - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
node(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
Node - Class in org.elasticsearch.common.lucene.spatial.prefix.tree
Represents a grid cell.
Node(SpatialPrefixTree, String) - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
Node(SpatialPrefixTree, byte[], int, int) - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
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
 
NodeAdminClient - Class in org.elasticsearch.client.node
 
NodeAdminClient(Settings, NodeClusterAdminClient, NodeIndicesAdminClient) - Constructor for class org.elasticsearch.client.node.NodeAdminClient
 
nodeAliasesUpdated(NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse) - Method in class org.elasticsearch.cluster.action.index.NodeAliasesUpdatedAction
 
NodeAliasesUpdatedAction - Class in org.elasticsearch.cluster.action.index
 
NodeAliasesUpdatedAction(Settings, ThreadPool, TransportService, ClusterService) - Constructor for class org.elasticsearch.cluster.action.index.NodeAliasesUpdatedAction
 
NodeAliasesUpdatedAction.Listener - Interface in org.elasticsearch.cluster.action.index
 
NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse - Class in org.elasticsearch.cluster.action.index
 
NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse(String, long) - Constructor for class org.elasticsearch.cluster.action.index.NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse
 
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
 
NodeCache - Class in org.elasticsearch.cache
 
NodeCache(Settings, ByteBufferCache, ClusterService) - Constructor for class org.elasticsearch.cache.NodeCache
 
NodeCacheModule - Class in org.elasticsearch.cache
 
NodeCacheModule(Settings) - Constructor for class org.elasticsearch.cache.NodeCacheModule
 
NodeClient - Class in org.elasticsearch.client.node
 
NodeClient(Settings, ThreadPool, NodeAdminClient, Map<GenericAction, TransportAction>) - 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(Settings, ThreadPool, Map<GenericAction, TransportAction>) - 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
 
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
 
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
 
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
 
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.NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse
 
nodeId() - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
nodeId() - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
nodeId() - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
nodeId() - Method in class org.elasticsearch.search.SearchShardTarget
 
nodeIndexCreated(String, String) - Method in class org.elasticsearch.cluster.action.index.NodeIndexCreatedAction
 
NodeIndexCreatedAction - Class in org.elasticsearch.cluster.action.index
 
NodeIndexCreatedAction(Settings, ThreadPool, TransportService, ClusterService) - Constructor for class org.elasticsearch.cluster.action.index.NodeIndexCreatedAction
 
NodeIndexCreatedAction.Listener - Interface in org.elasticsearch.cluster.action.index
 
nodeIndexDeleted(String, String) - Method in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
 
NodeIndexDeletedAction - Class in org.elasticsearch.cluster.action.index
 
NodeIndexDeletedAction(Settings, ThreadPool, TransportService, ClusterService) - 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(Settings, ThreadPool, Map<GenericAction, TransportAction>) - 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(StoreStats, DocsStats, IndexingStats, GetStats, SearchStats, CacheStats, MergeStats, RefreshStats, FlushStats) - 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(String, DiscoveryNode, ImmutableMap<String, String>, Settings, OsInfo, ProcessInfo, JvmInfo, ThreadPoolInfo, NetworkInfo, TransportInfo, HttpInfo) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
 
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
 
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
 
nodeMappingCreated(NodeMappingCreatedAction.NodeMappingCreatedResponse) - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction
 
NodeMappingCreatedAction - Class in org.elasticsearch.cluster.action.index
 
NodeMappingCreatedAction(Settings, ThreadPool, TransportService, ClusterService) - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction
 
NodeMappingCreatedAction.Listener - Interface in org.elasticsearch.cluster.action.index
 
NodeMappingCreatedAction.NodeMappingCreatedResponse - Class in org.elasticsearch.cluster.action.index
 
NodeMappingCreatedAction.NodeMappingCreatedResponse(String, String, String) - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
nodeMappingRefresh(NodeMappingRefreshAction.NodeMappingRefreshRequest) - Method in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
 
NodeMappingRefreshAction - Class in org.elasticsearch.cluster.action.index
 
NodeMappingRefreshAction(Settings, ThreadPool, TransportService, ClusterService, MetaDataMappingService) - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
 
NodeMappingRefreshAction.NodeMappingRefreshRequest - Class in org.elasticsearch.cluster.action.index
 
NodeMappingRefreshAction.NodeMappingRefreshRequest(String, String[], String) - Constructor for class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction.NodeMappingRefreshRequest
 
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(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(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
 
nodes() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse
 
nodes - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
nodes - Variable in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
nodes() - Method 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
 
nodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
nodes() - Method in interface org.elasticsearch.discovery.zen.DiscoveryNodesProvider
 
nodes() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
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, ClusterService, TransportService, IndicesService) - 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) - Constructor for class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
 
NodesFaultDetection.Listener - Interface in org.elasticsearch.discovery.zen.fd
 
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
 
nodesHotThreads(NodesHotThreadsRequest, ActionListener<NodesHotThreadsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
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
 
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
 
nodesMap() - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
NodesOperationRequest - Class in org.elasticsearch.action.support.nodes
 
NodesOperationRequest() - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
NodesOperationRequest(String...) - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
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
 
NodesRestartResponse.NodeRestartResponse(DiscoveryNode) - Constructor for class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartResponse.NodeRestartResponse
 
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
 
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
 
NodeStats - Class in org.elasticsearch.action.admin.cluster.node.stats
Node statistics (dynamic, changes depending on when created).
NodeStats(DiscoveryNode, long, String, NodeIndicesStats, OsStats, ProcessStats, JvmStats, ThreadPoolStats, NetworkStats, FsStats, TransportStats, HttpStats) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
nodesToShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
nodesToTokenStrings(Collection<Node>) - Static method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
Will add the trailing leaf byte for leaves.
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
 
NodeTokenStream - Class in org.elasticsearch.common.lucene.spatial.prefix
Custom TokenStream used to convert a list of Node representing a Shape, into indexable terms.
NodeTokenStream() - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.NodeTokenStream
 
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.
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.
NON_LOOPBACK_ADDRESS - Static variable in class org.elasticsearch.common.network.NetworkUtils
 
NONE - Static variable in interface org.elasticsearch.common.bloom.BloomFilter
 
NoneBloomCache - Class in org.elasticsearch.index.cache.bloom.none
 
NoneBloomCache(Index) - Constructor for class org.elasticsearch.index.cache.bloom.none.NoneBloomCache
 
NoneBloomCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.bloom.none.NoneBloomCache
 
NoneFieldDataCache - Class in org.elasticsearch.index.cache.field.data.none
 
NoneFieldDataCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
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) - 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
 
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 - Class in org.elasticsearch.index.search.nested
 
NoNodeAvailableException - Exception in org.elasticsearch.client.transport
An exception indicating no node is available to perform the operation.
NoNodeAvailableException() - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
 
NOOP_COLLECTOR - Static variable in class org.elasticsearch.common.lucene.search.NoopCollector
 
NoopCollector - Class in org.elasticsearch.common.lucene.search
 
NoopCollector() - Constructor for class org.elasticsearch.common.lucene.search.NoopCollector
 
normalize(double, DistanceUnit) - Method in enum org.elasticsearch.index.search.geo.GeoDistance
 
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
 
normalizeAngle(double, double) - Static method in class org.elasticsearch.common.math.MathUtils
Normalize an angle in a 2&pi wide interval around a center value.
normalizeArray(double[], double) - Static method in class org.elasticsearch.common.math.MathUtils
Normalizes an array to make it sum to a specified value.
normalizeLat(double) - Static method in class org.elasticsearch.index.search.geo.GeoUtils
Normalize latitude to lie within the -90 to 90 (both inclusive) range.
normalizeLon(double) - Static method in class org.elasticsearch.index.search.geo.GeoUtils
Normalize longitude to lie within the -180 (exclusive) to 180 (inclusive) range.
normalizePoint(Point) - Static method in class org.elasticsearch.index.search.geo.GeoUtils
Normalize the geo Point for its coordinates to lie within their respective normalized ranges.
normalizePoint(Point, boolean, boolean) - Static method in class org.elasticsearch.index.search.geo.GeoUtils
Normalize the geo Point for the given coordinates to lie within their respective normalized ranges.
normalizeVersions() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
normalizeVersions() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Normalizes all shard routings to the same version.
normsField(String) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
Field used for normalization factor (document boost).
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, 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
 
notASubtype(Class<?>, Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
NotDeletedFilter - Class in org.elasticsearch.common.lucene.search
A filter that filters out deleted documents.
NotDeletedFilter(Filter) - Constructor for class org.elasticsearch.common.lucene.search.NotDeletedFilter
 
NotDocIdSet - Class in org.elasticsearch.common.lucene.docset
 
NotDocIdSet(DocIdSet, int) - Constructor for class org.elasticsearch.common.lucene.docset.NotDocIdSet
 
NotDocIdSet.NotDocIdSetIterator - Class in org.elasticsearch.common.lucene.docset
 
NotDocSet - Class in org.elasticsearch.common.lucene.docset
 
NotDocSet(DocSet, int) - Constructor for class org.elasticsearch.common.lucene.docset.NotDocSet
 
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
 
notFound() - Method in class org.elasticsearch.action.delete.DeleteResponse
Returns true if there was no doc found to delete.
notFound() - Method in class org.elasticsearch.action.delete.index.ShardDeleteResponse
 
notFound() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
notFound(boolean) - Method in class org.elasticsearch.index.engine.Engine.Delete
 
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(long) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
nowInMillis() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
nowInMillis() - Method in class org.elasticsearch.search.internal.SearchContext
 
NULL - Static variable in class org.elasticsearch.index.gateway.CommitPoint
 
NULL_DIGEST - Static variable in class org.elasticsearch.common.Digest
 
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
 
NullIndexOutput - Class in org.elasticsearch.common.lucene.store
 
NullIndexOutput() - Constructor for class org.elasticsearch.common.lucene.store.NullIndexOutput
 
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 - 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 - Variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.GeoStringFieldMapper.Builder
 
nullValue(String) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.GeoStringFieldMapper.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
 
NUM_BYTES_ARRAY_HEADER - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_BYTES_CHAR - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_BYTES_DOUBLE - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_BYTES_FLOAT - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_BYTES_INT - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_BYTES_LONG - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_BYTES_OBJECT_HEADER - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_BYTES_OBJECT_REF - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_BYTES_SHORT - Static variable in class org.elasticsearch.common.RamUsage
 
NUM_OVERSHOOT_BYTES - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
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, String, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, boolean, NamedAnalyzer, NamedAnalyzer) - 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.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
 
NumberFieldMapper.CustomNumericField - Class in org.elasticsearch.index.mapper.core
 
NumberFieldMapper.CustomNumericField(NumberFieldMapper, byte[]) - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
 
NumberFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
NumberFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
 
numberOfActions() - Method in class org.elasticsearch.action.bulk.BulkRequest
 
numberOfActions() - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
The number of actions currently in the bulk.
numberOfCommitted() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
 
numberOfDataNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
numberOfFiles() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
numberOfFiles() - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
numberOfFiles() - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
 
numberOfFragments() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
numberOfFragments(int) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
numberOfNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
numberOfNodesShardsAreAllocatedOn(String...) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
numberOfOpenChannels() - Method in class org.elasticsearch.common.netty.OpenChannelsHandler
 
numberOfOwningShards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
The number fo shards on this node that will not be eventually relocated.
numberOfRecoveredFiles() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
numberOfReplicas() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
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
 
numberOfReusedFiles() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
numberOfSearch() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
 
numberOfShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
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 interface org.elasticsearch.index.service.IndexService
 
numberOfShards() - Method in class org.elasticsearch.index.service.InternalIndexService
 
numberOfShards() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
numberOfShards() - Method in class org.elasticsearch.search.internal.SearchContext
 
numberOfShardsNotWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
numberOfShardsOfType(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
numberOfShardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
Numbers - Class in org.elasticsearch.common
A set of utlities around 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
 
numDocs() - Method in class org.elasticsearch.action.admin.indices.status.DocsStatus
The number of docs.
numDocs() - Method in class org.elasticsearch.index.engine.Segment
 
numeric(String) - Method in class org.elasticsearch.search.lookup.DocLookup
 
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(DateTimeFormatter) - Constructor for class org.elasticsearch.index.analysis.NumericDateAnalyzer
 
NumericDateAnalyzer(int, DateTimeFormatter) - Constructor for class org.elasticsearch.index.analysis.NumericDateAnalyzer
 
NumericDateTokenizer - Class in org.elasticsearch.index.analysis
 
NumericDateTokenizer(Reader, int, DateTimeFormatter) - Constructor for class org.elasticsearch.index.analysis.NumericDateTokenizer
 
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
 
NumericDocFieldData<T extends NumericFieldData> - Class in org.elasticsearch.index.field.data
 
NumericDocFieldData(T) - Constructor for class org.elasticsearch.index.field.data.NumericDocFieldData
 
NumericDoubleAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericDoubleAnalyzer() - Constructor for class org.elasticsearch.index.analysis.NumericDoubleAnalyzer
 
NumericDoubleAnalyzer(int) - Constructor for class org.elasticsearch.index.analysis.NumericDoubleAnalyzer
 
NumericDoubleTokenizer - Class in org.elasticsearch.index.analysis
 
NumericDoubleTokenizer(Reader, int) - Constructor for class org.elasticsearch.index.analysis.NumericDoubleTokenizer
 
NumericDoubleTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.analysis.NumericDoubleTokenizer
 
NumericFieldData<Doc extends NumericDocFieldData> - Class in org.elasticsearch.index.field.data
 
NumericFieldData(String) - Constructor for class org.elasticsearch.index.field.data.NumericFieldData
 
NumericFieldData.DoubleValueInDocProc - Interface in org.elasticsearch.index.field.data
 
NumericFieldData.LongValueInDocProc - Interface in org.elasticsearch.index.field.data
 
NumericFieldData.MissingDoubleValueInDocProc - Interface in org.elasticsearch.index.field.data
 
NumericFieldData.MissingLongValueInDocProc - Interface in org.elasticsearch.index.field.data
 
NumericFieldDataComparator - Class in org.elasticsearch.index.field.data.support
 
NumericFieldDataComparator(String, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.support.NumericFieldDataComparator
 
NumericFloatAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericFloatAnalyzer() - Constructor for class org.elasticsearch.index.analysis.NumericFloatAnalyzer
 
NumericFloatAnalyzer(int) - Constructor for class org.elasticsearch.index.analysis.NumericFloatAnalyzer
 
NumericFloatTokenizer - Class in org.elasticsearch.index.analysis
 
NumericFloatTokenizer(Reader, int) - Constructor for class org.elasticsearch.index.analysis.NumericFloatTokenizer
 
NumericFloatTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.analysis.NumericFloatTokenizer
 
NumericIntegerAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericIntegerAnalyzer() - Constructor for class org.elasticsearch.index.analysis.NumericIntegerAnalyzer
 
NumericIntegerAnalyzer(int) - Constructor for class org.elasticsearch.index.analysis.NumericIntegerAnalyzer
 
NumericIntegerTokenizer - Class in org.elasticsearch.index.analysis
 
NumericIntegerTokenizer(Reader, int) - Constructor for class org.elasticsearch.index.analysis.NumericIntegerTokenizer
 
NumericIntegerTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.analysis.NumericIntegerTokenizer
 
NumericLongAnalyzer - Class in org.elasticsearch.index.analysis
 
NumericLongAnalyzer() - Constructor for class org.elasticsearch.index.analysis.NumericLongAnalyzer
 
NumericLongAnalyzer(int) - Constructor for class org.elasticsearch.index.analysis.NumericLongAnalyzer
 
NumericLongTokenizer - Class in org.elasticsearch.index.analysis
 
NumericLongTokenizer(Reader, int) - Constructor for class org.elasticsearch.index.analysis.NumericLongTokenizer
 
NumericLongTokenizer(Reader, int, char[]) - Constructor for class org.elasticsearch.index.analysis.NumericLongTokenizer
 
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 FieldDataCache.
NumericRangeFieldDataFilter(FieldDataCache, String, T, T, boolean, boolean) - Constructor for class org.elasticsearch.index.search.NumericRangeFieldDataFilter
 
numericRangeFilter(String) - Static method in class org.elasticsearch.index.query.FilterBuilders
A filter that restricts search results to values that are within the given numeric range.
NumericRangeFilterBuilder - Class in org.elasticsearch.index.query
A filter that restricts search results to values that are within the given numeric range.
NumericRangeFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.NumericRangeFilterBuilder
A filter that restricts search results to values that are within the given range.
NumericRangeFilterParser - Class in org.elasticsearch.index.query
 
NumericRangeFilterParser() - Constructor for class org.elasticsearch.index.query.NumericRangeFilterParser
 
NumericTokenizer - Class in org.elasticsearch.index.analysis
 
NumericTokenizer(Reader, NumericTokenStream, Object) - Constructor for class org.elasticsearch.index.analysis.NumericTokenizer
 
NumericTokenizer(Reader, NumericTokenStream, char[], Object) - Constructor for class org.elasticsearch.index.analysis.NumericTokenizer
 
numHits() - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
numHits() - Method in interface org.elasticsearch.search.internal.ScopePhase.TopDocsPhase
 
numOfFragments(int) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 

O

object(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
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 interface org.elasticsearch.index.mapper.ObjectMapperListener
 
ObjectMapper.Builder<T extends ObjectMapper.Builder,Y extends ObjectMapper> - Class in org.elasticsearch.index.mapper.object
 
ObjectMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
ObjectMapper.Defaults - Class in org.elasticsearch.index.mapper.object
 
ObjectMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.object.ObjectMapper.Defaults
 
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
 
ObjectMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
 
ObjectMapperListener - Interface in org.elasticsearch.index.mapper
 
ObjectMapperListener.Aggregator - Class in org.elasticsearch.index.mapper
 
ObjectMapperListener.Aggregator() - Constructor for class org.elasticsearch.index.mapper.ObjectMapperListener.Aggregator
 
objectMappers() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
objectMappers - Variable in class org.elasticsearch.index.mapper.ObjectMapperListener.Aggregator
 
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
 
Objects - Class in org.elasticsearch.common.inject.internal
Helper functions that can operate on any Object.
ObsBloomFilter - Class in org.elasticsearch.common.bloom
 
obtainDfsResults() - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
obtainFetchResults() - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
obtainPublishUrl(DiscoveryNode) - Method in class org.elasticsearch.jmx.action.GetJmxServiceUrlAction
 
obtainQueryFetchResults() - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
obtainQueryResults() - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
obtainSnapshotLock() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
obtainSnapshotLock() - Method in class org.elasticsearch.index.gateway.fs.FsIndexShardGateway
 
obtainSnapshotLock() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
 
obtainSnapshotLock() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
obtainSnapshotLock() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
occur - Variable in class org.elasticsearch.index.search.MatchQuery
 
of(T) - Static method in class org.elasticsearch.common.inject.util.Providers
Returns a provider which always provides instance.
offer(E) - Method in class jsr166y.ConcurrentLinkedDeque
Inserts the specified element at the tail of this deque.
offer(E, long, TimeUnit) - Method in class jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
offer(E) - Method in class jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
offerFirst(E) - Method in class jsr166y.ConcurrentLinkedDeque
Inserts the specified element at the front of this deque.
offerLast(E) - Method in class jsr166y.ConcurrentLinkedDeque
Inserts the specified element at the end of this deque.
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.
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
 
omitNorms(boolean) - Method in class org.elasticsearch.common.lucene.FieldBuilder
 
omitNorms - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
omitNorms(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
omitNorms - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
omitNorms() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
omitNorms(boolean) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
omitNorms() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
omitTermFreqAndPositions(boolean) - Method in class org.elasticsearch.common.lucene.FieldBuilder
 
onAdvance(int, int) - Method in class jsr166y.Phaser
Overridable method to perform an action upon impending phase advance, and to control termination.
onAliasesUpdated(NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse) - Method in interface org.elasticsearch.cluster.action.index.NodeAliasesUpdatedAction.Listener
 
onClose() - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
 
onClose(SegmentReader) - Method in class org.elasticsearch.index.cache.bloom.simple.SimpleBloomCache
 
onClose(SegmentReader) - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
onClose(SegmentReader) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
onClose(SegmentReader) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdCache
 
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..
onCompleted() - Method in interface org.elasticsearch.common.blobstore.BlobContainer.ReadBlobListener
 
onCompleted() - Method in interface org.elasticsearch.common.blobstore.ImmutableBlobContainer.WriterListener
 
onCompletion(CountedCompleter) - Method in class jsr166y.CountedCompleter
Performs an action when method CountedCompleter.tryComplete() is invoked and there are no pending counts, or when the unconditional method CountedCompleter.complete(java.lang.Void) is invoked.
onDisconnectedFromMaster() - Method in interface org.elasticsearch.discovery.zen.fd.MasterFaultDetection.Listener
 
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
 
onExceptionalCompletion(Throwable, CountedCompleter) - Method in class jsr166y.CountedCompleter
Performs an action when method ForkJoinTask.completeExceptionally(java.lang.Throwable) is invoked or method CountedCompleter.compute() throws an exception, and this task has not otherwise already completed normally.
onFailedEngine(ShardId, Throwable) - Method in interface org.elasticsearch.index.engine.Engine.FailedEngineListener
 
onFailedFetchPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
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.support.AdapterActionFuture
 
onFailure(Throwable) - Method in class org.elasticsearch.client.transport.TransportClientNodesService.RetryListener
 
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Listener
 
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Listener
 
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService.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 interface org.elasticsearch.cluster.metadata.MetaDataMappingService.Listener
 
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.metadata.MetaDataStateIndexService.Listener
 
onFailure(Throwable) - Method in interface org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService.Listener
 
onFailure(Throwable) - Method in interface org.elasticsearch.common.blobstore.BlobContainer.ReadBlobListener
 
onFailure(Throwable) - Method in interface org.elasticsearch.common.blobstore.ImmutableBlobContainer.WriterListener
 
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 interface org.elasticsearch.search.action.SearchServiceListener
 
onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService
 
onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.stats.ShardSearchService
 
onIgnoreRecovery(String) - Method in interface org.elasticsearch.index.gateway.IndexShardGatewayService.RecoveryListener
 
onIgnoreRecovery(boolean, String) - Method in interface org.elasticsearch.indices.recovery.RecoveryTarget.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) - Method in interface org.elasticsearch.discovery.zen.membership.MembershipAction.MembershipListener
 
onLeave(DiscoveryNode) - Method in interface org.elasticsearch.discovery.zen.membership.MembershipAction.MembershipListener
 
only(Object) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
Returns a matcher which matches objects equal to the given object.
ONLY_EXPUNGE_DELETES - Static variable in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
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.
onlyExpungeDeletes() - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
onlyExpungeDeletes(boolean) - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
onlyLongestMatch - Variable in class org.elasticsearch.index.analysis.compound.AbstractCompoundWordTokenFilterFactory
 
onlyNodeActiveShardsIt(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
onMaster() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
Called when local node is elected to be the master
onMasterFailure(DiscoveryNode, String) - Method in interface org.elasticsearch.discovery.zen.fd.MasterFaultDetection.Listener
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.bytes.ByteFieldData.ValueInDocProc
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.doubles.DoubleFieldData.ValueInDocProc
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.FieldData.StringValueInDocProc
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.floats.FloatFieldData.ValueInDocProc
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.ints.IntFieldData.ValueInDocProc
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.longs.LongFieldData.ValueInDocProc
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.NumericFieldData.MissingDoubleValueInDocProc
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.NumericFieldData.MissingLongValueInDocProc
 
onMissing(int) - Method in interface org.elasticsearch.index.field.data.shorts.ShortFieldData.ValueInDocProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector.StatsProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector.StatsProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.StaticAggregatorValueProc
 
onMissing(int) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector.Aggregator
 
onMissing(int) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector.Aggregator
 
onMissing(int) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector.Aggregator
 
onNewClusterState(ClusterState) - Method in interface org.elasticsearch.discovery.zen.publish.PublishClusterStateAction.NewClusterStateListener
 
onNewClusterState(RiverClusterState) - Method in interface org.elasticsearch.river.cluster.PublishRiverClusterStateAction.NewClusterStateListener
 
onNodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportConnectionListener
 
onNodeDisconnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportConnectionListener
 
onNodeFailure(DiscoveryNode, String) - Method in interface org.elasticsearch.discovery.zen.fd.NodesFaultDetection.Listener
 
onNodeIndexCreated(String, String) - Method in interface org.elasticsearch.cluster.action.index.NodeIndexCreatedAction.Listener
 
onNodeIndexDeleted(String, String) - Method in interface org.elasticsearch.cluster.action.index.NodeIndexDeletedAction.Listener
 
onNodeMappingCreated(NodeMappingCreatedAction.NodeMappingCreatedResponse) - Method in interface org.elasticsearch.cluster.action.index.NodeMappingCreatedAction.Listener
 
onOrAfter(Version) - Method in class org.elasticsearch.Version
 
onOrdinal(int, int) - Method in interface org.elasticsearch.index.field.data.FieldData.OrdinalInDocProc
 
onOrdinal(int, int) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteOrdinalsFacetCollector.ReaderAggregator
 
onOrdinal(int, int) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector.ReaderAggregator
 
onOrdinal(int, int) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector.ReaderAggregator
 
onOrdinal(int, int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector.ReaderAggregator
 
onOrdinal(int, int) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector.ReaderAggregator
 
onOrdinal(int, int) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector.ReaderAggregator
 
onOrdinal(int, int) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector.ReaderAggregator
 
onOrdinal(int, int) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector.ReaderAggregator
 
onPartial(byte[], int, int) - Method in interface org.elasticsearch.common.blobstore.BlobContainer.ReadBlobListener
 
onPause(long) - Method in interface org.apache.lucene.store.StoreRateLimiting.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
 
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() - Method in interface org.elasticsearch.indices.recovery.RecoveryTarget.RecoveryListener
 
onRecoveryFailed(IndexShardGatewayRecoveryException) - Method in interface org.elasticsearch.index.gateway.IndexShardGatewayService.RecoveryListener
 
onRecoveryFailure(RecoveryFailedException, boolean) - Method in interface org.elasticsearch.indices.recovery.RecoveryTarget.RecoveryListener
 
onRefreshSettings(Settings) - Method in interface org.elasticsearch.index.settings.IndexSettingsService.Listener
 
onRefreshSettings(Settings) - Method in interface org.elasticsearch.node.settings.NodeSettingsService.Listener
 
onRemoval(RemovalNotification<String, FieldData>) - Method in class org.elasticsearch.index.cache.field.data.resident.ResidentFieldDataCache
 
onRemoval(RemovalNotification<String, FieldData>) - Method in class org.elasticsearch.index.cache.field.data.soft.SoftFieldDataCache
 
onRemoval(RemovalNotification<WeightedFilterCache.FilterCacheKey, DocSet>) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache
 
onRemoval(RemovalNotification<WeightedFilterCache.FilterCacheKey, DocSet>) - Method in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
onResponse(Response) - Method in interface org.elasticsearch.action.ActionListener
A response handler.
onResponse(L) - Method in class org.elasticsearch.action.support.AdapterActionFuture
 
onResponse(Response) - Method in class org.elasticsearch.client.transport.TransportClientNodesService.RetryListener
 
onResponse(MetaDataCreateIndexService.Response) - Method in interface org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Listener
 
onResponse(MetaDataDeleteIndexService.Response) - Method in interface org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Listener
 
onResponse(MetaDataIndexAliasesService.Response) - Method in interface org.elasticsearch.cluster.metadata.MetaDataIndexAliasesService.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(MetaDataMappingService.Response) - Method in interface org.elasticsearch.cluster.metadata.MetaDataMappingService.Listener
 
onResponse(MetaDataStateIndexService.Response) - Method in interface org.elasticsearch.cluster.metadata.MetaDataStateIndexService.Listener
 
onResponse(LocalAllocateDangledIndices.AllocateDangledResponse) - Method in interface org.elasticsearch.gateway.local.state.meta.LocalAllocateDangledIndices.Listener
 
onResult(T) - Method in interface org.elasticsearch.search.action.SearchServiceListener
 
onRetryRecovery(TimeValue, RecoveryStatus) - Method in interface org.elasticsearch.indices.recovery.RecoveryTarget.RecoveryListener
 
onStart() - Method in class jsr166y.ForkJoinWorkerThread
Initializes internal state after construction but before processing any tasks.
onSuccess() - Method in interface org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService.Listener
 
onSuccess(ClusterState) - Method in interface org.elasticsearch.gateway.Gateway.GatewayStateRecoveredListener
 
onTermination(Throwable) - Method in class jsr166y.ForkJoinWorkerThread
Performs cleanup associated with termination of this worker thread.
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() - Method in interface org.elasticsearch.cluster.action.index.NodeAliasesUpdatedAction.Listener
 
onTimeout() - Method in interface org.elasticsearch.cluster.action.index.NodeMappingCreatedAction.Listener
 
onTimeout(TimeValue) - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
 
onValue(int, byte) - Method in interface org.elasticsearch.index.field.data.bytes.ByteFieldData.ValueInDocProc
 
onValue(byte) - Method in interface org.elasticsearch.index.field.data.bytes.ByteFieldData.ValueProc
 
onValue(int, double) - Method in interface org.elasticsearch.index.field.data.doubles.DoubleFieldData.ValueInDocProc
 
onValue(double) - Method in interface org.elasticsearch.index.field.data.doubles.DoubleFieldData.ValueProc
 
onValue(int, String) - Method in interface org.elasticsearch.index.field.data.FieldData.StringValueInDocProc
 
onValue(String) - Method in interface org.elasticsearch.index.field.data.FieldData.StringValueProc
 
onValue(int, float) - Method in interface org.elasticsearch.index.field.data.floats.FloatFieldData.ValueInDocProc
 
onValue(float) - Method in interface org.elasticsearch.index.field.data.floats.FloatFieldData.ValueProc
 
onValue(int, int) - Method in interface org.elasticsearch.index.field.data.ints.IntFieldData.ValueInDocProc
 
onValue(int) - Method in interface org.elasticsearch.index.field.data.ints.IntFieldData.ValueProc
 
onValue(int, MutableDateTime) - Method in interface org.elasticsearch.index.field.data.longs.LongFieldData.DateValueInDocProc
 
onValue(int, long) - Method in interface org.elasticsearch.index.field.data.longs.LongFieldData.ValueInDocProc
 
onValue(long) - Method in interface org.elasticsearch.index.field.data.longs.LongFieldData.ValueProc
 
onValue(int, double) - Method in interface org.elasticsearch.index.field.data.NumericFieldData.DoubleValueInDocProc
 
onValue(int, long) - Method in interface org.elasticsearch.index.field.data.NumericFieldData.LongValueInDocProc
 
onValue(int, double) - Method in interface org.elasticsearch.index.field.data.NumericFieldData.MissingDoubleValueInDocProc
 
onValue(int, long) - Method in interface org.elasticsearch.index.field.data.NumericFieldData.MissingLongValueInDocProc
 
onValue(int, short) - Method in interface org.elasticsearch.index.field.data.shorts.ShortFieldData.ValueInDocProc
 
onValue(short) - Method in interface org.elasticsearch.index.field.data.shorts.ShortFieldData.ValueProc
 
onValue(GeoPoint) - Method in interface org.elasticsearch.index.mapper.geo.GeoPointFieldData.PointValueProc
 
onValue(int, double, double) - Method in interface org.elasticsearch.index.mapper.geo.GeoPointFieldData.ValueInDocProc
 
onValue(double, double) - Method in interface org.elasticsearch.index.mapper.geo.GeoPointFieldData.ValueProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.datehistogram.CountDateHistogramFacetCollector.DateHistogramProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetCollector.DateHistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetCollector.DateHistogramProc.ValueAggregator
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetCollector.DateHistogramProc
 
onValue(int, double, double) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector.Aggregator
 
onValue(int, double, double) - Method in class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetCollector.Aggregator
 
onValue(int, double, double) - Method in class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetCollector.Aggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetCollector.ValueAggregator
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedCountHistogramFacetCollector.HistogramProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueHistogramFacetCollector.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueHistogramFacetCollector.HistogramProc.ValueAggregator
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueScriptHistogramFacetCollector.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.unbounded.CountHistogramFacetCollector.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.unbounded.FullHistogramFacetCollector.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueHistogramFacetCollector.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueHistogramFacetCollector.HistogramProc.ValueAggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueScriptHistogramFacetCollector.HistogramProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.range.KeyValueRangeFacetCollector.RangeProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.range.RangeFacetCollector.RangeProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector.StatsProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector.StatsProc
 
onValue(int, byte) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.AggregatorValueProc
 
onValue(byte) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.StaticAggregatorValueProc
 
onValue(int, byte) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.StaticAggregatorValueProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.AggregatorValueProc
 
onValue(double) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.StaticAggregatorValueProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.StaticAggregatorValueProc
 
onValue(int, float) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.AggregatorValueProc
 
onValue(float) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.StaticAggregatorValueProc
 
onValue(int, float) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.StaticAggregatorValueProc
 
onValue(int, int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.AggregatorValueProc
 
onValue(int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.StaticAggregatorValueProc
 
onValue(int, int) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.StaticAggregatorValueProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.AggregatorValueProc
 
onValue(long) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.StaticAggregatorValueProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.StaticAggregatorValueProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.AggregatorValueProc
 
onValue(long) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.StaticAggregatorValueProc
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.StaticAggregatorValueProc
 
onValue(int, short) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.AggregatorValueProc
 
onValue(short) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.StaticAggregatorValueProc
 
onValue(int, short) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.StaticAggregatorValueProc
 
onValue(int, String) - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.AggregatorValueProc
 
onValue(String) - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.StaticAggregatorValueProc
 
onValue(int, String) - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.StaticAggregatorValueProc
 
onValue(int, String) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.AggregatorValueProc
 
onValue(String) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.StaticAggregatorValueProc
 
onValue(int, String) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.StaticAggregatorValueProc
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector.Aggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector.Aggregator.ValueAggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector.ScriptAggregator
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector.Aggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector.Aggregator.ValueAggregator
 
onValue(int, long) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector.ScriptAggregator
 
onValue(int, String) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector.Aggregator
 
onValue(int, double) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector.Aggregator.ValueAggregator
 
onValue(int, String) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector.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
 
OpenBitDocSet - Class in org.elasticsearch.common.lucene.docset
 
OpenBitDocSet(OpenBitSet) - Constructor for class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
OpenBitDocSet(int) - Constructor for class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
OpenBitDocSet(DocIdSetIterator, int) - Constructor for class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
OpenBufferedIndexOutput - Class in org.apache.lucene.store
Exactly the same as Lucene BufferedIndexOutput but with the ability to set the buffer size
OpenBufferedIndexOutput(int) - Constructor for class org.apache.lucene.store.OpenBufferedIndexOutput
 
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(MetaDataStateIndexService.Request, MetaDataStateIndexService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataStateIndexService
 
OpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
 
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 delete 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
 
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 class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
openInput(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
openInput(String, int) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
openInput(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
openInputRaw(String) - Method in class org.elasticsearch.index.store.Store
Opened an index input in raw form, no decompression for example.
operationComplete(ChannelFuture) - Method in class org.elasticsearch.transport.netty.NettyTransport.CacheFutureListener
 
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(boolean) - Method in class org.elasticsearch.action.delete.DeleteRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreaded(boolean) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
operationThreaded(boolean) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
Sets whether the actual explain action should occur in a different thread if executed locally.
operationThreaded(boolean) - Method in class org.elasticsearch.action.get.GetRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreaded(boolean) - Method in class org.elasticsearch.action.index.IndexRequest
Controls if the operation will be executed on a separate thread when executed locally.
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.
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
Controls the operation threading model.
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
Controls the operation threading model.
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
 
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
Controls the operation threading model.
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
 
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
Controls the operation threading model.
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.count.CountRequest
Controls the operation threading model.
operationThreading() - Method in class org.elasticsearch.action.search.SearchRequest
Controls the the search operation threading model.
operationThreading(SearchOperationThreading) - Method in class org.elasticsearch.action.search.SearchRequest
Controls the the search operation threading model.
operationThreading(String) - Method in class org.elasticsearch.action.search.SearchRequest
Sets the string representation of the operation threading model.
operationThreading() - Method in class org.elasticsearch.action.search.SearchScrollRequest
Controls the the search operation threading model.
operationThreading(SearchOperationThreading) - Method in class org.elasticsearch.action.search.SearchScrollRequest
Controls the the search operation threading model.
operationThreading() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
Controls the operation threading model.
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
Controls the operation threading model.
operationThreading(String) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
Controls the operation threading model.
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(Engine.Optimize) - Method in interface org.elasticsearch.index.engine.Engine
 
optimize(Engine.Optimize) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
optimize(Engine.Optimize) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
optimize(Engine.Optimize) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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
 
optimizedGlobalExecution(SearchContext) - Method in class org.elasticsearch.search.facet.filter.FilterFacetCollector
 
optimizedGlobalExecution(SearchContext) - Method in interface org.elasticsearch.search.facet.OptimizeGlobalFacetCollector
 
optimizedGlobalExecution(SearchContext) - Method in class org.elasticsearch.search.facet.query.QueryFacetCollector
 
OptimizeFailedEngineException - Exception in org.elasticsearch.index.engine
 
OptimizeFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.OptimizeFailedEngineException
 
OptimizeGlobalFacetCollector - Interface in org.elasticsearch.search.facet
 
optimizeQuery(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
Optimizes the given query and returns the optimized version of it.
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
 
OptimizeRequest.Defaults() - Constructor for class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
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
 
optionalConstructor(Constructor) - Method in class org.elasticsearch.common.inject.internal.Errors
 
options() - Static method in class org.elasticsearch.transport.TransportRequestOptions
 
options() - Static method in class org.elasticsearch.transport.TransportResponseOptions
 
opType() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The operation type ("index", "create" or "delete").
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
Sets a string representation of the IndexRequest.opType(org.elasticsearch.action.index.IndexRequest.OpType).
opType() - Method in class org.elasticsearch.action.index.IndexRequest
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(FixedBitSet, DocIdSet) - Static method in class org.elasticsearch.common.lucene.docset.DocSets
 
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(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(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
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.
ORDERED - Static variable in class org.elasticsearch.common.Base64
Encode using the special "ordered" dialect of Base64 described here: http://www.faqs.org/qa/rfcc-1940.html.
ORDERED_MAP_FACTORY - Static variable in class org.elasticsearch.common.xcontent.support.XContentMapConverter
 
OrDocIdSet - Class in org.elasticsearch.common.lucene.docset
 
OrDocIdSet(List<DocIdSet>) - Constructor for class org.elasticsearch.common.lucene.docset.OrDocIdSet
 
OrDocIdSet.OrDocIdSetIterator - Class in org.elasticsearch.common.lucene.docset
 
OrDocSet - Class in org.elasticsearch.common.lucene.docset
 
OrDocSet(List<DocSet>) - Constructor for class org.elasticsearch.common.lucene.docset.OrDocSet
 
OrDocSet.OrDocIdSetIterator - Class in org.elasticsearch.common.lucene.docset
 
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.miscellaneous - package org.apache.lucene.analysis.miscellaneous
 
org.apache.lucene.analysis.pattern - package org.apache.lucene.analysis.pattern
 
org.apache.lucene.index - package org.apache.lucene.index
 
org.apache.lucene.index.memory - package org.apache.lucene.index.memory
 
org.apache.lucene.queryParser - package org.apache.lucene.queryParser
 
org.apache.lucene.search - package org.apache.lucene.search
 
org.apache.lucene.search.vectorhighlight - package org.apache.lucene.search.vectorhighlight
 
org.apache.lucene.store - package org.apache.lucene.store
 
org.apache.lucene.store.bytebuffer - package org.apache.lucene.store.bytebuffer
 
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.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.state - package org.elasticsearch.action.admin.cluster.state
 
org.elasticsearch.action.admin.cluster.support - package org.elasticsearch.action.admin.cluster.support
 
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.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 - package org.elasticsearch.action.admin.indices.exists
 
org.elasticsearch.action.admin.indices.flush - package org.elasticsearch.action.admin.indices.flush
Flush index/indices action.
org.elasticsearch.action.admin.indices.gateway - package org.elasticsearch.action.admin.indices.gateway
Indices Gateway Administrative Actions.
org.elasticsearch.action.admin.indices.gateway.snapshot - package org.elasticsearch.action.admin.indices.gateway.snapshot
GAteway Snapshot Action.
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.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.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 - package org.elasticsearch.action.admin.indices.settings
 
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.support - package org.elasticsearch.action.admin.indices.support
 
org.elasticsearch.action.admin.indices.template.delete - package org.elasticsearch.action.admin.indices.template.delete
 
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.delete - package org.elasticsearch.action.admin.indices.warmer.delete
 
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.delete.index - package org.elasticsearch.action.delete.index
 
org.elasticsearch.action.deletebyquery - package org.elasticsearch.action.deletebyquery
Delete by query 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.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.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.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.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 - package org.elasticsearch.cache
 
org.elasticsearch.cache.memory - package org.elasticsearch.cache.memory
 
org.elasticsearch.client - package org.elasticsearch.client
The client module allowing to easily perform actions/operations.
org.elasticsearch.client.internal - package org.elasticsearch.client.internal
 
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.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.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.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.bloom - package org.elasticsearch.common.bloom
 
org.elasticsearch.common.bytes - package org.elasticsearch.common.bytes
 
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.bzip2 - package org.elasticsearch.common.compress.bzip2
 
org.elasticsearch.common.compress.lzf - package org.elasticsearch.common.compress.lzf
 
org.elasticsearch.common.compress.snappy - package org.elasticsearch.common.compress.snappy
 
org.elasticsearch.common.compress.snappy.xerial - package org.elasticsearch.common.compress.snappy.xerial
 
org.elasticsearch.common.geo - package org.elasticsearch.common.geo
 
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.lab - package org.elasticsearch.common.lab
 
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.document - package org.elasticsearch.common.lucene.document
 
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.search.vectorhighlight - package org.elasticsearch.common.lucene.search.vectorhighlight
 
org.elasticsearch.common.lucene.spatial - package org.elasticsearch.common.lucene.spatial
 
org.elasticsearch.common.lucene.spatial.prefix - package org.elasticsearch.common.lucene.spatial.prefix
 
org.elasticsearch.common.lucene.spatial.prefix.tree - package org.elasticsearch.common.lucene.spatial.prefix.tree
 
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.regex - package org.elasticsearch.common.regex
 
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.trove - package org.elasticsearch.common.trove
 
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.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.blobstore - package org.elasticsearch.gateway.blobstore
 
org.elasticsearch.gateway.fs - package org.elasticsearch.gateway.fs
 
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.gateway.shared - package org.elasticsearch.gateway.shared
 
org.elasticsearch.http - package org.elasticsearch.http
 
org.elasticsearch.http.netty - package org.elasticsearch.http.netty
 
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.bloom - package org.elasticsearch.index.cache.bloom
 
org.elasticsearch.index.cache.bloom.none - package org.elasticsearch.index.cache.bloom.none
 
org.elasticsearch.index.cache.bloom.simple - package org.elasticsearch.index.cache.bloom.simple
 
org.elasticsearch.index.cache.field.data - package org.elasticsearch.index.cache.field.data
 
org.elasticsearch.index.cache.field.data.none - package org.elasticsearch.index.cache.field.data.none
 
org.elasticsearch.index.cache.field.data.resident - package org.elasticsearch.index.cache.field.data.resident
 
org.elasticsearch.index.cache.field.data.soft - package org.elasticsearch.index.cache.field.data.soft
 
org.elasticsearch.index.cache.field.data.support - package org.elasticsearch.index.cache.field.data.support
 
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.id - package org.elasticsearch.index.cache.id
 
org.elasticsearch.index.cache.id.simple - package org.elasticsearch.index.cache.id.simple
 
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.cache.query.parser.support - package org.elasticsearch.index.cache.query.parser.support
 
org.elasticsearch.index.deletionpolicy - package org.elasticsearch.index.deletionpolicy
 
org.elasticsearch.index.engine - package org.elasticsearch.index.engine
 
org.elasticsearch.index.engine.robin - package org.elasticsearch.index.engine.robin
 
org.elasticsearch.index.field.data - package org.elasticsearch.index.field.data
 
org.elasticsearch.index.field.data.bytes - package org.elasticsearch.index.field.data.bytes
 
org.elasticsearch.index.field.data.doubles - package org.elasticsearch.index.field.data.doubles
 
org.elasticsearch.index.field.data.floats - package org.elasticsearch.index.field.data.floats
 
org.elasticsearch.index.field.data.ints - package org.elasticsearch.index.field.data.ints
 
org.elasticsearch.index.field.data.longs - package org.elasticsearch.index.field.data.longs
 
org.elasticsearch.index.field.data.shorts - package org.elasticsearch.index.field.data.shorts
 
org.elasticsearch.index.field.data.strings - package org.elasticsearch.index.field.data.strings
 
org.elasticsearch.index.field.data.support - package org.elasticsearch.index.field.data.support
 
org.elasticsearch.index.field.function.sort - package org.elasticsearch.index.field.function.sort
 
org.elasticsearch.index.flush - package org.elasticsearch.index.flush
 
org.elasticsearch.index.gateway - package org.elasticsearch.index.gateway
 
org.elasticsearch.index.gateway.blobstore - package org.elasticsearch.index.gateway.blobstore
 
org.elasticsearch.index.gateway.fs - package org.elasticsearch.index.gateway.fs
 
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.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.multifield - package org.elasticsearch.index.mapper.multifield
 
org.elasticsearch.index.mapper.object - package org.elasticsearch.index.mapper.object
 
org.elasticsearch.index.mapper.selector - package org.elasticsearch.index.mapper.selector
 
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.query - package org.elasticsearch.index.query
 
org.elasticsearch.index.query.support - package org.elasticsearch.index.query.support
 
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.nested - package org.elasticsearch.index.search.nested
 
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.service - package org.elasticsearch.index.service
 
org.elasticsearch.index.settings - package org.elasticsearch.index.settings
 
org.elasticsearch.index.shard - package org.elasticsearch.index.shard
 
org.elasticsearch.index.shard.service - package org.elasticsearch.index.shard.service
 
org.elasticsearch.index.similarity - package org.elasticsearch.index.similarity
 
org.elasticsearch.index.store - package org.elasticsearch.index.store
 
org.elasticsearch.index.store.fs - package org.elasticsearch.index.store.fs
 
org.elasticsearch.index.store.memory - package org.elasticsearch.index.store.memory
 
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.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.cache.filter - package org.elasticsearch.indices.cache.filter
 
org.elasticsearch.indices.cluster - package org.elasticsearch.indices.cluster
 
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.indices.warmer - package org.elasticsearch.indices.warmer
 
org.elasticsearch.jmx - package org.elasticsearch.jmx
 
org.elasticsearch.jmx.action - package org.elasticsearch.jmx.action
 
org.elasticsearch.monitor - package org.elasticsearch.monitor
 
org.elasticsearch.monitor.dump - package org.elasticsearch.monitor.dump
 
org.elasticsearch.monitor.dump.cluster - package org.elasticsearch.monitor.dump.cluster
 
org.elasticsearch.monitor.dump.heap - package org.elasticsearch.monitor.dump.heap
 
org.elasticsearch.monitor.dump.summary - package org.elasticsearch.monitor.dump.summary
 
org.elasticsearch.monitor.dump.thread - package org.elasticsearch.monitor.dump.thread
 
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.monitor.sigar - package org.elasticsearch.monitor.sigar
 
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.plugins - package org.elasticsearch.plugins
 
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.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.state - package org.elasticsearch.rest.action.admin.cluster.state
 
org.elasticsearch.rest.action.admin.indices.alias - package org.elasticsearch.rest.action.admin.indices.alias
 
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 - package org.elasticsearch.rest.action.admin.indices.exists
 
org.elasticsearch.rest.action.admin.indices.flush - package org.elasticsearch.rest.action.admin.indices.flush
 
org.elasticsearch.rest.action.admin.indices.gateway.snapshot - package org.elasticsearch.rest.action.admin.indices.gateway.snapshot
 
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.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.put - package org.elasticsearch.rest.action.admin.indices.template.put
 
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.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.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.search - package org.elasticsearch.rest.action.search
 
org.elasticsearch.rest.action.support - package org.elasticsearch.rest.action.support
 
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.mvel - package org.elasticsearch.script.mvel
 
org.elasticsearch.search - package org.elasticsearch.search
 
org.elasticsearch.search.action - package org.elasticsearch.search.action
 
org.elasticsearch.search.builder - package org.elasticsearch.search.builder
 
org.elasticsearch.search.controller - package org.elasticsearch.search.controller
 
org.elasticsearch.search.count - package org.elasticsearch.search.count
 
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.histogram.bounded - package org.elasticsearch.search.facet.histogram.bounded
 
org.elasticsearch.search.facet.histogram.unbounded - package org.elasticsearch.search.facet.histogram.unbounded
 
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.bytes - package org.elasticsearch.search.facet.terms.bytes
 
org.elasticsearch.search.facet.terms.doubles - package org.elasticsearch.search.facet.terms.doubles
 
org.elasticsearch.search.facet.terms.floats - package org.elasticsearch.search.facet.terms.floats
 
org.elasticsearch.search.facet.terms.index - package org.elasticsearch.search.facet.terms.index
 
org.elasticsearch.search.facet.terms.ints - package org.elasticsearch.search.facet.terms.ints
 
org.elasticsearch.search.facet.terms.ip - package org.elasticsearch.search.facet.terms.ip
 
org.elasticsearch.search.facet.terms.longs - package org.elasticsearch.search.facet.terms.longs
 
org.elasticsearch.search.facet.terms.shorts - package org.elasticsearch.search.facet.terms.shorts
 
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.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.matchedfilters - package org.elasticsearch.search.fetch.matchedfilters
 
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.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.scan - package org.elasticsearch.search.scan
 
org.elasticsearch.search.sort - package org.elasticsearch.search.sort
 
org.elasticsearch.search.warmer - package org.elasticsearch.search.warmer
 
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.joda.time.base - package org.joda.time.base
 
origin(Engine.Operation.Origin) - Method in class org.elasticsearch.index.engine.Engine.Create
 
origin() - Method in class org.elasticsearch.index.engine.Engine.Create
 
origin(Engine.Operation.Origin) - Method in class org.elasticsearch.index.engine.Engine.Delete
 
origin() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
origin(Engine.Operation.Origin) - Method in class org.elasticsearch.index.engine.Engine.Index
 
origin() - Method in class org.elasticsearch.index.engine.Engine.Index
 
origin() - Method in interface org.elasticsearch.index.engine.Engine.Operation
 
os() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
Operating System level information.
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() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
Operating System level statistics.
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() - Method in class org.elasticsearch.monitor.os.SigarOsProbe
 
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() - 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() - Method in class org.elasticsearch.monitor.os.SigarOsProbe
 
OsStats.Cpu - Class in org.elasticsearch.monitor.os
 
OsStats.Mem - Class in org.elasticsearch.monitor.os
 
OsStats.Mem() - Constructor for class org.elasticsearch.monitor.os.OsStats.Mem
 
OsStats.Swap - Class in org.elasticsearch.monitor.os
 
OsStats.Swap() - Constructor for class org.elasticsearch.monitor.os.OsStats.Swap
 
OsUtils - Class in org.elasticsearch.common.os
 
otherCount() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
otherCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
otherCount() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
otherCount() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
otherCount() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
otherCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
otherCount() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
otherCount() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
otherCount() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet
The count of terms other than the one provided by the entries.
out - Variable in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
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.
oversize(int, int) - Static method in class org.elasticsearch.common.Bytes
Returns an array size >= minTargetSize, generally over-allocating exponentially to achieve amortized linear-time cost as the array grows.

P

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.CustomFiltersScoreQueryBuilder
Additional parameters that can be provided to the script.
param(String, Object) - Method in class org.elasticsearch.index.query.CustomScoreQueryBuilder
Additional parameters that can be provided to the script.
param(String) - Method in interface org.elasticsearch.rest.RestRequest
 
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.MapParams
 
paramAsBoolean(String, boolean) - Method in interface org.elasticsearch.common.xcontent.ToXContent.Params
 
paramAsBoolean(String, boolean) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsBoolean(String, boolean) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
paramAsBooleanOptional(String, Boolean) - Method in class org.elasticsearch.common.xcontent.ToXContent.MapParams
 
paramAsBooleanOptional(String, Boolean) - Method in interface org.elasticsearch.common.xcontent.ToXContent.Params
 
paramAsBooleanOptional(String, Boolean) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsBooleanOptional(String, Boolean) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
paramAsFloat(String, float) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsFloat(String, float) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
paramAsInt(String, int) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsInt(String, int) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
paramAsLong(String, long) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsLong(String, long) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
paramAsSize(String, ByteSizeValue) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsSize(String, ByteSizeValue) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
paramAsStringArray(String, String[]) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsStringArray(String, String[]) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
paramAsTime(String, TimeValue) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsTime(String, TimeValue) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
params() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
params(Map<String, Object>) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
Additional parameters that can be provided to the script.
params(Map<String, Object>) - Method in class org.elasticsearch.index.query.CustomScoreQueryBuilder
Additional parameters that can be provided to the script.
params(Map<String, Object>) - Method in class org.elasticsearch.index.query.ScriptFilterBuilder
 
params() - Method in interface org.elasticsearch.rest.RestRequest
 
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.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.update.UpdateRequest
Sets the parent id of this document.
parent() - Method in class org.elasticsearch.index.engine.Engine.Create
 
parent() - Method in class org.elasticsearch.index.engine.Engine.Index
 
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
 
parentDocs() - Method in class org.elasticsearch.index.search.child.ChildCollector
 
parentFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
ParentFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
ParentFieldMapper(String, String, String) - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
ParentFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
ParentFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Builder
 
ParentFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
ParentFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper.Defaults
 
ParentFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
ParentFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.ParentFieldMapper.TypeParser
 
parentIdByDoc(String, int) - Method in interface org.elasticsearch.index.cache.id.IdReaderCache
 
parentIdByDoc(int) - Method in interface org.elasticsearch.index.cache.id.IdReaderTypeCache
 
parentIdByDoc(String, int) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderCache
 
parentIdByDoc(int) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderTypeCache
 
parse(XContentParser, MappingMetaData.ParseContext) - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
 
parse(XContentParser) - Static method in class org.elasticsearch.common.geo.GeoJSONShapeParser
Parses the current object from the given XContentParser, creating the Shape representation
parse(String, long) - Method in class org.elasticsearch.common.joda.DateMathParser
 
parse(String, long, boolean, boolean) - Method in class org.elasticsearch.common.joda.DateMathParser
 
parse(String, DistanceUnit, DistanceUnit) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
 
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(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper.TypeParser
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.TypeParser
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.TypeParser
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.TypeParser
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.TypeParser
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper.TypeParser
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.TypeParser
 
parse(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(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(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.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(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, String) - Method in class org.elasticsearch.index.mapper.MapperService
Just parses and returns the mapper without adding it.
parse(ParseContext) - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
parse(String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper.TypeParser
 
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(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.ConstantScoreQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.CustomBoostFactorQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.CustomScoreQueryParser
 
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.FieldQueryParser
 
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) - 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.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.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(String) - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
parse(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
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryParser
 
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
 
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.ScriptFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.SpanFirstQueryParser
 
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.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, String) - Method in class org.elasticsearch.index.search.MatchQuery
 
parse(MatchQuery.Type, List<String>, String) - Method in class org.elasticsearch.index.search.MultiMatchQuery
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.index.search.stats.StatsGroupsParseElement
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetProcessor
 
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.FacetProcessor
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.filter.FilterFacetProcessor
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetProcessor
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetProcessor
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.query.QueryFacetProcessor
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.range.RangeFacetProcessor
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetProcessor
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.terms.TermsFacetProcessor
 
parse(String, XContentParser, SearchContext) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetProcessor
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.explain.ExplainParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.FieldsParseElement
 
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.version.VersionParseElement
 
parse(XContentParser, SearchContext) - 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.FilterParseElement
 
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.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.TimeoutParseElement
 
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_UPPER_INCLUSIVE - Static variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
 
parseArticles(Environment, Settings, Version) - Static method in class org.elasticsearch.index.analysis.Analysis
 
parseBoolean(char[], int, int, boolean) - Static method in class org.elasticsearch.common.Booleans
 
parseBoolean(String, boolean) - Static method in class org.elasticsearch.common.Booleans
 
parseBoolean(String, Boolean) - 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
 
ParseContext - Class in org.elasticsearch.index.mapper
 
ParseContext(String, Settings, DocumentMapperParser, DocumentMapper, ContentPath) - Constructor for class org.elasticsearch.index.mapper.ParseContext
 
parseContext - Variable in class org.elasticsearch.index.search.MatchQuery
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
parseDateTimeFormatter(String, Object) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parsedDoc() - Method in class org.elasticsearch.index.engine.Engine.Create
 
parsedDoc() - Method in class org.elasticsearch.index.engine.Engine.Index
 
parsedDoc() - Method in interface org.elasticsearch.index.engine.Engine.IndexingOperation
 
ParsedDocument - Class in org.elasticsearch.index.mapper
The result of parsing a document.
ParsedDocument(String, String, String, String, long, long, Document, Analyzer, BytesReference, boolean) - Constructor for class org.elasticsearch.index.mapper.ParsedDocument
 
ParsedDocument(String, String, String, String, long, long, List<Document>, Analyzer, BytesReference, boolean) - Constructor for class org.elasticsearch.index.mapper.ParsedDocument
 
parsedFilter() - Method in class org.elasticsearch.index.aliases.IndexAlias
 
parsedFilter(Filter) - Method in class org.elasticsearch.search.internal.SearchContext
 
parsedFilter() - Method in class org.elasticsearch.search.internal.SearchContext
 
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(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
 
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.matchedfilters.MatchedFiltersFetchSubPhase
 
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.version.VersionFetchSubPhase
 
parseElements() - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
parseElements() - Method in class org.elasticsearch.search.query.QueryPhase
 
parseElements() - Method in interface org.elasticsearch.search.SearchPhase
 
parseField(AbstractFieldMapper.Builder, String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parseFuzzyFactor(String) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
parseFuzzyFactor(String) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
parseIndex(String, String) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parseInnerFilter(XContentParser) - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
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() - Method in class org.elasticsearch.index.query.QueryParseContext
 
parseLocaleString(String) - Static method in class org.elasticsearch.common.Strings
Parse the given localeString into a Locale.
parseNumberField(NumberFieldMapper.Builder, String, Map<String, Object>, Mapper.TypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parsePathType(String, String) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parseQuery(String, BytesReference) - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
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
 
parser() - Method in class org.elasticsearch.index.mapper.SourceToParse
 
parser() - Method in class org.elasticsearch.index.query.QueryParseContext
 
parserContext() - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
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
 
parseSizeValue(String) - Static method in class org.elasticsearch.common.unit.SizeValue
 
parseSizeValue(String, SizeValue) - Static method in class org.elasticsearch.common.unit.SizeValue
 
parseStemExclusion(Settings, Set<?>) - Static method in class org.elasticsearch.index.analysis.Analysis
 
parseStopWords(Environment, Settings, Set<?>, Version) - Static method in class org.elasticsearch.index.analysis.Analysis
 
parseStore(String, String) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
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
 
parseTermVector(String, String) - Static method in class org.elasticsearch.index.mapper.core.TypeParsers
 
parseTimeValue(String, TimeValue) - Static method in class org.elasticsearch.common.unit.TimeValue
 
parseUnit(String, DistanceUnit) - Static method in enum org.elasticsearch.common.unit.DistanceUnit
 
parseUpperInclusive(String, long) - Method in class org.elasticsearch.common.joda.DateMathParser
 
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
 
parsingStillNeeded() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
Is parsing still needed?
partialField(String, String, String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Adds a partial field based on _source, with an "include" and/or "exclude" set which can include simple wildcard elements.
partialField(String, String[], String[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Adds a partial field based on _source, with an "includes" and/or "excludes set which can include simple wildcard elements.
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
 
PartialFieldsContext.PartialField(String, String[], String[]) - Constructor for class org.elasticsearch.search.fetch.partial.PartialFieldsContext.PartialField
 
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
 
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.AbstractFsBlobContainer
 
path() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
 
path() - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
 
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
 
path() - Method in interface org.elasticsearch.rest.RestRequest
The path part of the URI (without the query string), decoded.
path() - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
PATH_TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
PATH_TYPE - Static variable in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper.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
 
pathEquals(String, String) - Static method in class org.elasticsearch.common.Strings
Compare two paths after normalization of them.
PathHierarchyTokenizerFactory - Class in org.elasticsearch.index.analysis
 
PathHierarchyTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PathHierarchyTokenizerFactory
 
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
 
PathTrie.TrieNode(String, T, PathTrie.TrieNode, String) - Constructor for class org.elasticsearch.common.path.PathTrie.TrieNode
 
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.geo.GeoPointFieldMapper.Builder
 
pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper.Builder
 
pathType() - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
pathType - Variable in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.Builder
 
PatternAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
PatternAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternAnalyzerProvider
 
PatternReplaceFilter - Class in org.apache.lucene.analysis.pattern
A TokenFilter which applies a Pattern to each token in the stream, replacing match occurances with the specified replacement string.
PatternReplaceFilter(TokenStream, Pattern, String, boolean) - Constructor for class org.apache.lucene.analysis.pattern.PatternReplaceFilter
Constructs an instance to replace either the first, or all occurances
PatternReplaceTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
PatternReplaceTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternReplaceTokenFilterFactory
 
PatternTokenizer - Class in org.apache.lucene.analysis.pattern
This tokenizer uses regex pattern matching to construct distinct tokens for the input stream.
PatternTokenizer(Reader, Pattern, int) - Constructor for class org.apache.lucene.analysis.pattern.PatternTokenizer
creates a new PatternTokenizer returning tokens from group (-1 for split functionality)
PatternTokenizerFactory - Class in org.elasticsearch.index.analysis
 
PatternTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PatternTokenizerFactory
 
pause(long) - Method in class org.elasticsearch.common.RateLimiter
Pauses, if necessary, to keep the instantaneous IO rate at or below the target.
payload() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryResponse
 
payload - Variable in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
payload() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
payloadScore - Variable in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
payloadsSeen - Variable in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
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 jsr166y.ConcurrentLinkedDeque
 
peek() - Method in class jsr166y.LinkedTransferQueue
 
peekFirst() - Method in class jsr166y.ConcurrentLinkedDeque
 
peekLast() - Method in class jsr166y.ConcurrentLinkedDeque
 
peekNextLocalTask() - Static method in class jsr166y.ForkJoinTask
Returns, but does not unschedule or execute, a task queued by the current thread but not yet executed, if one is immediately available.
PeerRecoveryStatus - Class in org.elasticsearch.action.admin.indices.status
 
PeerRecoveryStatus(PeerRecoveryStatus.Stage, long, long, long, long, long, long) - Constructor for class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
peerRecoveryStatus() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Peer recovery status (null if not applicable).
peerRecoveryStatus() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
The peer recovery status if this shard recovered from a peer shard.
peerRecoveryStatus(ShardId) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
 
PeerRecoveryStatus.Stage - Enum in org.elasticsearch.action.admin.indices.status
 
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.
percentTermsToMatch(float) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The percent of the terms to match for each field.
percentTermsToMatch() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The percent of the terms to match for each field.
percentTermsToMatch(float) - Method in class org.elasticsearch.index.query.MoreLikeThisFieldQueryBuilder
The percentage of terms to match.
percentTermsToMatch(float) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
The percentage of terms to match.
percolate(String) - Method in class org.elasticsearch.action.index.IndexRequest
Causes the index request document to be percolated.
percolate() - Method in class org.elasticsearch.action.index.IndexRequest
 
percolate(String) - Method in class org.elasticsearch.action.update.UpdateRequest
Causes the update request document to be percolated.
percolate() - Method in class org.elasticsearch.action.update.UpdateRequest
 
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(PercolatorExecutor.SourceRequest) - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
percolate(PercolatorExecutor.DocAndSourceQueryRequest) - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
percolate(PercolatorExecutor.SourceRequest) - Method in class org.elasticsearch.index.percolator.PercolatorService
 
percolate(PercolatorExecutor.DocAndSourceQueryRequest) - Method in class org.elasticsearch.index.percolator.PercolatorService
 
PERCOLATE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
PercolateAction - Class in org.elasticsearch.action.percolate
 
PercolateIndexUnavailable - Exception in org.elasticsearch.index.percolator
 
PercolateIndexUnavailable(Index) - Constructor for exception org.elasticsearch.index.percolator.PercolateIndexUnavailable
 
PercolateRequest - Class in org.elasticsearch.action.percolate
 
PercolateRequest() - Constructor for class org.elasticsearch.action.percolate.PercolateRequest
 
PercolateRequest(String, String) - Constructor for class org.elasticsearch.action.percolate.PercolateRequest
Constructs a new percolate request.
PercolateRequestBuilder - Class in org.elasticsearch.action.percolate
 
PercolateRequestBuilder(Client) - Constructor for class org.elasticsearch.action.percolate.PercolateRequestBuilder
 
PercolateRequestBuilder(Client, String, String) - Constructor for class org.elasticsearch.action.percolate.PercolateRequestBuilder
 
PercolateResponse - Class in org.elasticsearch.action.percolate
 
PercolateResponse(List<String>) - Constructor for class org.elasticsearch.action.percolate.PercolateResponse
 
percolateService() - Method in interface org.elasticsearch.index.service.IndexService
 
percolateService() - Method in class org.elasticsearch.index.service.InternalIndexService
 
PercolatorException - Exception in org.elasticsearch.index.percolator
 
PercolatorException(Index, String) - Constructor for exception org.elasticsearch.index.percolator.PercolatorException
 
PercolatorException(Index, String, Throwable) - Constructor for exception org.elasticsearch.index.percolator.PercolatorException
 
PercolatorExecutor - Class in org.elasticsearch.index.percolator
 
PercolatorExecutor(Index, Settings, MapperService, IndexQueryParserService, IndexCache) - Constructor for class org.elasticsearch.index.percolator.PercolatorExecutor
 
PercolatorExecutor.DocAndQueryRequest - Class in org.elasticsearch.index.percolator
 
PercolatorExecutor.DocAndQueryRequest(ParsedDocument, Query) - Constructor for class org.elasticsearch.index.percolator.PercolatorExecutor.DocAndQueryRequest
 
PercolatorExecutor.DocAndSourceQueryRequest - Class in org.elasticsearch.index.percolator
 
PercolatorExecutor.DocAndSourceQueryRequest(ParsedDocument, String) - Constructor for class org.elasticsearch.index.percolator.PercolatorExecutor.DocAndSourceQueryRequest
 
PercolatorExecutor.Response - Class in org.elasticsearch.index.percolator
 
PercolatorExecutor.Response(List<String>, boolean) - Constructor for class org.elasticsearch.index.percolator.PercolatorExecutor.Response
 
PercolatorExecutor.SourceRequest - Class in org.elasticsearch.index.percolator
 
PercolatorExecutor.SourceRequest(String, BytesReference) - Constructor for class org.elasticsearch.index.percolator.PercolatorExecutor.SourceRequest
 
PercolatorModule - Class in org.elasticsearch.index.percolator
 
PercolatorModule() - Constructor for class org.elasticsearch.index.percolator.PercolatorModule
 
PercolatorService - Class in org.elasticsearch.index.percolator
 
PercolatorService(Index, Settings, IndicesService, PercolatorExecutor) - Constructor for class org.elasticsearch.index.percolator.PercolatorService
 
performRecoveryFinalization(boolean, RecoveryStatus) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
performRecoveryFinalization(boolean) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
performRecoveryOperation(Translog.Operation) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
performRecoveryPrepareForTranslog() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
After the store has been recovered, we need to start the engine in order to apply operations
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
 
performStateRecovery(Gateway.GatewayStateRecoveredListener) - Method in class org.elasticsearch.gateway.shared.SharedStorageGateway
 
PersianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
PersianAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PersianAnalyzerProvider
 
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.memory.ByteBufferIndexStore
 
persistent() - Method in class org.elasticsearch.index.store.ram.RamIndexStore
 
persistentSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
persistentSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
persistentSettings(String) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
persistentSettings(Map) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
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
 
phase() - Method in exception org.elasticsearch.index.engine.RecoveryEngineException
 
phase1(SnapshotIndexCommit) - Method in interface org.elasticsearch.index.engine.Engine.RecoveryHandler
 
phase1ExistingTotalSize() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
phase1TotalSize() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
phase2(Translog.Snapshot) - Method in interface org.elasticsearch.index.engine.Engine.RecoveryHandler
 
phase3(Translog.Snapshot) - Method in interface org.elasticsearch.index.engine.Engine.RecoveryHandler
 
phaseName() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
 
Phaser - Class in jsr166y
A reusable synchronization barrier, similar in functionality to CyclicBarrier and CountDownLatch but supporting more flexible usage.
Phaser() - Constructor for class jsr166y.Phaser
Creates a new phaser with no initially registered parties, no parent, and initial phase number 0.
Phaser(int) - Constructor for class jsr166y.Phaser
Creates a new phaser with the given number of registered unarrived parties, no parent, and initial phase number 0.
Phaser(Phaser) - Constructor for class jsr166y.Phaser
Equivalent to Phaser(parent, 0).
Phaser(Phaser, int) - Constructor for class jsr166y.Phaser
Creates a new phaser with the given parent and number of registered unarrived parties.
phraseSlop() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
phraseSlop(int) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
phraseSlop(int) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
Sets the default slop for phrases.
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
 
physicalName() - Method in class org.elasticsearch.index.gateway.CommitPoint.FileInfo
 
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
 
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
 
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
 
PlainByteBufferAllocator - Class in org.apache.lucene.store.bytebuffer
A simple byte buffer allocator that does not caching.
PlainByteBufferAllocator(boolean, int, int) - Constructor for class org.apache.lucene.store.bytebuffer.PlainByteBufferAllocator
Constructs a new plain byte buffer allocator that does no caching.
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
 
PlainShardIterator(ShardId, List<ShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.PlainShardIterator
 
PlainShardIterator(ShardId, List<ShardRouting>, int) - Constructor for class org.elasticsearch.cluster.routing.PlainShardIterator
 
PlainShardsIterator - Class in org.elasticsearch.cluster.routing
 
PlainShardsIterator(List<ShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.PlainShardsIterator
 
PlainShardsIterator(List<ShardRouting>, int) - Constructor for class org.elasticsearch.cluster.routing.PlainShardsIterator
 
PlainTransportFuture<V extends Streamable> - Class in org.elasticsearch.transport
 
PlainTransportFuture(TransportResponseHandler<V>) - Constructor for class org.elasticsearch.transport.PlainTransportFuture
 
Plugin - Interface in org.elasticsearch.plugins
An extension point allowing to plug in custom functionality.
PluginManager - Class in org.elasticsearch.plugins
 
PluginManager(Environment, String) - Constructor for class org.elasticsearch.plugins.PluginManager
 
plugins() - Method in class org.elasticsearch.plugins.PluginsService
 
pluginsFile() - Method in class org.elasticsearch.env.Environment
 
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.ShapeBuilder.PolygonBuilder
Adds a point to the Polygon
point(double, double) - Method in class org.elasticsearch.index.query.GeoDistanceFilterBuilder
 
point(double, double) - Method in class org.elasticsearch.index.query.GeoDistanceRangeFilterBuilder
 
Point - Class in org.elasticsearch.index.search.geo
 
Point() - Constructor for class org.elasticsearch.index.search.geo.Point
 
Point(double, double) - Constructor for class org.elasticsearch.index.search.geo.Point
 
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.
points() - Method in class org.elasticsearch.index.search.geo.GeoPolygonFilter
 
poll() - Method in class jsr166y.ConcurrentLinkedDeque
 
poll(long, TimeUnit) - Method in class jsr166y.LinkedTransferQueue
 
poll() - Method in class jsr166y.LinkedTransferQueue
 
pollFirst() - Method in class jsr166y.ConcurrentLinkedDeque
 
pollLast() - Method in class jsr166y.ConcurrentLinkedDeque
 
pollNextLocalTask() - Static method in class jsr166y.ForkJoinTask
Unschedules and returns, without executing, the next task queued by the current thread but not yet executed.
pollSubmission() - Method in class jsr166y.ForkJoinPool
Removes and returns the next unexecuted submission if one is available.
pollTask() - Static method in class jsr166y.ForkJoinTask
Unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if one is available, or if not available, a task that was forked by some other thread, if available.
pop() - Method in class jsr166y.ConcurrentLinkedDeque
 
popByteIntMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popCachedStream() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
popDoubleIntMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popDoubleObjectMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popEntry() - Static method in class org.elasticsearch.common.io.stream.CachedStreamOutput
 
popFloatIntMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popHashMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popIntArray(int) - Static method in class org.elasticsearch.common.CacheRecycler
 
popIntArray(int, int) - Static method in class org.elasticsearch.common.CacheRecycler
 
popIntIntMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popLongIntMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popLongLongMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popLongObjectMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popObjectArray(int) - Static method in class org.elasticsearch.common.CacheRecycler
 
popObjectIntMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
popShortIntMap() - Static method in class org.elasticsearch.common.CacheRecycler
 
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.FastByteArrayInputStream
The index of the next character to read from the input stream buffer.
pos - Variable in class org.elasticsearch.common.io.FastCharArrayReader
The current buffer position.
pos - Variable in class org.elasticsearch.common.io.stream.BytesStreamInput
 
position() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
position - Variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
position() - Method in class org.elasticsearch.common.io.FastByteArrayInputStream
 
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
 
POSITION_OFFSET_GAP - Static variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
 
positionOffsetGap - Variable in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
positionOffsetGap(int) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
positions - Variable in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
positive(QueryBuilder) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
 
possibleMergeNeeded() - Method in interface org.elasticsearch.index.engine.Engine
Returns true if a possible merge is really needed.
possibleMergeNeeded() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
postAdded() - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
 
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
 
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
 
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
 
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
 
postOffset(long) - Method in class org.elasticsearch.common.joda.TimeZoneRounding.Builder
 
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.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 interface org.elasticsearch.index.mapper.RootMapper
 
postPrimaryOperation(BulkShardRequest, TransportShardReplicationOperationAction.PrimaryResponse<BulkShardResponse, BulkShardRequest>) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
postPrimaryOperation(IndexRequest, TransportShardReplicationOperationAction.PrimaryResponse<IndexResponse, IndexRequest>) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
postPrimaryOperation(Request, TransportShardReplicationOperationAction.PrimaryResponse<Response, ReplicaRequest>) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
Called once replica operations have been dispatched on the
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.Field
 
postTags(String[]) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
postZone(DateTimeZone) - Method in class org.elasticsearch.common.joda.TimeZoneRounding.Builder
 
postZone(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Sets the post time zone to use when bucketing the values.
pow(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Raise an int to an int power.
pow(int, long) - Static method in class org.elasticsearch.common.math.MathUtils
Raise an int to a long power.
pow(long, int) - Static method in class org.elasticsearch.common.math.MathUtils
Raise a long to an int power.
pow(long, long) - Static method in class org.elasticsearch.common.math.MathUtils
Raise a long to a long power.
pow(BigInteger, int) - Static method in class org.elasticsearch.common.math.MathUtils
Raise a BigInteger to an int power.
pow(BigInteger, long) - Static method in class org.elasticsearch.common.math.MathUtils
Raise a BigInteger to a long power.
pow(BigInteger, BigInteger) - Static method in class org.elasticsearch.common.math.MathUtils
Raise a BigInteger to a BigInteger power.
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
 
PreBuiltAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Class in org.elasticsearch.index.analysis
 
PreBuiltAnalyzerProvider(String, AnalyzerScope, T) - 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
 
PreBuiltAnalyzerProviderFactory(PreBuiltAnalyzerProvider<Analyzer>) - Constructor for class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
 
PreBuiltCharFilterFactoryFactory - Class in org.elasticsearch.index.analysis
 
PreBuiltCharFilterFactoryFactory(CharFilterFactory) - Constructor for class org.elasticsearch.index.analysis.PreBuiltCharFilterFactoryFactory
 
PreBuiltTokenFilterFactoryFactory - Class in org.elasticsearch.index.analysis
 
PreBuiltTokenFilterFactoryFactory(TokenFilterFactory) - Constructor for class org.elasticsearch.index.analysis.PreBuiltTokenFilterFactoryFactory
 
PreBuiltTokenizerFactoryFactory - Class in org.elasticsearch.index.analysis
 
PreBuiltTokenizerFactoryFactory(TokenizerFactory) - Constructor for class org.elasticsearch.index.analysis.PreBuiltTokenizerFactoryFactory
 
precision(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
PRECISION - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
PRECISION - Static variable in class org.elasticsearch.index.search.geo.GeoHashUtils
 
PRECISION_STEP - Static variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Defaults
 
precisionStep - Variable in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
 
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
 
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
 
preferAttributesActiveShardsIt(String[], DiscoveryNodes) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
preferAttributesActiveShardsIt(String[], DiscoveryNodes, int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
preference() - Method in class org.elasticsearch.action.explain.ExplainRequest
 
preference(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
preference - Variable in class org.elasticsearch.action.get.GetRequest
 
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(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
 
preferLocal(boolean) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequest
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.
preferLocal(boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequest
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.
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.
preferNodeActiveShardsIt(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Prefers execution on the provided node if applicable.
preferNodeAssignedShardsIt(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Prefers execution on the provided node if applicable.
preferNodeShardsIt(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
Prefers execution on the provided node if applicable.
PREFERRED_ENCODING - Static variable in class org.elasticsearch.common.Base64
Preferred encoding.
prefixContent() - Method in class org.elasticsearch.rest.AbstractRestResponse
 
prefixContent() - Method in interface org.elasticsearch.rest.RestResponse
 
prefixContent() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
prefixContent() - Method in class org.elasticsearch.rest.XContentRestResponse
 
prefixContentLength() - Method in class org.elasticsearch.rest.AbstractRestResponse
 
prefixContentLength() - Method in interface org.elasticsearch.rest.RestResponse
 
prefixContentLength() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
prefixContentLength() - Method in class org.elasticsearch.rest.XContentRestResponse
 
prefixFilter(String, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
prefixFilter(String, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
prefixFilter(String, 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
 
prefixQuery(String, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
prefixQuery(String, MultiTermQuery.RewriteMethod, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
prefixQuery(String, 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
 
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.joda.TimeZoneRounding.Builder
 
preOffset(TimeValue) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Sets a pre offset that will be applied before rounding the results.
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
 
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
 
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
 
prepareClose(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
Closes an index based on the index name.
prepareClose(String) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
prepareCreate(SourceToParse) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
prepareDelete(String, String, long) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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[], String...) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
prepareDeleteByQuery(BytesReference, String[], String...) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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
 
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>) - Method in interface org.elasticsearch.client.Client
Prepares a request builder to execute, specified by Action.
prepareExecute(ClusterAction<Request, Response, RequestBuilder>) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
prepareExecute(IndicesAction<Request, Response, RequestBuilder>) - Method in interface org.elasticsearch.client.IndicesAdminClient
 
prepareExecute(Action<Request, Response, RequestBuilder>) - Method in class org.elasticsearch.client.support.AbstractClient
 
prepareExecute(ClusterAction<Request, Response, RequestBuilder>) - Method in class org.elasticsearch.client.support.AbstractClusterAdminClient
 
prepareExecute(IndicesAction<Request, Response, RequestBuilder>) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
prepareExists(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices exists.
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
 
prepareGatewaySnapshot(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
Explicitly perform gateway snapshot for one or more indices.
prepareGatewaySnapshot(String...) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
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
 
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) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
prepareIndex(SourceToParse) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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
 
prepareMultiSearch() - Method in interface org.elasticsearch.client.Client
Performs multiple search requests.
prepareMultiSearch() - Method in class org.elasticsearch.client.support.AbstractClient
 
prepareNodesHotThreads(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
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 an index based on the 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
 
preparePercolate(String, String) - Method in interface org.elasticsearch.client.Client
Percolates a request returning the matches documents.
preparePercolate(String, String) - Method in class org.elasticsearch.client.support.AbstractClient
 
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
 
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
 
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
 
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
 
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
 
prepareSettings(Settings, boolean) - Static method in class org.elasticsearch.node.internal.InternalSettingsPerparer
 
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
The status of one or more indices.
prepareStatus(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
 
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.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 interface org.elasticsearch.index.mapper.RootMapper
 
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.SearchContext
Should be called before executing the main query and after all other parameters have been set.
preProcess(SearchContext) - Method in class org.elasticsearch.search.query.QueryPhase
 
preProcess(SearchContext) - Method in interface org.elasticsearch.search.SearchPhase
Performs pre processing of the search context before the execute.
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.
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.Field
 
preTags(String[]) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
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
 
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.joda.TimeZoneRounding.Builder
 
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.joda.TimeZoneRounding.Builder
 
preZoneAdjustLargeInterval(boolean) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Should pre zone be adjusted for large (day and above) intervals.
primaries() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
 
primaries() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
primary() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
 
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
Is this a primary shard.
primary - Variable in class org.elasticsearch.gateway.local.state.shards.ShardStateInfo
 
primaryActive() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
primaryDir() - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
Return the primary directory
primaryExtensions() - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
primaryFirstActiveShardsIt() - 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
 
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
 
primaryShardsUnassigned() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
primaryStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Returns only the primary shards store size in bytes.
primaryStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Returns only the primary shards store size in bytes.
printer() - Method in class org.elasticsearch.common.joda.FormatDateTimeFormatter
 
printInfo() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
println(String) - Method in class org.elasticsearch.common.lucene.LoggerInfoStream
Override only the method Lucene actually uses.
printStackTrace() - Method in exception org.elasticsearch.common.math.MathRuntimeException
Prints the stack trace of this exception to the standard error stream.
printStackTrace(PrintStream) - Method in exception org.elasticsearch.common.math.MathRuntimeException
Prints the stack trace of this exception to the specified stream.
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
 
process() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
Process level information.
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() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
Process level statistics.
process(MetaData, String, MappingMetaData, boolean) - Method in class org.elasticsearch.action.index.IndexRequest
 
process(RestRequest, RestChannel, RestFilterChain) - Method in class org.elasticsearch.rest.RestFilter
Process the rest request.
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
 
processCollector(Collector) - Method in class org.elasticsearch.index.search.child.HasChildFilter
 
processCollector(Collector) - Method in interface org.elasticsearch.search.internal.ScopePhase.CollectorPhase
 
ProcessedClusterStateUpdateTask - Interface in org.elasticsearch.cluster
An extension interface to ClusterStateUpdateTask that allows to be notified when the cluster state update has been processed.
processedScope() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
processField(ObjectMapper.Builder, String, Object) - Method in class org.elasticsearch.index.mapper.object.ObjectMapper.TypeParser
 
processField(ObjectMapper.Builder, String, Object) - Method in class org.elasticsearch.index.mapper.object.RootObjectMapper.TypeParser
 
processFirstPhaseResult(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
 
processInfo() - Method in class org.elasticsearch.monitor.process.SigarProcessProbe
 
processingScope(String) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
processModule(Module) - Method in interface org.elasticsearch.common.inject.PreProcessModule
 
processModule(Module) - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGatewayModule
 
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
 
processor(String) - Method in class org.elasticsearch.search.facet.FacetProcessors
 
processPayload(Similarity) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
ProcessProbe - Interface in org.elasticsearch.monitor.process
 
processResults(TopDocs, SearchContext) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
processResults(TopDocs, SearchContext) - Method in interface org.elasticsearch.search.internal.ScopePhase.TopDocsPhase
 
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
 
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() - Method in class org.elasticsearch.monitor.process.SigarProcessProbe
 
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.
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
 
PublicTermsFilter - Class in org.apache.lucene.search
 
PublicTermsFilter() - Constructor for class org.apache.lucene.search.PublicTermsFilter
 
publish(ClusterState) - 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) - 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) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
publish(ClusterState) - Method in class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
 
publish(ClusterState) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
publish(RiverClusterState) - Method in class org.elasticsearch.river.cluster.PublishRiverClusterStateAction
 
publishAddress() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
 
PublishClusterStateAction - Class in org.elasticsearch.discovery.zen.publish
 
PublishClusterStateAction(Settings, TransportService, DiscoveryNodesProvider, PublishClusterStateAction.NewClusterStateListener) - Constructor for class org.elasticsearch.discovery.zen.publish.PublishClusterStateAction
 
PublishClusterStateAction.NewClusterStateListener - Interface in org.elasticsearch.discovery.zen.publish
 
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
 
publishUrl() - Method in class org.elasticsearch.jmx.JmxService
 
push(E) - Method in class jsr166y.ConcurrentLinkedDeque
 
pushByteIntMap(TByteIntHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushDoubleIntMap(TDoubleIntHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushDoubleObjectMap(ExtTDoubleObjectHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushEntry(CachedStreamOutput.Entry) - Static method in class org.elasticsearch.common.io.stream.CachedStreamOutput
 
pushFloatIntMap(TFloatIntHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushHashMap(ExtTHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushIntArray(int[]) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushIntArray(int[], int) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushIntIntMap(TIntIntHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushLongIntMap(TLongIntHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushLongLongMap(TLongLongHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushLongObjectMap(ExtTLongObjectHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushObjectArray(Object[]) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushObjectIntMap(TObjectIntHashMap<T>) - Static method in class org.elasticsearch.common.CacheRecycler
 
pushShortIntMap(TShortIntHashMap) - Static method in class org.elasticsearch.common.CacheRecycler
 
put(K, V) - Method in class jsr166e.ConcurrentHashMapV8
Maps the specified key to the specified value in this table.
put(E) - Method in class jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
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(K, V) - Method in class org.elasticsearch.common.collect.MapBuilder
 
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(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(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(QueryParserSettings, Query) - Method in class org.elasticsearch.index.cache.query.parser.support.AbstractJvmQueryParserCache
 
put(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.DocumentMapper.Builder
 
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
 
putAll(Map<? extends K, ? extends V>) - Method in class jsr166e.ConcurrentHashMapV8
Copies all of the mappings from the specified map to this one.
putAll(DiscoveryNodes) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
putAll(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.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) - 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
 
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
 
putIfAbsent(K, V) - Method in class jsr166e.ConcurrentHashMapV8
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
 
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(MetaDataMappingService.PutRequest, MetaDataMappingService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
 
PutMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.put
 
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
 
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.
putRootTypeParser(String, Mapper.TypeParser) - Method in class org.elasticsearch.index.mapper.DocumentMapperParser
 
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
 
PutWarmerRequest - Class in org.elasticsearch.action.admin.indices.warmer.put
A request to put a search warmer.
PutWarmerRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequest
Constructs a new warmer.
PutWarmerRequestBuilder - Class in org.elasticsearch.action.admin.indices.warmer.put
 
PutWarmerRequestBuilder(IndicesAdminClient, String) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
 
PutWarmerRequestBuilder(IndicesAdminClient) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
 
PutWarmerResponse - Class in org.elasticsearch.action.admin.indices.warmer.put
The response of put warmer operation.

Q

QSORT_STACK_SIZE - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This constant is accessible by subclasses for historical purposes.
QuadPrefixTree - Class in org.elasticsearch.common.lucene.spatial.prefix.tree
 
QuadPrefixTree(SpatialContext, Rectangle, int) - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
QuadPrefixTree(SpatialContext) - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
QuadPrefixTree(SpatialContext, int) - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.tree.QuadPrefixTree
 
QUADTREE - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
 
QUADTREE_LEVELS - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Defaults
 
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.ExistsFieldQueryExtension
 
query(QueryParseContext, String) - Method in interface org.apache.lucene.queryParser.FieldQueryExtension
 
query(QueryParseContext, String) - Method in class org.apache.lucene.queryParser.MissingFieldQueryExtension
 
query(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The query source to execute.
query(Map) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The query source to execute in the form of a map.
query(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
 
query(String) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The query source to validate.
query(byte[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The query source to validate.
query(byte[], int, int, boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The query source to validate.
query(BytesReference, boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The query source to validate.
query(QueryBuilder) - Method in class org.elasticsearch.action.count.CountRequest
The query source to execute.
query(Map) - Method in class org.elasticsearch.action.count.CountRequest
The query source to execute in the form of a map.
query(XContentBuilder) - Method in class org.elasticsearch.action.count.CountRequest
 
query(String) - Method in class org.elasticsearch.action.count.CountRequest
The query source to execute.
query(byte[]) - Method in class org.elasticsearch.action.count.CountRequest
The query source to execute.
query(byte[], int, int, boolean) - Method in class org.elasticsearch.action.count.CountRequest
The query source to execute.
query(BytesReference, boolean) - Method in class org.elasticsearch.action.count.CountRequest
 
query(QueryBuilder) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The query source to execute.
query(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The query source to execute.
query(Map) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The query source to execute in the form of a map.
query(XContentBuilder) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
query(byte[]) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The query source to execute.
query(byte[], int, int, boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The query source to execute.
query(BytesReference, boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
query(QueryBuilder) - Method in class org.elasticsearch.action.explain.ExplainSourceBuilder
 
query(BytesReference) - Method in class org.elasticsearch.action.explain.ExplainSourceBuilder
 
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.search.child.HasChildFilter
 
query() - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
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() - Method in interface org.elasticsearch.search.internal.ScopePhase
 
query() - Method in class org.elasticsearch.search.internal.SearchContext
The query to execute, might be rewritten.
QUERY_AND_FETCH_TYPE - Static variable in class org.elasticsearch.action.search.type.ParsedScrollId
 
QUERY_PREFIX - Static variable in class org.elasticsearch.index.query.IndexQueryParserService.Defaults
 
QUERY_RESULT_ORDERING - Static variable in class org.elasticsearch.search.controller.SearchPhaseController
 
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.search.internal.SearchContext
 
queryBoost(float) - Method in class org.elasticsearch.search.internal.SearchContext
 
QueryBuilder - Interface in org.elasticsearch.index.query
 
QueryBuilderException - Exception in org.elasticsearch.index.query
 
QueryBuilderException(String) - Constructor for exception org.elasticsearch.index.query.QueryBuilderException
 
QueryBuilderException(String, Throwable) - Constructor for exception org.elasticsearch.index.query.QueryBuilderException
 
QueryBuilders - Class in org.elasticsearch.index.query
A static factory for simple "import static" usage.
queryCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
queryCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
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
 
queryExplanations() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
The list of query explanations.
queryFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
queryFacet(String, QueryBuilder) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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
 
QueryFacetCollector - Class in org.elasticsearch.search.facet.query
 
QueryFacetCollector(String, Query, FilterCache) - Constructor for class org.elasticsearch.search.facet.query.QueryFacetCollector
 
QueryFacetProcessor - Class in org.elasticsearch.search.facet.query
 
QueryFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.query.QueryFacetProcessor
 
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
 
queryHint - Variable in class org.elasticsearch.action.count.CountRequest
 
queryHint() - Method in class org.elasticsearch.action.count.CountRequest
 
queryHint(String) - Method in class org.elasticsearch.action.count.CountRequest
A query hint to optionally later be used when routing the request.
queryHint(String) - Method in class org.elasticsearch.action.search.SearchRequest
A query hint to optionally later be used when routing the request.
queryHint() - Method in class org.elasticsearch.action.search.SearchRequest
A query hint to optionally later be used when routing the request.
QueryParseContext - Class in org.elasticsearch.index.query
 
QueryParseContext(Index, IndexQueryParserService) - 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
 
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 interface org.elasticsearch.index.service.IndexService
 
queryParserService() - Method in class org.elasticsearch.index.service.InternalIndexService
 
queryParserService() - Method in class org.elasticsearch.search.internal.SearchContext
 
QueryParserSettings - Class in org.apache.lucene.queryParser
 
QueryParserSettings() - Constructor for class org.apache.lucene.queryParser.QueryParserSettings
 
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) - 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
 
queryResult() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
queryResult() - Method in class org.elasticsearch.search.internal.SearchContext
 
queryResult() - Method in class org.elasticsearch.search.query.QuerySearchResult
 
queryResult() - Method in interface org.elasticsearch.search.query.QuerySearchResultProvider
 
queryResult() - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
 
queryRewritten() - Method in class org.elasticsearch.search.internal.SearchContext
Has the query been rewritten already?
QuerySearchRequest - Class in org.elasticsearch.search.query
 
QuerySearchRequest() - Constructor for class org.elasticsearch.search.query.QuerySearchRequest
 
QuerySearchRequest(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 - Interface in org.elasticsearch.search.query
 
queryString() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
queryString(String) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
queryString(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
A query that parses a query string and runs it.
queryStringLenient() - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
queryStringLenient() - Method in class org.elasticsearch.index.query.QueryParseContext
 
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
 
queryTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
queryTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
 
queryTypes() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
queryTypes(Collection<String>) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
queryTypes() - Method in class org.elasticsearch.index.query.QueryParseContext
Returns the narrowed down explicit types, or, if not set, all types.
queue() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
quietlyComplete() - Method in class jsr166y.ForkJoinTask
Completes this task normally without setting a value.
quietlyInvoke() - Method in class jsr166y.ForkJoinTask
Commences performing this task and awaits its completion if necessary, without returning its result or throwing its exception.
quietlyJoin() - Method in class jsr166y.ForkJoinTask
Joins this task, without returning its result or throwing its exception.
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.QueryParserSettings
 
quoteFieldSuffix() - Method in class org.apache.lucene.queryParser.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.
quoteIfString(Object) - Static method in class org.elasticsearch.common.Strings
Turn the given Object into a String with single quotes if it is a String; keeping the Object as-is else.

R

raf() - Method in class org.elasticsearch.index.translog.fs.RafReference
 
RafReference - Class in org.elasticsearch.index.translog.fs
 
RafReference(File) - Constructor for class org.elasticsearch.index.translog.fs.RafReference
 
raiseNodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
raiseNodeDisconnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
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) - 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
 
RamUsage - Class in org.elasticsearch.common
 
RamUsage() - Constructor for class org.elasticsearch.common.RamUsage
 
random() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
random(int) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
random(int, boolean, boolean) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
random(int, int, int, boolean, boolean) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
random(int, int, int, boolean, boolean, char[]) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string based on a variety of options, using default source of randomness.
random(int, int, int, boolean, boolean, char[], Random) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string based on a variety of options, using supplied source of randomness.
random(int, String) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
random(int, char[]) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
randomAllActiveShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
randomAllShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
An iterator over all shards (including replicas).
randomAlphabetic(int) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
randomAlphanumeric(int) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
randomAscii(int) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
randomBase64UUID() - Static method in class org.elasticsearch.common.UUID
 
randomDouble() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
randomFloat() - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
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
 
randomNodeName(InputStream) - Static method in class org.elasticsearch.common.Names
 
randomNumeric(int) - Static method in class org.elasticsearch.common.RandomStringGenerator
Creates a random string whose length is the number of characters specified.
RandomStringGenerator - Class in org.elasticsearch.common
 
RandomStringGenerator() - Constructor for class org.elasticsearch.common.RandomStringGenerator
RandomStringUtils instances should NOT be constructed in standard programming.
randomUUID() - Static method in class org.elasticsearch.common.UUID
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
rangeFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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.
RangeFacetCollector - Class in org.elasticsearch.search.facet.range
 
RangeFacetCollector(String, String, RangeFacet.Entry[], SearchContext) - Constructor for class org.elasticsearch.search.facet.range.RangeFacetCollector
 
RangeFacetCollector.RangeProc - Class in org.elasticsearch.search.facet.range
 
RangeFacetCollector.RangeProc(RangeFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.range.RangeFacetCollector.RangeProc
 
RangeFacetProcessor - Class in org.elasticsearch.search.facet.range
 
RangeFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.range.RangeFacetProcessor
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
rangeFilter(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeFilter(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeFilter(String, String, 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(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
rangeFilter(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
rangeFilter(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
rangeFilter(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
rangeFilter(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
A range filter based on the field data cache.
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
rangeFilter(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Constructs a range query filter based on the mapper.
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
rangeFilter(FieldDataCache, String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
rangeFilter(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
rangeFilter(FieldDataCache, String, String, 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
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Constructs a range query based on the mapper.
rangeQuery(String, String, boolean, boolean, QueryParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
rangeQuery(String, String, 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
 
rangeScriptFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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.
RateLimiter - Class in org.elasticsearch.common
 
RateLimiter(double) - Constructor for class org.elasticsearch.common.RateLimiter
mbPerSec is the MB/sec max IO rate
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
 
rateUnit() - Method in class org.elasticsearch.common.metrics.MeterMetric
 
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 interface org.elasticsearch.rest.RestRequest
The non decoded, raw path provided.
read() - Method in class org.elasticsearch.common.Base64.InputStream
Reads enough of the input stream to convert to/from Base64 and returns the next byte.
read(byte[], int, int) - Method in class org.elasticsearch.common.Base64.InputStream
Calls Base64.InputStream.read() repeatedly until the end of stream is reached or len bytes are read.
read() - Method in class org.elasticsearch.common.compress.bzip2.CBZip2InputStream
 
read(byte[], int, int) - Method in class org.elasticsearch.common.compress.bzip2.CBZip2InputStream
 
read(byte[], int, int, boolean) - Method in class org.elasticsearch.common.compress.CompressedIndexInput
 
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.FastByteArrayInputStream
Reads the next byte of data from this input stream.
read(byte[], int, int) - Method in class org.elasticsearch.common.io.FastByteArrayInputStream
Reads up to len bytes of data into an array of bytes from this input stream.
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.FileChannelInputStream
 
read(byte[], int, int) - Method in class org.elasticsearch.common.io.FileChannelInputStream
 
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() - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
read() - Method in class org.elasticsearch.gateway.shared.SharedStorageGateway
 
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(Translog.Location) - Method in interface org.elasticsearch.index.translog.fs.FsTranslogFile
 
read(Translog.Location) - Method in class org.elasticsearch.index.translog.fs.SimpleFsTranslogFile
 
read(Translog.Location) - Method in interface org.elasticsearch.index.translog.Translog
 
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
 
readAggregatedDfs(StreamInput) - Static method in class org.elasticsearch.search.dfs.AggregatedDfs
 
readAliasAction(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.AliasAction
 
readAllocationExplanation(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocationExplanation
 
readAllowed() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
readAnalyzeToken(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
readBlob(String, BlobContainer.ReadBlobListener) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
readBlob(String, BlobContainer.ReadBlobListener) - Method in class org.elasticsearch.common.blobstore.fs.AbstractFsBlobContainer
 
readBlobFully(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
 
readBlobFully(String) - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
 
readBoolean() - Method in class org.elasticsearch.common.io.stream.StreamInput
Reads a boolean.
readBoundTransportAddress(StreamInput) - Static method in class org.elasticsearch.common.transport.BoundTransportAddress
 
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.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
readByte() - Method in class org.elasticsearch.common.compress.CompressedIndexInput
 
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.transport.netty.ChannelBufferStreamInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.common.compress.CompressedIndexInput
 
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.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
 
readCacheStats(StreamInput) - Static method in class org.elasticsearch.index.cache.CacheStats
 
readChecksums(File[]) - Static method in class org.elasticsearch.index.store.Store
 
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
 
readCompressedString(StreamInput) - Static method in class org.elasticsearch.common.compress.CompressedString
 
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
 
reader() - Method in class org.elasticsearch.common.lucene.all.AllEntries.Entry
 
reader - Variable in class org.elasticsearch.common.lucene.uid.UidField.DocIdAndVersion
 
reader(IndexReader) - Method in interface org.elasticsearch.index.cache.id.IdCache
 
reader(IndexReader) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdCache
 
reader() - Method in interface org.elasticsearch.index.engine.Engine.Searcher
 
reader() - Method in class org.elasticsearch.index.engine.Engine.SimpleSearcher
 
reader() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
readerCacheKey() - Method in interface org.elasticsearch.index.cache.id.IdReaderCache
 
readerCacheKey() - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderCache
 
readerIndex(int) - Method in class org.apache.lucene.index.ExtendedIndexSearcher
 
readerKey() - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
readerValue() - Method in class org.elasticsearch.common.lucene.all.AllField
 
readerValue() - Method in class org.elasticsearch.common.lucene.uid.UidField
 
readerValue() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
 
readExplanation(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
 
readFacet(String, 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
 
readFetchSearchResult(StreamInput) - Static method in class org.elasticsearch.search.fetch.FetchSearchResult
 
readFilterFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
readFloat() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
readFlushStats(StreamInput) - Static method in class org.elasticsearch.index.flush.FlushStats
 
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.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.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.state.ClusterStateRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
 
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.IndicesExistsRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.exists.IndicesExistsResponse
 
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.gateway.snapshot.GatewaySnapshotResponse
 
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.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.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.segments.TransportIndicesSegmentsAction.IndexShardSegmentRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction.IndexShardStatsRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction.IndexShardStatusRequest
 
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.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.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.index.IndexDeleteRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.delete.index.IndexDeleteResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.delete.index.ShardDeleteRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.delete.index.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.IndexDeleteByQueryRequest
 
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.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.mlt.MoreLikeThisRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.PercolateRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.percolate.PercolateResponse
 
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.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.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.PrimaryOperationRequest
 
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.support.single.shard.TransportShardSingleOperationAction.ShardSingleOperationRequest
 
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.NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
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) - 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 interface org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
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, 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) - 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.common.compress.CompressedString
 
readFrom(StreamInput) - Method in class org.elasticsearch.common.io.BooleanStreamable
 
readFrom(StreamInput) - Method in class org.elasticsearch.common.io.stream.LongStreamable
 
readFrom(StreamInput) - Method in interface org.elasticsearch.common.io.stream.Streamable
 
readFrom(StreamInput) - Method in class org.elasticsearch.common.io.stream.StringStreamable
 
readFrom(StreamInput) - Method in class org.elasticsearch.common.io.stream.VoidStreamable
 
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
 
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.CacheStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.index.engine.Segment
 
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.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.StoreFileMetaData
 
readFrom(StreamInput) - Method in class org.elasticsearch.index.store.StoreStats
 
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.warmer.WarmerStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.indices.NodeIndicesStats
 
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) - 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) - Method in class org.elasticsearch.search.count.CountSearchResult
 
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.bounded.InternalBoundedCountHistogramFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
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.bytes.InternalByteTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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.FetchSearchRequest
 
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.highlight.HighlightField
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
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.InternalSearchRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalSearchResponse
 
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.warmer.IndexWarmersMetaData.Factory
 
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.TransportInfo
 
readFrom(StreamInput) - Method in class org.elasticsearch.transport.TransportStats
 
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
 
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
 
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
 
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
 
readHeader(StreamInput) - Method in class org.elasticsearch.common.compress.CompressedStreamInput
 
readHeader(IndexInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexInput
 
readHeader(StreamInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedStreamInput
 
readHeader(IndexInput) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexInput
 
readHeader(StreamInput) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamInput
 
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.bounded.InternalBoundedCountHistogramFacet
 
readHistogramFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
readHistogramFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
readHistogramFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
readHttpInfo(StreamInput) - Static method in class org.elasticsearch.http.HttpInfo
 
readHttpStats(StreamInput) - Static method in class org.elasticsearch.http.HttpStats
 
readIndexingStats(StreamInput) - Static method in class org.elasticsearch.index.indexing.IndexingStats
 
readIndexName(StreamInput) - Static method in class org.elasticsearch.index.Index
 
readIndexShardStatus(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
readIndicesStats(StreamInput) - Static method in class org.elasticsearch.indices.NodeIndicesStats
 
readInetSocketTransportAddress(StreamInput) - Static method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
readInt() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
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.
readInternalSearchResponse(StreamInput) - Static method in class org.elasticsearch.search.internal.InternalSearchResponse
 
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
 
readJvmInfo(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmInfo
 
readJvmStats(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats
 
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
 
readLong() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
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.
readMap(StreamInput) - Static method in class org.elasticsearch.common.io.stream.Streamables
 
readMap() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
readMap(XContentParser) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapConverter
 
readMap(XContentParser, XContentMapConverter.MapFactory) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapConverter
 
readMapValue(StreamInput) - Static method in class org.elasticsearch.common.io.stream.Streamables
 
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
 
ReadMostlyVector<E> - Class in jsr166e.extra
A class with the same methods and array-based characteristics as Vector but with reduced contention and improved throughput when invocations of read-only methods by multiple threads are most common.
ReadMostlyVector(int, int) - Constructor for class jsr166e.extra.ReadMostlyVector
Creates an empty vector with the given initial capacity and capacity increment.
ReadMostlyVector(int) - Constructor for class jsr166e.extra.ReadMostlyVector
Creates an empty vector with the given initial capacity.
ReadMostlyVector() - Constructor for class jsr166e.extra.ReadMostlyVector
Creates an empty vector with an underlying array of size 10.
ReadMostlyVector(Collection<? extends E>) - Constructor for class jsr166e.extra.ReadMostlyVector
Creates a vector containing the elements of the specified collection, in the order they are returned by the collection's iterator.
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
 
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
 
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
 
readOnlyRoutingNodes() - Method in class org.elasticsearch.cluster.ClusterState
Returns a built (on demand) routing nodes view of the routing table.
readOptionalString() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
readOptionalUTF() - Method in class org.elasticsearch.common.io.stream.StreamInput
Deprecated. use StreamInput.readOptionalString()
readOrderedMap(XContentParser) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapConverter
 
readOsInfo(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsInfo
 
readOsStats(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsStats
 
readPingResponse(StreamInput) - Static method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
readProcessInfo(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessInfo
 
readProcessStats(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessStats
 
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
 
readRefreshStats(StreamInput) - Static method in class org.elasticsearch.index.refresh.RefreshStats
 
readRiverRouting(StreamInput) - Static method in class org.elasticsearch.river.routing.RiverRouting
 
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
 
readSearchShardTarget(StreamInput) - Static method in class org.elasticsearch.search.SearchShardTarget
 
readSearchStats(StreamInput) - Static method in class org.elasticsearch.index.search.stats.SearchStats
 
readSegment(StreamInput) - Static method in class org.elasticsearch.index.engine.Segment
 
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
 
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
 
readShardStats(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.stats.ShardStats
 
readShort() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
readShort() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readShort() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
readSizeValue(StreamInput) - Static method in class org.elasticsearch.common.unit.SizeValue
 
readSource(StreamInput) - Method in class org.elasticsearch.index.translog.Translog.Create
 
readSource(StreamInput) - Method in class org.elasticsearch.index.translog.Translog.Delete
 
readSource(StreamInput) - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
readSource(StreamInput) - Method in class org.elasticsearch.index.translog.Translog.Index
 
readSource(StreamInput) - Method in interface org.elasticsearch.index.translog.Translog.Operation
 
readSource(byte[]) - Static method in class org.elasticsearch.index.translog.TranslogStreams
 
readStatisticalFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
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
 
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.bytes.InternalByteTermsFacet
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
readTermsFacet(StreamInput) - Static method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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
 
readText() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readText() - Method in class org.elasticsearch.common.io.stream.StreamInput
 
readThreadPoolInfo(StreamInput) - Static method in class org.elasticsearch.threadpool.ThreadPoolInfo
 
readThreadPoolStats(StreamInput) - Static method in class org.elasticsearch.threadpool.ThreadPoolStats
 
readThreads(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
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
 
readTransportInfo(StreamInput) - Static method in class org.elasticsearch.transport.TransportInfo
 
readTransportStats(StreamInput) - Static method in class org.elasticsearch.transport.TransportStats
 
readUTF() - Method in class org.elasticsearch.common.io.stream.AdapterStreamInput
 
readUTF() - Method in class org.elasticsearch.common.io.stream.HandlesStreamInput
Deprecated. 
readUTF() - Method in class org.elasticsearch.common.io.stream.StreamInput
Deprecated. use StreamInput.readString()
readVersion(StreamInput) - Static method in class org.elasticsearch.Version
 
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.
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
 
readyBuffer() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
Fill the uncompressed bytes buffer by reading the underlying inputStream.
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.index.engine.Engine.Get
 
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
 
rebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.EvenShardsCountAllocator
 
rebalance(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
 
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
 
received(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
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
 
recover(Engine.RecoveryHandler) - Method in interface org.elasticsearch.index.engine.Engine
 
recover(Engine.RecoveryHandler) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
recover(boolean, RecoveryStatus) - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
recover(boolean, RecoveryStatus) - 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, RecoveryStatus) - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
recover(boolean, RecoveryStatus) - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
recover(Engine.RecoveryHandler) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
recover(Engine.RecoveryHandler) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
recoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
How much of the index has been recovered.
recoveredIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
How much of the index has been recovered.
recoveredTotalSize() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
recoveredTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
recoveredTranslogOperations() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
RecoverFilesRecoveryException - Exception in org.elasticsearch.indices.recovery
 
RecoverFilesRecoveryException(ShardId, int, ByteSizeValue, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
 
recovering(String) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
Marks the shard as recovering, fails with exception is recovering is not allowed to be set.
recovery(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Should the status include recovery information.
recovery() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
 
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(ShardId, DiscoveryNode, DiscoveryNode, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
 
recoveryId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
 
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) - Constructor for class org.elasticsearch.indices.recovery.RecoverySource
 
RecoverySource.Actions - Class in org.elasticsearch.indices.recovery
 
RecoverySource.Actions() - Constructor for class org.elasticsearch.indices.recovery.RecoverySource.Actions
 
recoveryStatus() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
recoveryStatus() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
The last / on going recovery status.
recoveryStatus() - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
 
recoveryStatus() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
recoveryStatus() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
RecoveryStatus - Class in org.elasticsearch.index.gateway
 
RecoveryStatus() - Constructor for class org.elasticsearch.index.gateway.RecoveryStatus
 
RecoveryStatus - Class in org.elasticsearch.indices.recovery
 
RecoveryStatus(long, InternalIndexShard) - Constructor for class org.elasticsearch.indices.recovery.RecoveryStatus
 
RecoveryStatus.Index - Class in org.elasticsearch.index.gateway
 
RecoveryStatus.Index() - Constructor for class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
RecoveryStatus.Stage - Enum in org.elasticsearch.index.gateway
 
RecoveryStatus.Stage - Enum in org.elasticsearch.indices.recovery
 
RecoveryStatus.Start - Class in org.elasticsearch.index.gateway
 
RecoveryStatus.Start() - Constructor for class org.elasticsearch.index.gateway.RecoveryStatus.Start
 
RecoveryStatus.Translog - Class in org.elasticsearch.index.gateway
 
RecoveryStatus.Translog() - Constructor for class org.elasticsearch.index.gateway.RecoveryStatus.Translog
 
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, IndicesService, IndicesLifecycle, RecoverySettings) - Constructor for class org.elasticsearch.indices.recovery.RecoveryTarget
 
RecoveryTarget.Actions - Class in org.elasticsearch.indices.recovery
 
RecoveryTarget.Actions() - Constructor for class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
 
RecoveryTarget.RecoveryListener - Interface in org.elasticsearch.indices.recovery
 
RecursiveAction - Class in jsr166y
A recursive resultless ForkJoinTask.
RecursiveAction() - Constructor for class jsr166y.RecursiveAction
 
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
 
RecursiveTask<V> - Class in jsr166y
A recursive result-bearing ForkJoinTask.
RecursiveTask() - Constructor for class jsr166y.RecursiveTask
 
recycler - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexOutput
 
recycler - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamInput
 
recycler - Variable in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamOutput
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.datehistogram.InternalDateHistogramFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
reduce(String, List<Facet>) - Method in interface org.elasticsearch.search.facet.FacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.filter.FilterFacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.histogram.InternalHistogramFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.query.QueryFacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.range.RangeFacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.InternalTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.terms.TermsFacetProcessor
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.termsstats.InternalTermsStatsFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
reduce(String, List<Facet>) - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetProcessor
 
reducedType() - Method in class org.elasticsearch.index.field.data.FieldDataType.ExtendedFieldComparatorSource
 
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
 
refresh() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
Should a refresh be performed once the flush is done.
refresh(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
Should a refresh be performed once the flush is done.
REFRESH - Static variable in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
refresh() - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should refresh be performed after the optimization.
refresh(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should refresh be performed after the optimization.
refresh() - Method 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.index.IndexDeleteRequest
 
refresh() - Method in class org.elasticsearch.action.delete.index.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(IndexReader[]) - Method in interface org.elasticsearch.index.cache.id.IdCache
 
refresh(IndexReader[]) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdCache
 
refresh() - Method in class org.elasticsearch.index.engine.Engine.Flush
Should a refresh be performed after flushing.
refresh(boolean) - Method in class org.elasticsearch.index.engine.Engine.Flush
Should a refresh be performed after flushing.
refresh() - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
refresh(boolean) - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
refresh(Engine.Refresh) - Method in interface org.elasticsearch.index.engine.Engine
Refreshes the engine for new search operations to reflect the latest changes.
refresh(Engine.Refresh) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
refresh(Engine.Refresh) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
refresh(Engine.Refresh) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
refresh() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
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...) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
Refreshes mappings if they are not the same between original and parsed version
refreshNeeded() - Method in interface org.elasticsearch.index.engine.Engine
Returns true if a refresh is really needed.
refreshNeeded() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
RefreshRequest - Class in org.elasticsearch.action.admin.indices.refresh
A refresh request making all operations performed since the last refresh available for search.
RefreshRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
 
refreshRequest(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() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
refreshStats() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
refreshStats() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
Refresh stats.
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 interface org.elasticsearch.index.shard.service.IndexShard
 
refreshStats() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
Regex - Class in org.elasticsearch.common.regex
 
Regex() - Constructor for class org.elasticsearch.common.regex.Regex
 
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.
register() - Method in class jsr166y.Phaser
Adds a new unarrived party to this phaser.
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.
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.
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(ActionTransportRequestHandler) - Method in class org.elasticsearch.transport.TransportService
 
registerHandler(String, TransportRequestHandler) - Method in class org.elasticsearch.transport.TransportService
 
registerMBean(Object) - Method in class org.elasticsearch.jmx.JmxService
 
registerRiver(String, Class<? extends Module>) - Method in class org.elasticsearch.river.RiversModule
Registers a custom river type name against a module.
registerScript(String, Class<? extends NativeScriptFactory>) - Method in class org.elasticsearch.script.ScriptModule
 
registerStream(InternalFacet.Stream, String...) - Static method in class org.elasticsearch.search.facet.InternalFacet.Streams
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
registerStream() - Static method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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.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.bounded.InternalBoundedCountHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.histogram.InternalHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
registerStreams() - Static method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
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
 
reinitialize() - Method in class jsr166y.ForkJoinTask
Resets the internal bookkeeping state of this task, allowing a subsequent fork.
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.
rejected() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.elasticsearch.common.util.concurrent.EsAbortPolicy
 
relation(ShapeRelation) - Method in class org.elasticsearch.index.query.GeoShapeFilterBuilder
Sets the ShapeRelation that defines how the Shape used in the Filter must relate to indexed Shapes
relation(ShapeRelation) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
 
Releasable - Interface in org.elasticsearch.common.lease
 
release(ByteBuffer) - Method in interface org.apache.lucene.store.bytebuffer.ByteBufferAllocator
Release the buffer.
release(ByteBuffer) - Method in class org.apache.lucene.store.bytebuffer.CachingByteBufferAllocator
 
release(ByteBuffer) - Method in class org.apache.lucene.store.bytebuffer.PlainByteBufferAllocator
 
release(ByteBuffer) - Method in class org.elasticsearch.cache.memory.ByteBufferCache
 
release() - Method in interface org.elasticsearch.common.lease.Releasable
 
release() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommit
Releases the current snapshot, returning true if it was actually released.
release() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommits
 
release() - Method in class org.elasticsearch.index.engine.Engine.GetResult
 
release() - Method in class org.elasticsearch.index.engine.Engine.SimpleSearcher
 
release() - Method in class org.elasticsearch.index.gateway.fs.FsIndexShardGateway.FsSnapshotLock
 
release() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway.SnapshotLock
 
release() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
release() - Method in class org.elasticsearch.search.internal.SearchContext
 
releaseContextsForIndex(Index) - Method in class org.elasticsearch.search.SearchService
 
releaseContextsForShard(ShardId) - Method in class org.elasticsearch.search.SearchService
 
releaseDfsResults(Collection<DfsSearchResult>) - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
releaseFetchResults(Map<SearchShardTarget, FetchSearchResult>) - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
releaseIrrelevantSearchContexts(Map<SearchShardTarget, QuerySearchResultProvider>, Map<SearchShardTarget, ExtTIntArrayList>) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
Releases shard targets that are not used in the docsIdsToLoad.
releaseQueryFetchResults(Map<SearchShardTarget, QueryFetchSearchResult>) - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
releaseQueryResults(Map<SearchShardTarget, QuerySearchResultProvider>) - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
relocate(String) - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
relocated(String) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
relocating() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
relocating() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
The shard is in relocating mode.
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.
relocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
relocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
relocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
remaining() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
remaining() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
remainingCapacity() - Method in class jsr166y.LinkedTransferQueue
Always returns Integer.MAX_VALUE because a LinkedTransferQueue is not capacity constrained.
remap(K, V) - Method in interface jsr166e.ConcurrentHashMapV8.RemappingFunction
Returns a new value given a key and its current value.
remote(String) - Method in class org.elasticsearch.river.routing.RiversRouting.Builder
 
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
 
remove(Object) - Method in class jsr166e.ConcurrentHashMapV8
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class jsr166e.ConcurrentHashMapV8
remove(int) - Method in class jsr166e.extra.ReadMostlyVector
 
remove(Object) - Method in class jsr166e.extra.ReadMostlyVector
 
remove(K) - Method in class jsr166e.LongAdderTable
Removes the given key from the table.
remove() - Method in class jsr166y.ConcurrentLinkedDeque
 
remove(Object) - Method in class jsr166y.ConcurrentLinkedDeque
Removes the first element e such that o.equals(e), if such an element exists in this deque.
remove(Object) - Method in class jsr166y.LinkedTransferQueue
Removes a single instance of the specified element from this queue, if it is present.
remove(NodeAliasesUpdatedAction.Listener) - Method in class org.elasticsearch.cluster.action.index.NodeAliasesUpdatedAction
 
remove(NodeIndexCreatedAction.Listener) - Method in class org.elasticsearch.cluster.action.index.NodeIndexCreatedAction
 
remove(NodeIndexDeletedAction.Listener) - Method in class org.elasticsearch.cluster.action.index.NodeIndexDeletedAction
 
remove(NodeMappingCreatedAction.Listener) - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction
 
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(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(Object) - Method in class org.elasticsearch.common.collect.MapBackedSet
 
remove(K) - Method in class org.elasticsearch.common.collect.MapBuilder
 
remove() - Method in class org.elasticsearch.common.inject.internal.UnmodifiableIterator
Guaranteed to throw an exception and leave the underlying data unmodified.
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(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(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(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
remove(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
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 to the index.
removeAll(Collection<?>) - Method in class jsr166e.extra.ReadMostlyVector
 
removeAll() - Method in class jsr166e.LongAdderTable
Removes all keys from the table.
removeAllElements() - Method in class jsr166e.extra.ReadMostlyVector
See Vector.removeAllElements()
removeAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
removeAttribute(String) - Method in class org.elasticsearch.node.service.NodeService
 
removeByShardId(int) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
removeCollectors(String) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
removeConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
 
removeCurrent() - Static method in class org.elasticsearch.search.internal.SearchContext
 
removeCurrentMerge() - Static method in class org.apache.lucene.index.TrackingMergeScheduler
 
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
 
removeDuplicateStrings(String[]) - Static method in class org.elasticsearch.common.Strings
Remove duplicate Strings from the given array.
removeElement(Object) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.removeElement(java.lang.Object)
removeElementAt(int) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.removeElementAt(int)
removeFilter(SettingsFilter.Filter) - Method in class org.elasticsearch.common.settings.SettingsFilter
 
removeFirst() - Method in class jsr166y.ConcurrentLinkedDeque
 
removeFirstOccurrence(Object) - Method in class jsr166y.ConcurrentLinkedDeque
Removes the first element e such that o.equals(e), if such an element exists in this deque.
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
 
removeIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
removeIndexBlocks(String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
 
removeLast() - Method in class jsr166y.ConcurrentLinkedDeque
 
removeLastOccurrence(Object) - Method in class jsr166y.ConcurrentLinkedDeque
Removes the last element e such that o.equals(e), if such an element exists in this deque.
removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
removeLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.common.component.LifecycleComponent
 
removeListener() - Method in enum org.elasticsearch.action.ThreadingModel
 
removeListener(InitialStateDiscoveryListener) - Method in interface org.elasticsearch.discovery.Discovery
 
removeListener(InitialStateDiscoveryListener) - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
removeListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
removeListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
 
removeListener(InitialStateDiscoveryListener) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
removeListener(IndexingOperationListener) - Method in class org.elasticsearch.index.indexing.ShardIndexingService
 
removeListener(IndexSettingsService.Listener) - Method in class org.elasticsearch.index.settings.IndexSettingsService
 
removeListener(IndicesLifecycle.Listener) - Method in interface org.elasticsearch.indices.IndicesLifecycle
Remove a listener.
removeListener(IndicesLifecycle.Listener) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
removeListener(IndicesWarmer.Listener) - Method in interface org.elasticsearch.indices.warmer.IndicesWarmer
 
removeListener(IndicesWarmer.Listener) - Method in class org.elasticsearch.indices.warmer.InternalIndicesWarmer
 
removeListener(NodeSettingsService.Listener) - Method in class org.elasticsearch.node.settings.NodeSettingsService
 
removeMapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
removeMapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
 
removeMapping(MetaDataMappingService.RemoveRequest, MetaDataMappingService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
 
removeNodeAttribute(String) - Method in class org.elasticsearch.node.service.NodeService
Deprecated. 
removeOperation() - Method in enum org.elasticsearch.action.ThreadingModel
 
removePlugin(String) - Method in class org.elasticsearch.plugins.PluginManager
 
removeQuery(String) - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
removerAlias(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
removeRemovalListener(String) - Method in class org.elasticsearch.indices.cache.filter.IndicesFilterCache
 
removeReplica() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
removeShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
removeShard(int, String) - Method in interface org.elasticsearch.index.service.IndexService
Removes the shard, does not delete local data or the gateway.
removeShard(int, String) - Method in class org.elasticsearch.index.service.InternalIndexService
 
removeTemplate(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
removeTemplate(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
 
removeTypes() - Static method in class org.elasticsearch.index.query.QueryParseContext
 
renameFile(Directory, String, String) - Method in interface org.elasticsearch.index.store.DirectoryService
 
renameFile(Directory, String, String) - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
renameFile(Directory, String, String) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectoryService
 
renameFile(Directory, String, String) - Method in class org.elasticsearch.index.store.ram.RamDirectoryService
 
renameFile(String, String) - Method in class org.elasticsearch.index.store.Store
 
replace(K, V, V) - Method in class jsr166e.ConcurrentHashMapV8
replace(K, V) - Method in class jsr166e.ConcurrentHashMapV8
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, Properties) - Method in class org.elasticsearch.common.property.PropertyPlaceholder
Replaces all placeholders of format ${name} with the corresponding property from the supplied Properties.
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:

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
 
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(ReplicationType) - Method in class org.elasticsearch.action.delete.DeleteRequest
Set the replication type for this operation.
replicationType(ReplicationType) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The replication type to use with this operation.
replicationType(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The replication type to use with this operation.
replicationType(ReplicationType) - Method in class org.elasticsearch.action.index.IndexRequest
Set the replication type for this operation.
replicationType(String) - Method in class org.elasticsearch.action.index.IndexRequest
Set the replication type for this operation.
replicationType - Variable in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
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 - 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() - 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.
request() - Method in interface org.elasticsearch.action.ActionRequestBuilder
 
request - Variable in class org.elasticsearch.action.admin.cluster.support.BaseClusterRequestBuilder
 
request() - Method in class org.elasticsearch.action.admin.cluster.support.BaseClusterRequestBuilder
 
request - Variable in class org.elasticsearch.action.admin.indices.support.BaseIndicesRequestBuilder
 
request() - Method in class org.elasticsearch.action.admin.indices.support.BaseIndicesRequestBuilder
 
request() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
 
request() - Method in class org.elasticsearch.action.search.SearchRequestBuilder
 
request - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
request - Variable in class org.elasticsearch.action.support.BaseRequestBuilder
 
request() - Method in class org.elasticsearch.action.support.BaseRequestBuilder
 
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.ShardSingleOperationRequest
 
request() - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction.ShardSingleOperationRequest
 
request() - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
requests() - Method in class org.elasticsearch.action.search.MultiSearchRequest
 
Requests - Class in org.elasticsearch.client
A handy one stop shop for creating requests (make sure to import static this class).
Requests() - Constructor for class org.elasticsearch.client.Requests
 
requestStaticInjection(Class<?>...) - Method in class org.elasticsearch.common.inject.AbstractModule
 
requestStaticInjection(Class<?>...) - Method in interface org.elasticsearch.common.inject.Binder
Upon successful creation, the Injector will inject static fields and methods in the given classes.
requestStaticInjection(Class<?>...) - Method in class org.elasticsearch.common.inject.PrivateModule
 
requireBinding(Key<?>) - Method in class org.elasticsearch.common.inject.AbstractModule
Adds a dependency from this module to key.
requireBinding(Class<?>) - Method in class org.elasticsearch.common.inject.AbstractModule
Adds a dependency from this module to type.
requireBinding(Key<?>) - Method in class org.elasticsearch.common.inject.PrivateModule
Instructs Guice to require a binding to the given key.
requireBinding(Class<?>) - Method in class org.elasticsearch.common.inject.PrivateModule
Instructs Guice to require a binding to the given type.
required() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.Routing
 
Required - 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.
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
 
requiredAverageNumberOfShardsPerNode() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
requireFieldMatch(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder.Field
 
requireFieldMatch(boolean) - Method in class org.elasticsearch.search.highlight.HighlightBuilder
 
requireFieldMatch() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
requireFieldMatch(boolean) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
requiresProcessing() - Method in class org.elasticsearch.index.search.child.HasChildFilter
 
requiresProcessing() - Method in interface org.elasticsearch.search.internal.ScopePhase.CollectorPhase
 
requiresSnapshot() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
requiresSnapshot() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
Returns true if snapshot is even required on this gateway (i.e.
requiresSnapshot() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
requiresSnapshot() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
requiresSnapshotScheduling() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
requiresSnapshotScheduling() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
Returns true if this gateway requires scheduling management for snapshot operations.
requiresSnapshotScheduling() - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
requiresSnapshotScheduling() - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
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) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
Reroutes the routing table based on the live nodes.
rerouteWithNoReassign(ClusterState) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
Only handles reroute but *without* any reassignment of unassigned shards or rebalancing.
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(K) - Method in class jsr166e.LongAdderTable
Resets the sum associated with the given key to zero if the key exists in the table.
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.miscellaneous.WordDelimiterFilter
reset(Reader) - Method in class org.apache.lucene.analysis.pattern.PatternTokenizer
 
reset(QueryParserSettings) - Method in class org.apache.lucene.queryParser.MapperQueryParser
 
reset() - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
 
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.
reset() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
 
reset() - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
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.FastByteArrayInputStream
Resets the buffer to the marked position.
reset() - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Resets the count field of this byte array output stream to zero, so that all currently accumulated output in the output stream is discarded.
reset() - Method in class org.elasticsearch.common.io.FastCharArrayReader
Resets the stream to the most recent mark, or to the beginning if it has never been marked.
reset() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Resets the buffer so that you can use it again without throwing away the already allocated buffer.
reset() - Method in class org.elasticsearch.common.io.FastStringReader
Resets the stream to the most recent mark, or to the beginning of the string if it has never been marked.
reset() - Method in class org.elasticsearch.common.io.FileChannelInputStream
 
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.CachedStreamOutput.Entry
 
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.OutputStreamStreamOutput
 
reset() - Method in class org.elasticsearch.common.io.stream.StreamInput
Resets the stream.
reset() - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
reset() - Method in class org.elasticsearch.common.io.UTF8StreamWriter
 
reset() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
reset() - Method in interface org.elasticsearch.common.lucene.document.ResetFieldSelector
 
reset() - Method in class org.elasticsearch.common.lucene.document.SingleFieldSelector
 
reset() - Method in class org.elasticsearch.common.lucene.Lucene.ExistsCollector
 
reset() - Method in class org.elasticsearch.common.lucene.spatial.prefix.NodeTokenStream
 
reset(byte[], int, int) - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
reset() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
 
reset() - Method in class org.elasticsearch.common.lucene.uid.UidField.UidPayloadTokenStream
 
reset() - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
resets (clears) this timer before next execution.
reset(Throwable) - Method in class org.elasticsearch.common.util.concurrent.ThreadBarrier
Resets the barrier to its initial state.
reset() - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
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(Reader) - Method in class org.elasticsearch.index.analysis.NumericTokenizer
 
reset(Reader, char[]) - Method in class org.elasticsearch.index.analysis.NumericTokenizer
 
reset() - Method in class org.elasticsearch.index.mapper.ContentPath
 
reset() - Method in class org.elasticsearch.index.mapper.internal.SourceFieldSelector
 
reset(XContentParser, Document, SourceToParse, DocumentMapper.ParseListener) - Method in class org.elasticsearch.index.mapper.ParseContext
 
reset() - Method in class org.elasticsearch.index.mapper.selector.AllButSourceFieldSelector
 
reset() - Method in class org.elasticsearch.index.mapper.selector.FieldMappersFieldSelector
 
reset() - Method in class org.elasticsearch.index.mapper.selector.UidAndRoutingFieldSelector
 
reset() - Method in class org.elasticsearch.index.mapper.selector.UidAndSourceFieldSelector
 
reset() - Method in class org.elasticsearch.index.mapper.selector.UidFieldSelector
 
reset(XContentParser) - Method in class org.elasticsearch.index.query.QueryParseContext
 
reset(InternalSearchHit, IndexReader, int, IndexReader, int, Document) - 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.transport.netty.ChannelBufferStreamInput
 
resetAll() - Method in class jsr166e.LongAdderTable
Resets the sum associated with each key to zero.
resetAndLog(String) - Method in class org.elasticsearch.common.inject.internal.Stopwatch
Resets and logs elapsed time in milliseconds.
ResetFieldSelector - Interface in org.elasticsearch.common.lucene.document
 
resetToBufferStart() - Method in class org.elasticsearch.common.compress.CompressedStreamInput
Expert!, resets to buffer start, without the need to decompress it again.
resident() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
ResidentFieldDataCache - Class in org.elasticsearch.index.cache.field.data.resident
 
ResidentFieldDataCache(Index, Settings, IndexSettingsService) - Constructor for class org.elasticsearch.index.cache.field.data.resident.ResidentFieldDataCache
 
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
 
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
 
resolveConfig(String) - Method in class org.elasticsearch.env.Environment
 
resolveConfigAndLoadToString(String) - Method in class org.elasticsearch.env.Environment
 
resolveDefault() - Method in interface org.elasticsearch.common.network.NetworkService.CustomNameResolver
Resolves the default value if possible.
resolveIfPossible(String) - Method in interface org.elasticsearch.common.network.NetworkService.CustomNameResolver
Resolves a custom value handling, return null if can't handle it.
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
 
resolveNodes(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, DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
resolveRequest(ClusterState, ExplainRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
resolveRequest(ClusterState, GetRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
 
resolveRequest(ClusterState, MultiGetShardRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
resolveRequest(ClusterState, IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
resolveRequest(ClusterState, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
Resolves the request, by default, simply setting the concrete index (if its aliased one).
resolveRequest(ClusterState, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
Resolves the request, by default, simply setting the concrete index (if its aliased one).
resolveRequest(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
resolveRequest(ClusterState, UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
resolveSearchRouting(String, String) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
resolveSearchRouting(String, String[]) - Method in class org.elasticsearch.cluster.metadata.MetaData
 
resolveTypeVariable(Type, Class<?>, TypeVariable) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
 
ResourceDMBean - Class in org.elasticsearch.jmx
 
ResourceDMBean(Object, ESLogger) - Constructor for class org.elasticsearch.jmx.ResourceDMBean
 
response() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The actual response (IndexResponse or DeleteResponse).
response() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
The actual get response, null if its a failure.
response() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
The actual search response, null if its a failure.
response() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryResponse
 
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
 
responses() - Method in class org.elasticsearch.action.bulk.BulkShardResponse
 
responses() - Method in class org.elasticsearch.action.delete.index.IndexDeleteResponse
 
responses() - Method in class org.elasticsearch.action.get.MultiGetResponse
 
responses() - Method in class org.elasticsearch.action.search.MultiSearchResponse
The list of responses, the order is the same as the one provided in the request.
REST_DECODER - Static variable in class org.elasticsearch.rest.support.RestUtils
 
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
 
RestAnalyzeAction - Class in org.elasticsearch.rest.action.admin.indices.analyze
 
RestAnalyzeAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.analyze.RestAnalyzeAction
 
restart(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
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, Client, RestController) - Constructor for class org.elasticsearch.rest.action.bulk.RestBulkAction
 
RestChannel - Interface in org.elasticsearch.rest
 
RestClearIndicesCacheAction - Class in org.elasticsearch.rest.action.admin.indices.cache.clear
 
RestClearIndicesCacheAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.cache.clear.RestClearIndicesCacheAction
 
RestCloseIndexAction - Class in org.elasticsearch.rest.action.admin.indices.close
 
RestCloseIndexAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.close.RestCloseIndexAction
 
RestClusterGetSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster.settings
 
RestClusterGetSettingsAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.settings.RestClusterGetSettingsAction
 
RestClusterHealthAction - Class in org.elasticsearch.rest.action.admin.cluster.health
 
RestClusterHealthAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.health.RestClusterHealthAction
 
RestClusterRerouteAction - Class in org.elasticsearch.rest.action.admin.cluster.reroute
 
RestClusterRerouteAction(Settings, Client, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.reroute.RestClusterRerouteAction
 
RestClusterStateAction - Class in org.elasticsearch.rest.action.admin.cluster.state
 
RestClusterStateAction(Settings, Client, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.state.RestClusterStateAction
 
RestClusterUpdateSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster.settings
 
RestClusterUpdateSettingsAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.settings.RestClusterUpdateSettingsAction
 
restContentBuilder(RestRequest) - Static method in class org.elasticsearch.rest.action.support.RestXContentBuilder
 
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.count
 
RestCountAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.count.RestCountAction
 
RestCreateIndexAction - Class in org.elasticsearch.rest.action.admin.indices.create
 
RestCreateIndexAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.create.RestCreateIndexAction
 
RestDeleteAction - Class in org.elasticsearch.rest.action.delete
 
RestDeleteAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.delete.RestDeleteAction
 
RestDeleteByQueryAction - Class in org.elasticsearch.rest.action.deletebyquery
 
RestDeleteByQueryAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.deletebyquery.RestDeleteByQueryAction
 
RestDeleteIndexAction - Class in org.elasticsearch.rest.action.admin.indices.delete
 
RestDeleteIndexAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.delete.RestDeleteIndexAction
 
RestDeleteIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices.template.delete
 
RestDeleteIndexTemplateAction(Settings, Client, RestController) - 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, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.mapping.delete.RestDeleteMappingAction
 
RestDeleteWarmerAction - Class in org.elasticsearch.rest.action.admin.indices.warmer.delete
 
RestDeleteWarmerAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.warmer.delete.RestDeleteWarmerAction
 
restDocumentSource(BytesReference, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.rest.action.support.RestXContentBuilder
 
RestExplainAction - Class in org.elasticsearch.rest.action.explain
Rest action for computing a score explanation for specific documents.
RestExplainAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.explain.RestExplainAction
 
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, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.flush.RestFlushAction
 
RestGatewaySnapshotAction - Class in org.elasticsearch.rest.action.admin.indices.gateway.snapshot
 
RestGatewaySnapshotAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.gateway.snapshot.RestGatewaySnapshotAction
 
RestGetAction - Class in org.elasticsearch.rest.action.get
 
RestGetAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.get.RestGetAction
 
RestGetIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices.template.get
 
RestGetIndexTemplateAction(Settings, Client, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.indices.template.get.RestGetIndexTemplateAction
 
RestGetIndicesAliasesAction - Class in org.elasticsearch.rest.action.admin.indices.alias
 
RestGetIndicesAliasesAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.alias.RestGetIndicesAliasesAction
 
RestGetMappingAction - Class in org.elasticsearch.rest.action.admin.indices.mapping.get
 
RestGetMappingAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.mapping.get.RestGetMappingAction
 
RestGetSettingsAction - Class in org.elasticsearch.rest.action.admin.indices.settings
 
RestGetSettingsAction(Settings, Client, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.indices.settings.RestGetSettingsAction
 
RestGetWarmerAction - Class in org.elasticsearch.rest.action.admin.indices.warmer.get
 
RestGetWarmerAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.warmer.get.RestGetWarmerAction
 
RestHandler - Interface in org.elasticsearch.rest
 
RestHeadAction - Class in org.elasticsearch.rest.action.get
 
RestHeadAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.get.RestHeadAction
 
RestIndexAction - Class in org.elasticsearch.rest.action.index
 
RestIndexAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.index.RestIndexAction
 
RestIndicesAliasesAction - Class in org.elasticsearch.rest.action.admin.indices.alias
 
RestIndicesAliasesAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.alias.RestIndicesAliasesAction
 
RestIndicesExistsAction - Class in org.elasticsearch.rest.action.admin.indices.exists
 
RestIndicesExistsAction(Settings, Client, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.indices.exists.RestIndicesExistsAction
 
RestIndicesSegmentsAction - Class in org.elasticsearch.rest.action.admin.indices.segments
 
RestIndicesSegmentsAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.segments.RestIndicesSegmentsAction
 
RestIndicesStatsAction - Class in org.elasticsearch.rest.action.admin.indices.stats
 
RestIndicesStatsAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.stats.RestIndicesStatsAction
 
RestIndicesStatusAction - Class in org.elasticsearch.rest.action.admin.indices.status
 
RestIndicesStatusAction(Settings, Client, RestController, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.indices.status.RestIndicesStatusAction
 
RestMainAction - Class in org.elasticsearch.rest.action.main
 
RestMainAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.main.RestMainAction
 
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, Client, RestController) - Constructor for class org.elasticsearch.rest.action.mlt.RestMoreLikeThisAction
 
RestMultiGetAction - Class in org.elasticsearch.rest.action.get
 
RestMultiGetAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.get.RestMultiGetAction
 
RestMultiSearchAction - Class in org.elasticsearch.rest.action.search
 
RestMultiSearchAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.search.RestMultiSearchAction
 
RestNodesHotThreadsAction - Class in org.elasticsearch.rest.action.admin.cluster.node.hotthreads
 
RestNodesHotThreadsAction(Settings, Client, RestController) - 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, Client, RestController, 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, Client, RestController) - 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, Client, RestController) - 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, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.node.stats.RestNodesStatsAction
 
RestOpenIndexAction - Class in org.elasticsearch.rest.action.admin.indices.open
 
RestOpenIndexAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.open.RestOpenIndexAction
 
RestOptimizeAction - Class in org.elasticsearch.rest.action.admin.indices.optimize
 
RestOptimizeAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.optimize.RestOptimizeAction
 
RestPercolateAction - Class in org.elasticsearch.rest.action.percolate
 
RestPercolateAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.percolate.RestPercolateAction
 
RestPutIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices.template.put
 
RestPutIndexTemplateAction(Settings, Client, RestController) - 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, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.mapping.put.RestPutMappingAction
 
RestPutWarmerAction - Class in org.elasticsearch.rest.action.admin.indices.warmer.put
 
RestPutWarmerAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.warmer.put.RestPutWarmerAction
 
RestRefreshAction - Class in org.elasticsearch.rest.action.admin.indices.refresh
 
RestRefreshAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.refresh.RestRefreshAction
 
RestRequest - Interface in org.elasticsearch.rest
 
RestRequest.Method - Enum in org.elasticsearch.rest
 
RestResponse - Interface in org.elasticsearch.rest
 
RestSearchAction - Class in org.elasticsearch.rest.action.search
 
RestSearchAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.search.RestSearchAction
 
RestSearchScrollAction - Class in org.elasticsearch.rest.action.search
 
RestSearchScrollAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.search.RestSearchScrollAction
 
RestStatus - Enum in org.elasticsearch.rest
 
RestUpdateAction - Class in org.elasticsearch.rest.action.update
 
RestUpdateAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.update.RestUpdateAction
 
RestUpdateSettingsAction - Class in org.elasticsearch.rest.action.admin.indices.settings
 
RestUpdateSettingsAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.settings.RestUpdateSettingsAction
 
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, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.indices.validate.query.RestValidateQueryAction
 
RestXContentBuilder - Class in org.elasticsearch.rest.action.support
 
RestXContentBuilder() - Constructor for class org.elasticsearch.rest.action.support.RestXContentBuilder
 
result - Variable in class org.elasticsearch.common.Unicode.UTF16Result
 
result() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
 
resumeEncoding() - Method in class org.elasticsearch.common.Base64.OutputStream
Resumes encoding of the stream.
retainAll(Collection<?>) - Method in class jsr166e.extra.ReadMostlyVector
 
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
 
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
 
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(StartRecoveryRequest, RecoveryStatus, RecoveryTarget.RecoveryListener) - 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.
reusableTokenStream(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
reusableTokenStream(String, Reader) - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
 
reusableTokenStream(String, Reader) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
 
reusableTokenStream(String, Reader) - Method in class org.elasticsearch.index.analysis.NumericAnalyzer
 
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
 
reusedIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
reusedIndexSize() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
reusedTotalSize() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
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.elasticsearch.common.lucene.search.function.FiltersFunctionScoreQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
 
rewrite(String) - Method in class org.elasticsearch.index.query.FieldQueryBuilder
 
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.WildcardQueryBuilder
 
rewrite(IndexReader) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.index.search.nested.BlockJoinQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.index.search.nested.IncludeAllChildrenQuery
 
rewrite(Query) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
rewrite(Query) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
rewriteMethod() - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
rewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
rewriteMethod - Variable in class org.elasticsearch.index.search.MatchQuery
 
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
 
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
 
RiverClusterState.Builder() - Constructor for class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
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
 
RiverIndexName.Conf() - Constructor for class org.elasticsearch.river.RiverIndexName.Conf
 
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) - Constructor for class org.elasticsearch.river.routing.RiversRouter
 
RiversRouting - Class in org.elasticsearch.river.routing
 
RiversRouting.Builder - Class in org.elasticsearch.river.routing
 
RiversRouting.Builder() - Constructor for class org.elasticsearch.river.routing.RiversRouting.Builder
 
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
 
rNums - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
This array really shouldn't be here.
RobinEngine - Class in org.elasticsearch.index.engine.robin
 
RobinEngine(ShardId, Settings, ThreadPool, IndexSettingsService, ShardIndexingService, IndicesWarmer, Store, SnapshotDeletionPolicy, Translog, MergePolicyProvider, MergeSchedulerProvider, AnalysisService, SimilarityService, BloomCache) - Constructor for class org.elasticsearch.index.engine.robin.RobinEngine
 
RobinEngineModule - Class in org.elasticsearch.index.engine.robin
 
RobinEngineModule() - Constructor for class org.elasticsearch.index.engine.robin.RobinEngineModule
 
RobinIndexEngine - Class in org.elasticsearch.index.engine.robin
 
RobinIndexEngine(Index) - Constructor for class org.elasticsearch.index.engine.robin.RobinIndexEngine
 
RobinIndexEngine(Index, Settings) - Constructor for class org.elasticsearch.index.engine.robin.RobinIndexEngine
 
RobinIndexEngineModule - Class in org.elasticsearch.index.engine.robin
 
RobinIndexEngineModule() - Constructor for class org.elasticsearch.index.engine.robin.RobinIndexEngineModule
 
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
 
rootDoc() - Method in class org.elasticsearch.index.mapper.ParseContext
 
rootDoc() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
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.Builder(String) - Constructor for class org.elasticsearch.index.mapper.object.RootObjectMapper.Builder
 
RootObjectMapper.Defaults - Class in org.elasticsearch.index.mapper.object
 
RootObjectMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.object.RootObjectMapper.Defaults
 
RootObjectMapper.TypeParser - Class in org.elasticsearch.index.mapper.object
 
RootObjectMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.object.RootObjectMapper.TypeParser
 
rotl64(long, int) - Static method in class org.elasticsearch.common.MurmurHash
 
round(double, int) - Static method in class org.elasticsearch.common.math.MathUtils
Round the given value to the specified number of decimal places.
round(double, int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Round the given value to the specified number of decimal places.
round(float, int) - Static method in class org.elasticsearch.common.math.MathUtils
Round the given value to the specified number of decimal places.
round(float, int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Round the given value to the specified number of decimal places.
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
 
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() - Method in class org.elasticsearch.action.explain.ExplainRequest
 
routing(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
routing - Variable in class org.elasticsearch.action.get.GetRequest
 
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.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.support.replication.IndicesReplicationOperationRequest
 
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() - Method in class org.elasticsearch.index.engine.Engine.Create
 
routing() - Method in class org.elasticsearch.index.engine.Engine.Index
 
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
 
RoutingAllocation(AllocationDeciders, RoutingNodes, DiscoveryNodes) - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
RoutingAllocation.Result - Class in org.elasticsearch.cluster.routing.allocation
 
RoutingAllocation.Result(boolean, RoutingTable, AllocationExplanation) - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
 
RoutingBuilders - Class in org.elasticsearch.cluster.routing
 
routingEntry() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
routingEntry() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
routingEntry(ShardRouting) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
RoutingException - Exception in org.elasticsearch.cluster.routing
 
RoutingException(String) - Constructor for exception org.elasticsearch.cluster.routing.RoutingException
 
RoutingException(String, Throwable) - Constructor for exception org.elasticsearch.cluster.routing.RoutingException
 
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(Field.Store, Field.Index, boolean, String) - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
RoutingFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
RoutingFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Builder
 
RoutingFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
RoutingFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
 
RoutingFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
RoutingFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.TypeParser
 
RoutingMissingException - Exception in org.elasticsearch.action
 
RoutingMissingException(String, String, String) - Constructor for exception org.elasticsearch.action.RoutingMissingException
 
RoutingNode - Class in org.elasticsearch.cluster.routing
 
RoutingNode(String, DiscoveryNode) - Constructor for class org.elasticsearch.cluster.routing.RoutingNode
 
RoutingNode(String, DiscoveryNode, List<MutableShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.RoutingNode
 
routingNodes() - Method in class org.elasticsearch.cluster.ClusterState
 
routingNodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
RoutingNodes - Class in org.elasticsearch.cluster.routing
 
RoutingNodes(ClusterState) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
 
routingNodes(ClusterState) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
routingParsingStillNeeded() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
Is routing parsing still needed?
routingResolved() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData.ParseContext
Has routing been resolved during the parsing phase.
routingResult(RoutingAllocation.Result) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
RoutingService - Class in org.elasticsearch.cluster.routing
 
RoutingService(Settings, ThreadPool, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.routing.RoutingService
 
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(RoutingTable.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
routingTable(RoutingTable) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
routingTable() - Method in class org.elasticsearch.cluster.ClusterState
 
routingTable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.Result
 
routingTable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
 
routingTable() - Static method in class org.elasticsearch.cluster.routing.RoutingBuilders
 
routingTable() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
RoutingTable - Class in org.elasticsearch.cluster.routing
 
routingTable(RoutingTable) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
RoutingTable.Builder - Class in org.elasticsearch.cluster.routing
 
RoutingTable.Builder() - Constructor for class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
routingTableChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
RoutingTableValidation - Class in org.elasticsearch.cluster.routing
 
RoutingTableValidation() - Constructor for class org.elasticsearch.cluster.routing.RoutingTableValidation
 
RoutingValidationException - Exception in org.elasticsearch.cluster.routing
 
RoutingValidationException(RoutingTableValidation) - Constructor for exception org.elasticsearch.cluster.routing.RoutingValidationException
 
run() - Method in class jsr166y.ForkJoinWorkerThread
This method is required to be public, but should never be called explicitly.
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.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.mvel.MvelScriptEngineService.MvelExecutableScript
 
run() - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 
RUNA - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
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.mvel.MvelScriptEngineService.MvelSearchScript
 
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.mvel.MvelScriptEngineService.MvelSearchScript
 
runAsFloat() - Method in class org.elasticsearch.script.ScriptService.DocScoreSearchScript
 
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.mvel.MvelScriptEngineService.MvelSearchScript
 
runAsLong() - Method in interface org.elasticsearch.script.SearchScript
 
RUNB - Static variable in interface org.elasticsearch.common.compress.bzip2.BZip2Constants
 
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
 
rxCount() - Method in class org.elasticsearch.transport.TransportStats
 
rxSize() - Method in class org.elasticsearch.transport.TransportStats
 

S

SAFE_MIN - Static variable in class org.elasticsearch.common.math.MathUtils
Safe minimum, such that 1 / SAFE_MIN does not overflow.
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
 
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
 
SameShardAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
An allocation strategy that does not allow for the same shard instance to be allocated on the same node.
SameShardAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
 
sameTranslogNewOperations() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
Indicates that the same translog exists, but new operations have been appended to it.
scalb(double, int) - Static method in class org.elasticsearch.common.math.MathUtils
Scale a number by 2scaleFactor.
scalb(Double, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
scalb(Float, Integer) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
SCAN - Static variable in class org.elasticsearch.action.search.type.ParsedScrollId
 
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
 
ScanContext.ScanFilter(Map<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
 
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(String) - Method in class org.elasticsearch.index.query.HasChildFilterBuilder
 
scope(String) - Method in class org.elasticsearch.index.query.HasChildQueryBuilder
The scope of the query, which can later be used, for example, to run facets against the child docs that matches the query.
scope(String) - Method in class org.elasticsearch.index.query.NestedFilterBuilder
 
scope(String) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
 
scope(String) - Method in class org.elasticsearch.index.query.TopChildrenQueryBuilder
The scope of the query, which can later be used, for example, to run facets against the child docs that matches the query.
scope() - Method in class org.elasticsearch.index.search.child.HasChildFilter
 
scope() - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
scope - Variable in class org.elasticsearch.search.facet.AbstractFacetBuilder
 
scope(String) - Method in class org.elasticsearch.search.facet.AbstractFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.datehistogram.DateHistogramFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.filter.FilterFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.histogram.HistogramScriptFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.query.QueryFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.range.RangeFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.range.RangeScriptFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
Marks the facet to run in a specific scope.
scope(String) - Method in class org.elasticsearch.search.facet.terms.TermsFacetBuilder
Marks the facet to run in a specific scope.
scope() - Method in interface org.elasticsearch.search.internal.ScopePhase
 
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
 
ScopePhase - Interface in org.elasticsearch.search.internal
 
ScopePhase.CollectorPhase - Interface in org.elasticsearch.search.internal
 
ScopePhase.TopDocsPhase - Interface in org.elasticsearch.search.internal
 
scopePhases() - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
score(int, float) - Method in interface org.elasticsearch.common.lucene.search.function.ScoreFunction
 
score(int, float) - Method in class org.elasticsearch.index.query.CustomScoreQueryParser.ScriptScoreFunction
 
score(String) - Method in class org.elasticsearch.index.query.TopChildrenQueryBuilder
How to compute the score.
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() - Method in interface org.elasticsearch.search.controller.ShardDoc
 
score() - Method in class org.elasticsearch.search.controller.ShardFieldDoc
 
score() - Method in class org.elasticsearch.search.controller.ShardScoreDoc
 
score(float) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
score() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
score() - Method in class org.elasticsearch.search.lookup.DocLookup
 
score() - Method in interface org.elasticsearch.search.SearchHit
The score.
SCORE_FIELD_NAME - Static variable in class org.elasticsearch.search.sort.SortParseElement
 
ScoreDocQueue - Class in org.elasticsearch.search.controller
Same as lucene HitQueue.
ScoreDocQueue(int) - Constructor for class org.elasticsearch.search.controller.ScoreDocQueue
 
ScoreFunction - Interface in org.elasticsearch.common.lucene.search.function
 
scoreMode(String) - Method in class org.elasticsearch.index.query.CustomFiltersScoreQueryBuilder
 
scoreMode(String) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
The score mode.
scoreOrdered() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
scoreOrdered(boolean) - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
scorer(IndexReader, boolean, boolean) - Method in class org.elasticsearch.common.lucene.all.AllTermQuery.AllTermWeight
 
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
 
script() - Method in class org.elasticsearch.action.update.UpdateRequest
 
script(String) - Method in class org.elasticsearch.action.update.UpdateRequest
The script to execute.
script(String, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
The script to execute.
script(String, String, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
The script to execute.
script(String) - Method in class org.elasticsearch.index.query.CustomScoreQueryBuilder
Sets the boost factor for this query.
script - Variable in class org.elasticsearch.script.ScriptService.CacheKey
 
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
 
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).
scriptFields() - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
ScriptFieldsContext.ScriptField(String, SearchScript, boolean) - Constructor for class org.elasticsearch.search.fetch.script.ScriptFieldsContext.ScriptField
 
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.
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
 
ScriptGeoDistanceFacetCollector - Class in org.elasticsearch.search.facet.geodistance
 
ScriptGeoDistanceFacetCollector(String, String, double, double, DistanceUnit, GeoDistance, GeoDistanceFacet.Entry[], SearchContext, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetCollector
 
ScriptGeoDistanceFacetCollector.Aggregator - Class in org.elasticsearch.search.facet.geodistance
 
ScriptGeoDistanceFacetCollector.Aggregator(GeoDistance.FixedSourceDistance, GeoDistanceFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetCollector.Aggregator
 
ScriptHistogramFacetCollector - Class in org.elasticsearch.search.facet.histogram.unbounded
 
ScriptHistogramFacetCollector(String, String, String, String, Map<String, Object>, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.ScriptHistogramFacetCollector
 
scriptLang(String) - Method in class org.elasticsearch.action.update.UpdateRequest
The language of the script to execute.
ScriptModule - Class in org.elasticsearch.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.
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.
ScriptRangeFacetCollector - Class in org.elasticsearch.search.facet.range
 
ScriptRangeFacetCollector(String, String, String, String, Map<String, Object>, RangeFacet.Entry[], SearchContext) - Constructor for class org.elasticsearch.search.facet.range.ScriptRangeFacetCollector
 
scriptService() - Method in class org.elasticsearch.index.query.QueryParseContext
 
ScriptService - Class in org.elasticsearch.script
 
ScriptService(Settings) - Constructor for class org.elasticsearch.script.ScriptService
 
ScriptService(Settings, Environment, Set<ScriptEngineService>) - Constructor for class org.elasticsearch.script.ScriptService
 
scriptService() - Method in class org.elasticsearch.search.internal.SearchContext
 
ScriptService.CacheKey - Class in org.elasticsearch.script
 
ScriptService.CacheKey(String, String) - Constructor for class org.elasticsearch.script.ScriptService.CacheKey
 
ScriptService.DocScoreNativeScriptFactory - Class in org.elasticsearch.script
 
ScriptService.DocScoreNativeScriptFactory() - Constructor for class org.elasticsearch.script.ScriptService.DocScoreNativeScriptFactory
 
ScriptService.DocScoreSearchScript - Class in org.elasticsearch.script
 
ScriptService.DocScoreSearchScript() - Constructor for class org.elasticsearch.script.ScriptService.DocScoreSearchScript
 
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
 
ScriptStatisticalFacetCollector - Class in org.elasticsearch.search.facet.statistical
 
ScriptStatisticalFacetCollector(String, String, String, Map<String, Object>, SearchContext) - Constructor for class org.elasticsearch.search.facet.statistical.ScriptStatisticalFacetCollector
 
ScriptTermsStringFieldFacetCollector - Class in org.elasticsearch.search.facet.terms.strings
 
ScriptTermsStringFieldFacetCollector(String, int, TermsFacet.ComparatorType, SearchContext, ImmutableSet<String>, Pattern, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.strings.ScriptTermsStringFieldFacetCollector
 
scroll() - Method in class org.elasticsearch.action.search.SearchRequest
If set, will enable scrolling of the search request.
scroll(Scroll) - Method in class org.elasticsearch.action.search.SearchRequest
If set, will enable scrolling of the search request.
scroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequest
If set, will enable scrolling of the search request for the specified timeout.
scroll(String) - Method in class org.elasticsearch.action.search.SearchRequest
If set, will enable scrolling of the search request for the specified timeout.
scroll() - Method in class org.elasticsearch.action.search.SearchScrollRequest
If set, will enable scrolling of the search request.
scroll(Scroll) - Method in class org.elasticsearch.action.search.SearchScrollRequest
If set, will enable scrolling of the search request.
scroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchScrollRequest
If set, will enable scrolling of the search request for the specified timeout.
scroll(String) - Method in class org.elasticsearch.action.search.SearchScrollRequest
If set, will enable scrolling of the search request for the specified timeout.
scroll() - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
scroll(Scroll) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
scroll() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
scroll(Scroll) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
scroll() - Method in class org.elasticsearch.search.internal.SearchContext
 
scroll(Scroll) - Method in class org.elasticsearch.search.internal.SearchContext
 
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.
scrollId() - 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.
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
 
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(Query) - Method in class org.apache.lucene.index.memory.CustomMemoryIndex
Convenience method that efficiently returns the relevance score by matching this index against the given Lucene query expression.
search() - Method 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() - Method in class org.elasticsearch.index.engine.Segment
 
search() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
search(Object, SearchLookup, Map<String, Object>) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService
 
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(CompiledScript, SearchLookup, Map<String, Object>) - Method in class org.elasticsearch.script.ScriptService
 
search(SearchLookup, String, String, Map<String, Object>) - Method in class org.elasticsearch.script.ScriptService
 
search(MapperService, FieldDataCache, String, String, Map<String, Object>) - Method in class org.elasticsearch.script.ScriptService
 
search(Weight, Filter, Collector) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(Weight, Filter, int) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(Weight, Filter, int, Sort) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
search(Weight, Filter, int, Sort, boolean) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
search(Weight, Filter, Collector) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
SEARCH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
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(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
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(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Builder
 
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.
searchCache - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
SearchContext - Class in org.elasticsearch.search.internal
 
SearchContext(long, InternalSearchRequest, SearchShardTarget, Engine.Searcher, IndexService, IndexShard, ScriptService) - Constructor for class org.elasticsearch.search.internal.SearchContext
 
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<FacetCollector>) - Constructor for class org.elasticsearch.search.facet.SearchContextFacets
 
SearchContextHighlight - Class in org.elasticsearch.search.highlight
 
SearchContextHighlight(List<SearchContextHighlight.Field>) - Constructor for class org.elasticsearch.search.highlight.SearchContextHighlight
 
SearchContextHighlight.Field - Class in org.elasticsearch.search.highlight
 
SearchContextHighlight.Field(String) - Constructor for class org.elasticsearch.search.highlight.SearchContextHighlight.Field
 
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() - Method in interface org.elasticsearch.index.engine.Engine
 
searcher() - Method in interface org.elasticsearch.index.engine.Engine.Searcher
 
searcher() - Method in class org.elasticsearch.index.engine.Engine.SimpleSearcher
 
searcher() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
searcher() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
searcher() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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.
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.
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, FieldDataCache, String[]) - Constructor for class org.elasticsearch.search.lookup.SearchLookup
 
SearchModule - Class in org.elasticsearch.search
 
SearchModule() - Constructor for class org.elasticsearch.search.SearchModule
 
SearchOperationThreading - Enum in org.elasticsearch.action.search
Controls the operation threading model for search operation that are performed locally on the executing node.
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, FacetProcessors) - 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
 
searchQueryHint(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Optional search query hint.
searchQueryHint() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
Optional search query hint.
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 - Class in org.elasticsearch.action.search
A request to execute search against one or more indices (or all).
SearchRequest() - Constructor for class org.elasticsearch.action.search.SearchRequest
 
SearchRequest(String...) - Constructor for class org.elasticsearch.action.search.SearchRequest
Constructs a new search request against the indices.
SearchRequest(String[], 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.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
 
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 interface org.elasticsearch.index.shard.service.IndexShard
 
searchService() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
SearchService - Class in org.elasticsearch.search
 
SearchService(Settings, ClusterService, IndicesService, IndicesLifecycle, IndicesWarmer, ThreadPool, ScriptService, DfsPhase, QueryPhase, FetchPhase) - 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, TransportService, ClusterService, SearchService) - Constructor for class org.elasticsearch.search.action.SearchServiceTransportAction
 
searchShards(ClusterState, String[], String[], String, Map<String, Set<String>>, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
searchShards(ClusterState, String[], String[], String, Map<String, Set<String>>, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
searchShardsCount(ClusterState, String[], String[], String, Map<String, Set<String>>, String) - Method in interface org.elasticsearch.cluster.routing.operation.OperationRouting
 
searchShardsCount(ClusterState, String[], 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, Map<String, SearchStats.Stats>) - Constructor for class org.elasticsearch.index.search.stats.SearchStats
 
searchStats(String...) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
searchStats(String...) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
SearchStats.Stats - Class in org.elasticsearch.index.search.stats
 
SearchStats.Stats(long, long, long, long, long, long) - Constructor for class org.elasticsearch.index.search.stats.SearchStats.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.search.internal.InternalSearchRequest
 
searchType() - Method in class org.elasticsearch.search.internal.SearchContext
 
searchType(SearchType) - Method in class org.elasticsearch.search.internal.SearchContext
 
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.
secondaryDir() - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
Return the secondary directory
seconds() - Method in class org.elasticsearch.common.unit.TimeValue
 
secondsFrac() - Method in class org.elasticsearch.common.unit.TimeValue
 
seek(long) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexInput
 
seek(long) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexOutput
 
seek(long) - Method in class org.apache.lucene.store.OpenBufferedIndexOutput
Sets current position in this file, where the next write will occur.
seek(long) - Method in class org.elasticsearch.common.compress.CompressedIndexInput
 
seek(long) - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
seek(int) - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Seeks back to the given position.
seek(long) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
seek(long) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
seek(int) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
 
seek(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
seek(long) - Method in class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
seek(long) - Method in class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
seek(long) - Method in class org.elasticsearch.common.lucene.store.NullIndexOutput
 
seekForward(long) - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
seekForward(long) - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
 
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
 
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
 
segments() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
 
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 interface org.elasticsearch.index.engine.Engine
 
segments() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
sendExecuteDfs(DiscoveryNode, InternalSearchRequest, SearchServiceListener<DfsSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteFetch(DiscoveryNode, InternalSearchRequest, 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, FetchSearchRequest, SearchServiceListener<FetchSearchResult>) - Method in class org.elasticsearch.search.action.SearchServiceTransportAction
 
sendExecuteFirstPhase(DiscoveryNode, InternalSearchRequest, SearchServiceListener<FirstResult>) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
sendExecuteQuery(DiscoveryNode, InternalSearchRequest, SearchServiceListener<QuerySearchResult>) - 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, InternalSearchRequest, 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) - 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, Streamable, TransportRequestOptions) - Method in class org.elasticsearch.transport.local.LocalTransport
 
sendRequest(DiscoveryNode, long, String, Streamable, TransportRequestOptions) - Method in class org.elasticsearch.transport.netty.NettyTransport
 
sendRequest(DiscoveryNode, long, String, Streamable, TransportRequestOptions) - Method in interface org.elasticsearch.transport.Transport
Sends the request to the node.
sendRequest(DiscoveryNode, String, Streamable, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
 
sendRequest(DiscoveryNode, String, Streamable, 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 interface org.elasticsearch.rest.RestChannel
 
sendResponse(Streamable) - Method in class org.elasticsearch.transport.local.LocalTransportChannel
 
sendResponse(Streamable, TransportResponseOptions) - Method in class org.elasticsearch.transport.local.LocalTransportChannel
 
sendResponse(Throwable) - Method in class org.elasticsearch.transport.local.LocalTransportChannel
 
sendResponse(Streamable) - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
 
sendResponse(Streamable, TransportResponseOptions) - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
 
sendResponse(Throwable) - Method in class org.elasticsearch.transport.netty.NettyTransportChannel
 
sendResponse(Streamable) - Method in interface org.elasticsearch.transport.TransportChannel
 
sendResponse(Streamable, TransportResponseOptions) - Method in interface org.elasticsearch.transport.TransportChannel
 
sendResponse(Throwable) - Method in interface org.elasticsearch.transport.TransportChannel
 
sendValidateJoinRequestBlocking(DiscoveryNode, ClusterState, TimeValue) - Method in class org.elasticsearch.discovery.zen.membership.MembershipAction
Validates the join request, throwing a failure if it failed.
sent(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
SequenceLock - Class in jsr166e
A reentrant mutual exclusion Lock in which each lock acquisition or release advances a sequence number.
SequenceLock() - Constructor for class jsr166e.SequenceLock
Creates an instance of SequenceLock with the default number of retry attempts to acquire the lock before blocking.
SequenceLock(int) - Constructor for class jsr166e.SequenceLock
Creates an instance of SequenceLock that will retry attempts to acquire the lock at least the given number times before blocking.
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.
serialize(Shape, XContentBuilder) - Static method in class org.elasticsearch.common.geo.GeoJSONShapeSerializer
Serializes the given Shape as GeoJSON format into the given XContentBuilder
SerialMergeSchedulerProvider - Class in org.elasticsearch.index.merge.scheduler
 
SerialMergeSchedulerProvider(ShardId, Settings) - Constructor for class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
 
SerialMergeSchedulerProvider.CustomSerialMergeScheduler - Class in org.elasticsearch.index.merge.scheduler
 
SerialMergeSchedulerProvider.CustomSerialMergeScheduler(ESLogger, SerialMergeSchedulerProvider) - Constructor for class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider.CustomSerialMergeScheduler
 
serverOpen() - Method in class org.elasticsearch.http.HttpStats
 
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
 
serverOpen() - Method in class org.elasticsearch.transport.TransportStats
 
serviceAttributes() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
The service attributes of the node.
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
 
serviceUrl() - Method in class org.elasticsearch.jmx.JmxService
 
set(double) - Method in class jsr166e.extra.AtomicDouble
Sets to the given value.
set(int, double) - Method in class jsr166e.extra.AtomicDoubleArray
Sets the element at position i to the given value.
set(int, E) - Method in class jsr166e.extra.ReadMostlyVector
 
set(boolean) - Method in class org.elasticsearch.common.io.BooleanStreamable
 
set(long) - Method in class org.elasticsearch.common.io.stream.LongStreamable
 
set(String) - Method in class org.elasticsearch.common.io.stream.StringStreamable
 
set() - Method in class org.elasticsearch.common.lucene.docset.FixedBitDocSet
 
set() - Method in class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
set(int, long) - Method in class org.elasticsearch.common.util.BigLongArray
 
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(T) - Method in class org.elasticsearch.common.util.concurrent.ThreadLocals.CleanableValue
 
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(String) - Method in class org.elasticsearch.index.search.MatchQuery
 
setAttribute(Attribute) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
setAttributes(AttributeList) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
setBinding(BindingImpl<T>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
setBloomCache(BloomCache) - Method in interface org.apache.lucene.index.XIndexWriter.XBufferedDeletesStream
 
setBloomCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
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
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataMissingComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataMissingComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataMissingComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataMissingComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataMissingComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataMissingComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.function.sort.DoubleFieldsFunctionDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
setBottom(int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
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.
setChronology(Chronology) - Method in class org.joda.time.base.BaseDateTime
Sets the chronology of the datetime.
setClusterService(ClusterService) - Method in class org.elasticsearch.index.cache.IndexCache
 
setClusterService(ClusterService) - Method in class org.elasticsearch.node.settings.NodeSettingsService
 
setCollector(Collector) - Method in class org.elasticsearch.index.search.nested.BlockJoinQuery
 
setCompress(boolean) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
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.update.UpdateRequestBuilder
Sets the consistency level of write.
setContentType(XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
The content type that will be used to generate a document from user provided objects (like Map).
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.
setCurrent(SearchContext) - Static method in class org.elasticsearch.search.internal.SearchContext
 
setCurrentMerge(MergePolicy.OneMerge) - Static method in class org.apache.lucene.index.TrackingMergeScheduler
 
setCurrentReference(T) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
 
setCustom(IndexMetaData.Custom) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
 
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
 
setDiscreteMultiValueHighlighting(boolean) - Method in class org.apache.lucene.search.vectorhighlight.AbstractFragmentsBuilder
 
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.
setDocs(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setElementAt(E, int) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.setElementAt(E, int)
setEnablePositionIncrements(boolean) - Method in class org.elasticsearch.index.search.MatchQuery
 
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.
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.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).
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
Sets a raw (xcontent) binary representation of facets to use.
setFacets(byte[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Sets a raw (xcontent) binary representation of facets to use.
setFacets(byte[], int, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Sets a raw (xcontent) binary representation of facets to use.
setFacets(XContentBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Sets a raw (xcontent) binary representation of facets to use.
setFacets(Map) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Sets a raw (xcontent) binary representation of facets to use.
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.
setFieldDataCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
setFields(SortField[]) - Method in class org.apache.lucene.search.ShardFieldDocSortedHitQueue
Allows redefinition of sort fields if they are null.
setFields(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
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(String...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Explicitly specify the fields that will be returned.
setFilter(FilterBuilder) - 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).
setFilter(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).
setFilter(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).
setFilter(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).
setFilter(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).
setFilter(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).
setFilter(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).
setFilter(Filter) - Method in class org.elasticsearch.index.search.nested.NestedChildrenCollector
 
setFilter(Filter) - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
setFilter(Filter) - Method in class org.elasticsearch.search.facet.FacetCollector
 
setFilterAll() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Filters all data responses.
setFilterBlocks(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
 
setFilterCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
setFilterIndexTemplates(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
 
setFilterIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
When ClusterStateRequestBuilder.setFilterMetaData(boolean) is not set, which indices to return the IndexMetaData for.
setFilterMetaData(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Should the cluster state result include the MetaData.
setFilterNodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Should the cluster state result include the DiscoveryNodes.
setFilterRoutingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Should the cluster state result include teh RoutingTable.
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.
setForkJoinTaskTag(short) - Method in class jsr166y.ForkJoinTask
Atomically sets the tag value for this task.
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.
setFs(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
Should the node file system stats be returned.
setFull(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
 
setFuzziness(String) - Method in class org.elasticsearch.index.search.MatchQuery
 
setFuzzyPrefixLength(int) - Method in class org.elasticsearch.index.search.MatchQuery
 
setFuzzyRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.elasticsearch.index.search.MatchQuery
 
setGatewayAllocator(Class<? extends GatewayAllocator>) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
setGet(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setGroups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setHighlighterEncoder(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
The encoder to set for highlighting
setHighlighterOrder(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
The order of fragments per field.
setHighlighterPostTags(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
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.
setHighlighterRequireFieldMatch(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
 
setHighlighterTagsSchema(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Set a tag scheme that encapsulates a built in pre and post tags.
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
 
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.update.UpdateRequestBuilder
Sets the id of the indexed document.
setIdCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
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.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.count.CountRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
Specifies what type of requested indices to ignore.
setIgnoreIndices(IgnoreIndices) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Specifies what type of requested indices to ignore.
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.close.CloseIndexRequestBuilder
 
setIndex(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
 
setIndex(String) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
 
setIndex(String) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
Sets the index the delete will happen on.
setIndex(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
Sets the index to get a score explanation for.
setIndex(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
Sets the index of the document to fetch.
setIndex(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Sets the index to index the document to.
setIndex(String) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Sets the index to percolate the document against.
setIndex(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Sets the index the document will exists on.
setIndexing(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setIndexOptions(FieldInfo.IndexOptions) - Method in class org.elasticsearch.common.lucene.uid.UidField
 
setIndexShard(IndexShard) - Method in class org.elasticsearch.index.get.ShardGetService
 
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(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.exists.IndicesExistsRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
Sets specific indices to return the stats for.
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
Sets specific indices to return the status for.
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
Sets the indices the query validation will run against.
setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequestBuilder
 
setIndices(String...) - Method in class org.elasticsearch.action.count.CountRequestBuilder
Sets the indices the count query will run against.
setIndices(String...) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The indices the delete by query will run against.
setIndices(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Sets the indices the search will be executed on.
setIndicesService(IndicesService) - Method in class org.elasticsearch.index.percolator.PercolatorExecutor
 
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.
setLeaf() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
setLength(long) - Method in class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
setLength(long) - Method in class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
setLength(int) - Method in class org.elasticsearch.common.Unicode.UTF16Result
 
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
 
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
 
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.count.CountRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Should the listener be called on a separate thread if needed.
setListenerThreaded(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Should the listener be called on a separate thread if needed.
setLocal(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Sets if the cluster state request should be executed locally on the node, and not go to the master.
setLockFactory(LockFactory) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
setMappingsModified() - Method in class org.elasticsearch.index.mapper.ParseContext
 
SETMASK - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This constant is accessible by subclasses for historical purposes.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.warmer.delete.DeleteWarmerRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.warmer.put.PutWarmerRequestBuilder
Sets the master node timeout in case the master has not yet been discovered.
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
 
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.
setMaxQueryTerms(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
setMaxRate(ByteSizeValue) - Method in class org.apache.lucene.store.StoreRateLimiting
 
setMaxRate(double) - Method in class org.elasticsearch.common.RateLimiter
 
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
 
setMerge(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
setMillis(long) - Method in class org.joda.time.base.BaseDateTime
Sets the milliseconds of the datetime.
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
 
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.
setMinTermFreq(int) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
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
 
setMoreLikeFields(String[]) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
setName(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.
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.
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.
setNextDocId(int) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setNextDocId(int) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 
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.SearchLookup
 
setNextDocId(int) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.common.lucene.docset.DocIdSetCollector
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.common.lucene.Lucene.ExistsCollector
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.common.lucene.MultiCollector
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
 
setNextReader(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
setNextReader(IndexReader) - Method in interface org.elasticsearch.common.lucene.search.function.ScoreFunction
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.common.lucene.search.NoopCollector
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.index.field.data.support.NumericFieldDataComparator
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.index.field.function.sort.DoubleFieldsFunctionDataComparator
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
setNextReader(IndexReader) - Method in class org.elasticsearch.index.query.CustomScoreQueryParser.ScriptScoreFunction
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.index.search.child.ChildCollector
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.index.search.nested.NestedChildrenCollector
 
setNextReader(IndexReader) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setNextReader(IndexReader) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 
setNextReader(IndexReader) - Method in interface org.elasticsearch.script.SearchScript
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
setNextReader(IndexReader) - Method in class org.elasticsearch.search.lookup.DocLookup
 
setNextReader(IndexReader) - Method in class org.elasticsearch.search.lookup.FieldsLookup
 
setNextReader(IndexReader) - Method in class org.elasticsearch.search.lookup.SearchLookup
 
setNextReader(IndexReader) - Method in class org.elasticsearch.search.lookup.SourceLookup
 
setNextScore(float) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setNextScore(float) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 
setNextScore(float) - Method in interface org.elasticsearch.script.SearchScript
 
setNextSource(Map<String, Object>) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setNextSource(Map<String, Object>) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 
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
 
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.mvel.MvelScriptEngineService.MvelExecutableScript
 
setNextVar(String, Object) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 
setNodeEnv(NodeEnvironment) - Method in class org.elasticsearch.gateway.shared.SharedStorageGateway
 
setNodes(List<Node>) - Method in class org.elasticsearch.common.lucene.spatial.prefix.NodeTokenStream
Sets the Nodes that will be converted into their indexable form
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.hotthreads.NodesHotThreadsRequestBuilder
 
setNodesIds(String...) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
 
setNodesIds(String...) - Method in class org.elasticsearch.action.admin.cluster.node.restart.NodesRestartRequestBuilder
The nodes ids to restart.
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.admin.cluster.node.stats.NodesStatsRequestBuilder
 
setNodesProvider(DiscoveryNodesProvider) - Method in class org.elasticsearch.discovery.zen.ping.multicast.MulticastZenPing
 
setNodesProvider(DiscoveryNodesProvider) - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
setNodesProvider(DiscoveryNodesProvider) - Method in interface org.elasticsearch.discovery.zen.ping.ZenPing
 
setNodesProvider(DiscoveryNodesProvider) - Method in class org.elasticsearch.discovery.zen.ping.ZenPingService
 
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.
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.
setOmitTermFreqAndPositions(boolean) - Method in class org.elasticsearch.common.lucene.uid.UidField
 
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.delete.DeleteRequestBuilder
Controls if the operation will be executed on a separate thread when executed locally.
setOperationThreaded(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
Controls if the operation will be executed on a separate thread when executed locally.
setOperationThreaded(boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Controls if the operation will be executed on a separate thread when executed locally.
setOperationThreaded(boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Controls if the operation will be executed on a separate thread when executed locally.
setOperationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
Controls the operation threading model.
setOperationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
Controls the operation threading model.
setOperationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
Controls the operation threading model.
setOperationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
Controls the operation threading model.
setOperationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.count.CountRequestBuilder
Controls the operation threading model.
setOperationThreading(SearchOperationThreading) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Controls the the search operation threading model.
setOperationThreading(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Sets the string representation of the operation threading model.
setOperationThreading(SearchOperationThreading) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
Controls the the search operation threading model.
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
Sets a string representation of the IndexRequestBuilder.setOpType(org.elasticsearch.action.index.IndexRequest.OpType).
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
Deprecated. Replaced by UTF8StreamWriter.setOutput(OutputStream)
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.update.UpdateRequestBuilder
 
setPendingCount(int) - Method in class jsr166y.CountedCompleter
Sets the pending count to the given value.
setPercentTermsToMatch(float) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder
The percent of the terms to match for each field.
setPercentTermsToMatch(float) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
setPercolate(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Causes the index request document to be percolated.
setPercolate(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Causes the updated document to be percolated.
setPersistentSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
setPersistentSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
setPersistentSettings(String) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
setPersistentSettings(Map) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
setPhraseSlop(int) - Method in class org.elasticsearch.index.search.MatchQuery
 
setPreference(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
Sets the shard preference.
setPreference(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
Sets the preference to execute the search.
setPreference(String) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
Sets the preference to execute the search.
setPreference(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Sets the preference to execute the search.
setPreferLocal(boolean) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
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.
setPreferLocal(boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
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(BytesReference) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
The query source to validate.
setQuery(BytesReference, boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
The query source to validate.
setQuery(byte[]) - 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 source to execute.
setQuery(BytesReference, boolean) - Method in class org.elasticsearch.action.count.CountRequestBuilder
The query source to execute.
setQuery(byte[]) - Method in class org.elasticsearch.action.count.CountRequestBuilder
The query source to execute.
setQuery(QueryBuilder) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query source to execute.
setQuery(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query source to execute.
setQuery(Map<String, Object>) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query source to execute in the form of a map.
setQuery(XContentBuilder) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query source to execute in the form of a builder.
setQuery(byte[]) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query source to execute.
setQuery(BytesReference) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query source to execute.
setQuery(BytesReference, boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query source to execute.
setQuery(byte[], int, int, boolean) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
The query source 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.
setQueryHint(String) - Method in class org.elasticsearch.action.count.CountRequestBuilder
A query hint to optionally later be used when routing the request.
setQueryHint(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
A query hint to optionally later be used when routing the request.
setRawResult(Void) - Method in class jsr166y.CountedCompleter
Requires null completion value.
setRawResult(V) - Method in class jsr166y.ForkJoinTask
Forces the given value to be returned as a result.
setRawResult(Void) - Method in class jsr166y.RecursiveAction
Requires null completion value.
setRawResult(V) - Method in class jsr166y.RecursiveTask
 
setRealtime(Boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
 
setRealtime(Boolean) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
 
setRecovery(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
Should the status include recovery information.
setRefresh(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
 
setRefresh(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
Should refresh be performed after the optimization.
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.
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.update.UpdateRequestBuilder
Sets the replication type.
setResolveAddress(boolean) - Static method in class org.elasticsearch.common.transport.InetSocketTransportAddress
 
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.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.explain.ExplainRequestBuilder
Sets the routing for sharding.
setRouting(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
Controls the shard routing of the request.
setRouting(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
Controls the shard routing of the request.
setRouting(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
A comma separated list of routing values to control the shards the search will be executed on.
setRouting(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
The routing values to control the shards that the search will be executed on.
setRouting(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Controls the shard routing of the request.
setScorer(Scorer) - Method in class org.elasticsearch.common.lucene.docset.DocIdSetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.common.lucene.Lucene.ExistsCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.common.lucene.MultiCollector
 
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.field.function.sort.DoubleFieldsFunctionDataComparator
 
setScorer(Scorer) - Method in class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
setScorer(Scorer) - Method in class org.elasticsearch.index.search.child.ChildCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.index.search.nested.NestedChildrenCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.script.AbstractSearchScript
 
setScorer(Scorer) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 
setScorer(Scorer) - Method in interface org.elasticsearch.script.SearchScript
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.AbstractFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.geodistance.ScriptGeoDistanceFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.histogram.bounded.BoundedValueScriptHistogramFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ScriptHistogramFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.histogram.unbounded.ValueScriptHistogramFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.range.ScriptRangeFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.statistical.ScriptStatisticalFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.strings.ScriptTermsStringFieldFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.search.lookup.DocLookup
 
setScorer(Scorer) - Method in class org.elasticsearch.search.lookup.SearchLookup
 
setScript(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
The script to execute.
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.
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.
setSeed(long) - Method in class jsr166y.ThreadLocalRandom
Throws UnsupportedOperationException.
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.indices.create.CreateIndexRequestBuilder
The settings to created the index with.
setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
The settings to created 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 crete the index with (either json/yaml/properties format)
setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
The settings to crete the index with (either json/yaml/properties format)
setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequestBuilder
The settings update.
setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequestBuilder
The settings to update.
setSettings(String) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequestBuilder
The settings to update (either json/yaml/properties format)
setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequestBuilder
The settings to update (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)
setShardsAllocator(Class<? extends ShardsAllocator>) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocatorModule
 
setSimilarity(Similarity) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
 
setSize(int) - Method in class jsr166e.extra.ReadMostlyVector
See Vector.setSize(int)
setSize(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
The number of search hits to return.
setSlop(int) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
Sets the phrase slop for this query.
setSnapshot(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequestBuilder
Should the status include recovery information.
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(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, 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(Map<String, Object>) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Index the Map as a JSON.
setSource(Map<String, Object>, XContentType) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Index the Map as the provided content type.
setSource(String) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Sets the document source to index.
setSource(XContentBuilder) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Sets the content source to index.
setSource(BytesReference) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Sets the document to index in bytes form.
setSource(BytesReference, boolean) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Sets the document to index in bytes form.
setSource(byte[]) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
Sets the document to index in bytes form.
setSource(byte[], int, int) - Method in class org.elasticsearch.action.percolate.PercolateRequestBuilder
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.percolate.PercolateRequestBuilder
Sets the document to index in bytes form.
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
 
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
 
setStore(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
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.
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(int) - 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.alias.IndicesAliasesRequestBuilder
Sets operation timeout.
setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
Timeout to wait for the operation to be acknowledged by current cluster nodes.
setTimeout(String) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
Timeout to wait for the index creation to be acknowledged by current cluster nodes.
setTimeout(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
Timeout to wait for the index creation to be acknowledged by current cluster nodes.
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.admin.indices.mapping.put.PutMappingRequestBuilder
Timeout to wait till the put mapping gets acknowledged of all current cluster nodes.
setTimeout(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
Timeout to wait till the put mapping gets acknowledged of all current cluster nodes.
setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
Timeout to wait for the operation to be acknowledged by current cluster nodes.
setTimeout(String) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
setTimeout(String) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
Timeout to wait for the index creation to be acknowledged by current cluster nodes.
setTimeout(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
Timeout to wait for the index creation to be acknowledged by current cluster nodes.
setTimeout(TimeValue) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
A timeout to wait if the delete by query operation can't be performed immediately.
setTimeout(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder
A timeout to wait if the delete by query operation can't be performed immediately.
setTimeout(TimeValue) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
A timeout to wait if the index operation can't be performed immediately.
setTimeout(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
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.update.UpdateRequestBuilder
A timeout to wait if the index operation can't be performed immediately.
setTimeout(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
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_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_READ_ONLY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
 
SETTING_READ_ONLY - Static variable in class org.elasticsearch.cluster.metadata.MetaData
 
SETTING_VERSION_CREATED - Static variable in class org.elasticsearch.cluster.metadata.IndexMetaData
 
settings() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
The settings of the node.
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.indices.create.CreateIndexRequest
The settings to created the index with.
settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
The settings to created the index with.
settings(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
The settings to crete 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 crete the index with (either json/yaml/properties format)
settings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
The settings to created the index with.
settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
The settings to created the index with.
settings(String) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
The settings to crete the index with (either json/yaml/properties format)
settings(Map) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
The settings to crete the index with (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 interface org.elasticsearch.client.internal.InternalClient
 
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.MetaDataCreateIndexService.Request
 
settings(Settings) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
 
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.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 - Variable in class org.elasticsearch.river.AbstractRiverComponent
 
settings() - Method in class org.elasticsearch.river.RiverSettings
 
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
 
SettingsLoader.Helper() - Constructor for class org.elasticsearch.common.settings.loader.SettingsLoader.Helper
 
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 interface org.elasticsearch.index.service.IndexService
 
settingsService() - Method in class org.elasticsearch.index.service.InternalIndexService
 
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.search.SearchRequestBuilder
Applies when sorting, and controls if scores will be tracked as well.
setTransientSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
setTransientSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
setTransientSettings(String) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
setTransientSettings(Map) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
 
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.
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.indices.mapping.delete.DeleteMappingRequestBuilder
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.percolate.PercolateRequestBuilder
Sets the type of the document to percolate.
setType(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
Sets the type of the indexed document.
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.search.SearchRequestBuilder
The document types to execute the search against.
setTypes(String[]) - Static method in class org.elasticsearch.index.query.QueryParseContext
 
setTypesWithPrevious(String[]) - Static method in class org.elasticsearch.index.query.QueryParseContext
 
setUid(String) - Method in class org.elasticsearch.common.lucene.uid.UidField
 
setup() - Static method in class org.elasticsearch.common.netty.NettyStaticSetup
 
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.
setUseDisMax(boolean) - Method in class org.elasticsearch.index.search.MultiMatchQuery
 
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
 
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.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(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
Should each SearchHit be returned with its version.
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.index.IndexRequestBuilder
Sets the versioning type.
setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
 
setWaitForGreenStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
 
setWaitForMerge(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequestBuilder
Should the call block until the optimize completes.
setWaitForNodes(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
Waits for N number of nodes.
setWaitForOperations(boolean) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
 
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
 
setWarmer(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
 
sha(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-1 digest and returns the value as a byte[].
sha(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-1 digest and returns the value as a byte[].
sha(String) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-1 digest and returns the value as a byte[].
sha256(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-256 digest and returns the value as a byte[].
sha256(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-256 digest and returns the value as a byte[].
sha256(String) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-256 digest and returns the value as a byte[].
sha256Hex(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-256 digest and returns the value as a hex string.
sha256Hex(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-256 digest and returns the value as a hex string.
sha256Hex(String) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-256 digest and returns the value as a hex string.
sha384(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-384 digest and returns the value as a byte[].
sha384(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-384 digest and returns the value as a byte[].
sha384(String) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-384 digest and returns the value as a byte[].
sha384Hex(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-384 digest and returns the value as a hex string.
sha384Hex(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-384 digest and returns the value as a hex string.
sha384Hex(String) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-384 digest and returns the value as a hex string.
sha512(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-512 digest and returns the value as a byte[].
sha512(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-512 digest and returns the value as a byte[].
sha512(String) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-512 digest and returns the value as a byte[].
sha512Hex(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-512 digest and returns the value as a hex string.
sha512Hex(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-512 digest and returns the value as a hex string.
sha512Hex(String) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-512 digest and returns the value as a hex string.
shaHex(byte[]) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-1 digest and returns the value as a hex string.
shaHex(InputStream) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-1 digest and returns the value as a hex string.
shaHex(String) - Static method in class org.elasticsearch.common.Digest
Calculates the SHA-1 digest and returns the value as a hex string.
ShapeBuilder - Class in org.elasticsearch.common.geo
Utility class for building Shape instances like Point, Rectangle and Polygons.
ShapeBuilder.PolygonBuilder - Class in org.elasticsearch.common.geo
Builder for creating a Shape instance of a Polygon
ShapeBuilder.PolygonBuilder() - Constructor for class org.elasticsearch.common.geo.ShapeBuilder.PolygonBuilder
 
ShapeBuilder.RectangleBuilder - Class in org.elasticsearch.common.geo
Builder for creating a Rectangle instance
ShapeBuilder.RectangleBuilder() - Constructor for class org.elasticsearch.common.geo.ShapeBuilder.RectangleBuilder
 
shapeRel - Variable in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
ShapeRelation - Enum in org.elasticsearch.common.geo
Enum representing the relationship between a Query / Filter Shape and indexed Shapes that will be used to determine if a Document should be matched or not
ShapesAvailability - Class in org.elasticsearch.common.geo
 
shard() - 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
 
shard(int) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
shard(int) - Method in interface org.elasticsearch.index.service.IndexService
 
shard(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
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.
shardAction - Variable in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
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.index
Delete by query request to execute on a specific shard.
ShardDeleteResponse - Class in org.elasticsearch.action.delete.index
Delete response executed on a specific shard.
ShardDeleteResponse() - Constructor for class org.elasticsearch.action.delete.index.ShardDeleteResponse
 
ShardDeleteResponse(long, boolean) - Constructor for class org.elasticsearch.action.delete.index.ShardDeleteResponse
 
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.memory.ByteBufferIndexStore
 
shardDirectory() - Method in class org.elasticsearch.index.store.ram.RamIndexStore
 
ShardDoc - Interface in org.elasticsearch.search.controller
 
shardFailed(ShardRouting, String) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
 
shardFailures() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
 
shardFailures() - Method in class org.elasticsearch.action.search.SearchResponse
The failures that occurred during the search.
shardFailures() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationResponse
The list of shard failures exception.
ShardFieldDoc - Class in org.elasticsearch.search.controller
 
ShardFieldDoc(SearchShardTarget, int, float) - Constructor for class org.elasticsearch.search.controller.ShardFieldDoc
 
ShardFieldDoc(SearchShardTarget, int, float, Object[]) - Constructor for class org.elasticsearch.search.controller.ShardFieldDoc
 
ShardFieldDocSortedHitQueue - Class in org.apache.lucene.search
 
ShardFieldDocSortedHitQueue(SortField[], int) - Constructor for class org.apache.lucene.search.ShardFieldDocSortedHitQueue
Creates a hit queue sorted by the given list of fields.
shardGatewayClass() - Method in class org.elasticsearch.index.gateway.fs.FsIndexGateway
 
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, IndexCache) - 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.admin.indices.segments.IndexShardSegments
 
shardId() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
 
shardId() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
shardId() - Method in class org.elasticsearch.action.bulk.BulkShardResponse
 
shardId() - Method in class org.elasticsearch.action.delete.index.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.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.broadcast.BroadcastShardOperationResponse
 
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.support.single.shard.TransportShardSingleOperationAction.ShardSingleOperationRequest
 
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
 
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.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.indices.recovery.StartRecoveryRequest
 
shardId() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
shardId() - Method in class org.elasticsearch.indices.warmer.IndicesWarmer.WarmerContext
 
shardId() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
shardId() - Method in class org.elasticsearch.search.SearchShardTarget
 
shardIds() - Method in interface org.elasticsearch.index.service.IndexService
 
shardIds() - Method in class org.elasticsearch.index.service.InternalIndexService
 
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) - Constructor for class org.elasticsearch.index.indexing.ShardIndexingService
 
shardIndexLocations(ShardId) - Method in class org.elasticsearch.index.store.fs.FsIndexStore
 
ShardIndexWarmerService - Class in org.elasticsearch.index.warmer
 
ShardIndexWarmerService(ShardId, Settings) - Constructor for class org.elasticsearch.index.warmer.ShardIndexWarmerService
 
shardInjector(int) - Method in interface org.elasticsearch.index.service.IndexService
 
shardInjector(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
shardInjectorSafe(int) - Method in interface org.elasticsearch.index.service.IndexService
 
shardInjectorSafe(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
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
 
shardLocations(ShardId) - Method in class org.elasticsearch.index.store.fs.FsIndexStore
 
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, int) - 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(ShardGatewaySnapshotRequest) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
shardOperation(ShardOptimizeRequest) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
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
 
shardOperation(ShardValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
shardOperation(ShardCountRequest) - Method in class org.elasticsearch.action.count.TransportCountAction
 
shardOperation(ExplainRequest, int) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
shardOperation(GetRequest, int) - Method in class org.elasticsearch.action.get.TransportGetAction
 
shardOperation(MultiGetShardRequest, int) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
shardOperation(PercolateRequest, int) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
shardOperation(ShardRequest) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
shardOperation(Request, int) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
shardOperation(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
shardOperation(Request, int) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
shardOperation(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
shardOperation(UpdateRequest, ActionListener<UpdateResponse>, int) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
ShardOperationFailedException - Interface in org.elasticsearch.action
An exception indicating that a failure occurred performing an operation on the shard.
shardOperationOnPrimary(ClusterState, TransportShardReplicationOperationAction<BulkShardRequest, BulkShardRequest, BulkShardResponse>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
shardOperationOnPrimary(ClusterState, TransportShardReplicationOperationAction<ShardDeleteRequest, ShardDeleteRequest, ShardDeleteResponse>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
shardOperationOnPrimary(ClusterState, TransportShardReplicationOperationAction<DeleteRequest, DeleteRequest, DeleteResponse>.PrimaryOperationRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
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<ShardDeleteRequest, ShardDeleteRequest, ShardDeleteResponse>.ReplicaOperationRequest) - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
shardOperationOnReplica(TransportShardReplicationOperationAction<DeleteRequest, DeleteRequest, DeleteResponse>.ReplicaOperationRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
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
 
shardPath(int) - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexGateway
 
shardPath(BlobPath, String, int) - Static method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexGateway
 
shardPath - Variable in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
ShardReplicationOperationRequest - Class in org.elasticsearch.action.support.replication
 
ShardReplicationOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
shardRouting() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
 
shardRouting() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
The shard routing information (cluster wide shard state).
shardRouting() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The shard routing information (cluster wide shard state).
ShardRouting - Interface in org.elasticsearch.cluster.routing
Shard routing represents the state of a shard instance allocated in the cluster.
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
The state of the shard as defined by the cluster.
shards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
shards(ClusterState, AnalyzeRequest) - 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, GatewaySnapshotRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
The snapshot request works against all primary shards.
shards(ClusterState, OptimizeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
The refresh request works against *all* shards.
shards(ClusterState, RefreshRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
The refresh request works against *all* shards.
shards() - 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).
shards() - Method in class org.elasticsearch.action.admin.indices.segments.IndexShardSegments
 
shards(ClusterState, IndicesSegmentsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
Segments goes across *all* active shards.
shards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
 
shards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
 
shards() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
shards(ClusterState, IndicesStatsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
Status goes across *all* shards.
shards() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
shards() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
A shard id to index shard status map (note, index shard status is the replication shard group that maps to the shard id).
shards - Variable in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
shards() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
shards(ClusterState, IndicesStatusRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Status goes across *all* shards.
shards(ClusterState, ValidateQueryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
shards(ClusterState, BulkShardRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
shards(ClusterState, CountRequest, String[]) - Method in class org.elasticsearch.action.count.TransportCountAction
 
shards(IndexDeleteRequest) - Method in class org.elasticsearch.action.delete.index.TransportIndexDeleteAction
 
shards(ClusterState, ShardDeleteRequest) - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
shards(ClusterState, DeleteRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
shards(IndexDeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
shards(ClusterState, ShardDeleteByQueryRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
shards(ClusterState, ExplainRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
shards(ClusterState, GetRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
 
shards(ClusterState, MultiGetShardRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
shards(ClusterState, IndexRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
shards(ClusterState, PercolateRequest) - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
shards(ClusterState, Request, String[]) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
shards(Request) - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
shards(ClusterState, Request) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
shards(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
Can return null to execute on this local node.
shards(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
Should return an iterator with a single shard!
shards(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
shards(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
shards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
shards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
shards(ClusterState, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
shards(ClusterState, String, int) - Method in class org.elasticsearch.cluster.routing.operation.plain.PlainOperationRouting
 
shards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
shardSafe(int) - Method in interface org.elasticsearch.index.service.IndexService
 
shardSafe(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
ShardsAllocator - Interface in org.elasticsearch.cluster.routing.allocation.allocator
 
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
 
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
 
ShardScoreDoc - Class in org.elasticsearch.search.controller
 
ShardScoreDoc(SearchShardTarget, int, float) - Constructor for class org.elasticsearch.search.controller.ShardScoreDoc
 
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(String, SearchShardTarget) - Constructor for class org.elasticsearch.action.search.ShardSearchFailure
 
ShardSearchModule - Class in org.elasticsearch.index.search.stats
 
ShardSearchModule() - Constructor for class org.elasticsearch.index.search.stats.ShardSearchModule
 
ShardSearchService - Class in org.elasticsearch.index.search.stats
 
ShardSearchService(ShardId, Settings, ShardSlowLogSearchService) - Constructor for class org.elasticsearch.index.search.stats.ShardSearchService
 
ShardSegments - Class in org.elasticsearch.action.admin.indices.segments
 
ShardSegments(ShardRouting, List<Segment>) - Constructor for class org.elasticsearch.action.admin.indices.segments.ShardSegments
 
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
 
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.
ShardsLimitAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
 
ShardsLimitAllocationDecider(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
 
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
 
ShardSlowLogSearchService.SlowLogSearchContextPrinter(SearchContext, long, boolean) - Constructor for class org.elasticsearch.index.search.slowlog.ShardSlowLogSearchService.SlowLogSearchContextPrinter
 
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
 
shardsRoutingFor(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
shardsRoutingFor(String, int) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
shardStarted(ShardRouting, String) - 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, ThreadPool) - 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 - Class in org.elasticsearch.action.admin.indices.stats
 
ShardStatus - Class in org.elasticsearch.action.admin.indices.status
Shard instance (actual allocated shard) status.
shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
shardsWithState(String, ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
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 interface org.elasticsearch.search.controller.ShardDoc
 
shardTarget() - Method in class org.elasticsearch.search.controller.ShardFieldDoc
 
shardTarget() - Method in class org.elasticsearch.search.controller.ShardScoreDoc
 
shardTarget() - Method in class org.elasticsearch.search.count.CountSearchResult
 
shardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.count.CountSearchResult
 
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(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
 
shardTranslogLocations(ShardId) - Method in class org.elasticsearch.index.store.fs.FsIndexStore
 
share() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
SharedStorageGateway - Class in org.elasticsearch.gateway.shared
 
SharedStorageGateway(Settings, ThreadPool, ClusterService) - Constructor for class org.elasticsearch.gateway.shared.SharedStorageGateway
 
ShingleTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
ShingleTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
 
SHORT - Static variable in class org.elasticsearch.index.field.data.FieldDataType.DefaultTypes
 
ShortDocFieldData - Class in org.elasticsearch.index.field.data.shorts
 
ShortDocFieldData(ShortFieldData) - Constructor for class org.elasticsearch.index.field.data.shorts.ShortDocFieldData
 
shortField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
ShortFieldData - Class in org.elasticsearch.index.field.data.shorts
 
ShortFieldData(String, short[]) - Constructor for class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
ShortFieldData.ValueInDocProc - Interface in org.elasticsearch.index.field.data.shorts
 
ShortFieldData.ValueProc - Interface in org.elasticsearch.index.field.data.shorts
 
ShortFieldDataComparator - Class in org.elasticsearch.index.field.data.shorts
 
ShortFieldDataComparator(int, String, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.shorts.ShortFieldDataComparator
 
ShortFieldDataMissingComparator - Class in org.elasticsearch.index.field.data.shorts
 
ShortFieldDataMissingComparator(int, String, FieldDataCache, short) - Constructor for class org.elasticsearch.index.field.data.shorts.ShortFieldDataMissingComparator
 
ShortFieldDataType - Class in org.elasticsearch.index.field.data.shorts
 
ShortFieldDataType() - Constructor for class org.elasticsearch.index.field.data.shorts.ShortFieldDataType
 
ShortFieldMapper - Class in org.elasticsearch.index.mapper.core
 
ShortFieldMapper(FieldMapper.Names, int, String, Field.Index, Field.Store, float, boolean, FieldInfo.IndexOptions, Short, boolean) - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
ShortFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
ShortFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper.Builder
 
ShortFieldMapper.CustomShortNumericField - Class in org.elasticsearch.index.mapper.core
 
ShortFieldMapper.CustomShortNumericField(NumberFieldMapper, short) - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper.CustomShortNumericField
 
ShortFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
ShortFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper.Defaults
 
ShortFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
ShortFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.ShortFieldMapper.TypeParser
 
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() - Method in interface org.elasticsearch.common.xcontent.XContentParser
 
shortValue(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
shortValue(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
shortValue(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
shortValue(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
shortValue(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
shortValue(int) - Method in class org.elasticsearch.index.field.data.NumericFieldData
Returns the value of the specified number as a short.
shortValue(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
should(FilterBuilder) - Method in class org.elasticsearch.index.query.BoolFilterBuilder
Adds a filter that should appear in the matching documents.
should(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
Adds a query that should appear in the matching documents.
shouldConnectTo(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
Should this node form a connection to the provided node.
shouldExport(Settings) - Static method in class org.elasticsearch.jmx.JmxService
 
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?
shutdown() - Method in class jsr166y.ForkJoinPool
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in class org.elasticsearch.threadpool.ThreadPool
 
shutdownNow() - Method in class jsr166y.ForkJoinPool
Attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks.
shutdownNow() - Method in class org.elasticsearch.threadpool.ThreadPool
 
sigar() - Method in class org.elasticsearch.monitor.sigar.SigarService
 
sigarAvailable() - Method in class org.elasticsearch.monitor.sigar.SigarService
 
SigarFsProbe - Class in org.elasticsearch.monitor.fs
 
SigarFsProbe(Settings, NodeEnvironment, SigarService) - Constructor for class org.elasticsearch.monitor.fs.SigarFsProbe
 
SigarNetworkProbe - Class in org.elasticsearch.monitor.network
 
SigarNetworkProbe(Settings, SigarService) - Constructor for class org.elasticsearch.monitor.network.SigarNetworkProbe
 
SigarOsProbe - Class in org.elasticsearch.monitor.os
 
SigarOsProbe(Settings, SigarService) - Constructor for class org.elasticsearch.monitor.os.SigarOsProbe
 
SigarProcessProbe - Class in org.elasticsearch.monitor.process
 
SigarProcessProbe(Settings, SigarService) - Constructor for class org.elasticsearch.monitor.process.SigarProcessProbe
 
SigarService - Class in org.elasticsearch.monitor.sigar
 
SigarService(Settings) - Constructor for class org.elasticsearch.monitor.sigar.SigarService
 
sign(byte) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the sign for byte value x.
sign(double) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the sign for double precision x.
sign(float) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the sign for float value x.
sign(int) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the sign for int value x.
sign(long) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the sign for long value x.
sign(short) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the sign for short value x.
signum(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
signum(Float) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
similarity(String) - Method in class org.elasticsearch.index.similarity.SimilarityService
 
SimilarityModule - Class in org.elasticsearch.index.similarity
 
SimilarityModule(Settings) - Constructor for class org.elasticsearch.index.similarity.SimilarityModule
 
SimilarityProvider<T extends org.apache.lucene.search.Similarity> - Interface in org.elasticsearch.index.similarity
 
SimilarityProviderFactory - Interface in org.elasticsearch.index.similarity
 
similarityService() - Method in class org.elasticsearch.index.query.QueryParseContext
 
similarityService() - Method in interface org.elasticsearch.index.service.IndexService
 
similarityService() - Method in class org.elasticsearch.index.service.InternalIndexService
 
SimilarityService - Class in org.elasticsearch.index.similarity
 
SimilarityService(Index) - Constructor for class org.elasticsearch.index.similarity.SimilarityService
 
SimilarityService(Index, Settings, Map<String, SimilarityProviderFactory>) - Constructor for class org.elasticsearch.index.similarity.SimilarityService
 
similarityService() - Method in class org.elasticsearch.search.internal.SearchContext
 
SIMPLE_MAP_FACTORY - Static variable in class org.elasticsearch.common.xcontent.support.XContentMapConverter
 
SimpleAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
SimpleAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SimpleAnalyzerProvider
 
SimpleBloomCache - Class in org.elasticsearch.index.cache.bloom.simple
 
SimpleBloomCache(Index, Settings, ThreadPool) - Constructor for class org.elasticsearch.index.cache.bloom.simple.SimpleBloomCache
 
SimpleBoundaryScanner2 - Class in org.elasticsearch.common.lucene.search.vectorhighlight
A copy of Lucene SimpleBoundaryScanner.
SimpleBoundaryScanner2() - Constructor for class org.elasticsearch.common.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
SimpleBoundaryScanner2(int, char[]) - Constructor for class org.elasticsearch.common.lucene.search.vectorhighlight.SimpleBoundaryScanner2
 
SimpleDump - Class in org.elasticsearch.monitor.dump
 
SimpleDump(long, String, Map<String, Object>, File) - Constructor for class org.elasticsearch.monitor.dump.SimpleDump
 
SimpleDumpGenerator - Class in org.elasticsearch.monitor.dump
 
SimpleDumpGenerator(File, Map<String, DumpContributor>) - Constructor for class org.elasticsearch.monitor.dump.SimpleDumpGenerator
 
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
 
SimpleHashFunction() - Constructor for class org.elasticsearch.cluster.routing.operation.hash.simple.SimpleHashFunction
 
SimpleIdCache - Class in org.elasticsearch.index.cache.id.simple
 
SimpleIdCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.id.simple.SimpleIdCache
 
SimpleIdReaderCache - Class in org.elasticsearch.index.cache.id.simple
 
SimpleIdReaderCache(Object, ImmutableMap<String, SimpleIdReaderTypeCache>) - Constructor for class org.elasticsearch.index.cache.id.simple.SimpleIdReaderCache
 
SimpleIdReaderTypeCache - Class in org.elasticsearch.index.cache.id.simple
 
SimpleIdReaderTypeCache(String, ExtTObjectIntHasMap<HashedBytesArray>, HashedBytesArray[], int[]) - Constructor for class org.elasticsearch.index.cache.id.simple.SimpleIdReaderTypeCache
 
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.
simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
simpleMatchToIndexNames(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
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_INSTANCE_AND_SCOPE - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
 
SingleCustomOperationRequest - Class in org.elasticsearch.action.support.single.custom
 
SingleCustomOperationRequest() - Constructor for class org.elasticsearch.action.support.single.custom.SingleCustomOperationRequest
 
SingleFieldSelector - Class in org.elasticsearch.common.lucene.document
 
SingleFieldSelector() - Constructor for class org.elasticsearch.common.lucene.document.SingleFieldSelector
 
SingleFieldSelector(String) - Constructor for class org.elasticsearch.common.lucene.document.SingleFieldSelector
 
singles() - Method in class org.elasticsearch.common.unit.SizeValue
 
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
 
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_ANNOTATION - Static variable in class org.elasticsearch.common.inject.internal.Scoping
 
SINGLETON_INSTANCE - Static variable in class org.elasticsearch.common.inject.internal.Scoping
 
SingleValueByteFieldData - Class in org.elasticsearch.index.field.data.bytes
 
SingleValueByteFieldData(String, int[], byte[]) - Constructor for class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
SingleValueDoubleFieldData - Class in org.elasticsearch.index.field.data.doubles
 
SingleValueDoubleFieldData(String, int[], double[]) - Constructor for class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
SingleValueFloatFieldData - Class in org.elasticsearch.index.field.data.floats
 
SingleValueFloatFieldData(String, int[], float[]) - Constructor for class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
SingleValueGeoPointFieldData - Class in org.elasticsearch.index.mapper.geo
 
SingleValueGeoPointFieldData(String, int[], double[], double[]) - Constructor for class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
SingleValueIntFieldData - Class in org.elasticsearch.index.field.data.ints
 
SingleValueIntFieldData(String, int[], int[]) - Constructor for class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
SingleValueLongFieldData - Class in org.elasticsearch.index.field.data.longs
 
SingleValueLongFieldData(String, int[], long[]) - Constructor for class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
SingleValueShortFieldData - Class in org.elasticsearch.index.field.data.shorts
 
SingleValueShortFieldData(String, int[], short[]) - Constructor for class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
SingleValueStringFieldData - Class in org.elasticsearch.index.field.data.strings
 
SingleValueStringFieldData(String, int[], String[]) - Constructor for class org.elasticsearch.index.field.data.strings.SingleValueStringFieldData
 
sinh(double) - Static method in class org.elasticsearch.common.math.MathUtils
Returns the hyperbolic sine of x.
sinh(Double) - Static method in class org.elasticsearch.common.math.UnboxedMathUtils
 
size() - Method in class jsr166e.ConcurrentHashMapV8
size() - Method in class jsr166e.extra.ReadMostlyVector
 
size() - Method in class jsr166y.ConcurrentLinkedDeque
Returns the number of elements in this deque.
size() - Method in class jsr166y.LinkedTransferQueue
Returns the number of elements in this queue.
size() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
size() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
size() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
size() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
size() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
The number of shard routing instances.
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.MapBackedSet
 
size() - Method in class org.elasticsearch.common.inject.internal.Errors
 
size() - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Returns the current size of the buffer.
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 - Variable in class org.elasticsearch.common.util.BigLongArray
 
size() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
size() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommits
 
size() - Method in class org.elasticsearch.index.engine.Segment
 
size() - Method in class org.elasticsearch.index.store.StoreStats
 
size - Variable in class org.elasticsearch.index.translog.Translog.Location
 
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.SearchContext
 
size(int) - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
sizeActive() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
sizeActive() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
SizeFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
SizeFieldMapper() - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
SizeFieldMapper(boolean, Field.Store) - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
SizeFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
SizeFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
SizeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
SizeFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Defaults
 
SizeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
SizeFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.SizeFieldMapper.TypeParser
 
SizeHeaderFrameDecoder - Class in org.elasticsearch.transport.netty
 
SizeHeaderFrameDecoder() - Constructor for class org.elasticsearch.transport.netty.SizeHeaderFrameDecoder
 
sizeInBytes(ByteBufferAllocator.Type) - Method in interface org.apache.lucene.store.bytebuffer.ByteBufferAllocator
The size (in bytes) that is allocated for the provided type.
sizeInBytes() - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
Returns the size in bytes of the directory, chunk by buffer size.
sizeInBytes(ByteBufferAllocator.Type) - Method in class org.apache.lucene.store.bytebuffer.PlainByteBufferAllocator
 
sizeInBytes(ByteBufferAllocator.Type) - Method in class org.elasticsearch.cache.memory.ByteBufferCache
 
sizeInBytes() - Method in interface org.elasticsearch.common.bloom.BloomFilter
 
sizeInBytes() - Method in class org.elasticsearch.common.bloom.ObsBloomFilter
 
sizeInBytes() - Method in class org.elasticsearch.common.lucene.docset.AllDocSet
 
sizeInBytes() - Method in class org.elasticsearch.common.lucene.docset.AndDocSet
 
sizeInBytes() - Method in class org.elasticsearch.common.lucene.docset.DocSet
 
sizeInBytes() - Method in class org.elasticsearch.common.lucene.docset.FixedBitDocSet
 
sizeInBytes() - Method in class org.elasticsearch.common.lucene.docset.GetDocSet
 
sizeInBytes() - Method in class org.elasticsearch.common.lucene.docset.NotDocSet
 
sizeInBytes() - Method in class org.elasticsearch.common.lucene.docset.OpenBitDocSet
 
sizeInBytes() - Method in class org.elasticsearch.common.lucene.docset.OrDocSet
 
sizeInBytes() - Method in interface org.elasticsearch.index.cache.bloom.BloomCache
 
sizeInBytes(String) - Method in interface org.elasticsearch.index.cache.bloom.BloomCache
 
sizeInBytes() - Method in class org.elasticsearch.index.cache.bloom.none.NoneBloomCache
 
sizeInBytes(String) - Method in class org.elasticsearch.index.cache.bloom.none.NoneBloomCache
 
sizeInBytes() - Method in class org.elasticsearch.index.cache.bloom.simple.SimpleBloomCache
 
sizeInBytes(String) - Method in class org.elasticsearch.index.cache.bloom.simple.SimpleBloomCache
 
sizeInBytes() - Method in interface org.elasticsearch.index.cache.field.data.FieldDataCache
 
sizeInBytes(String) - Method in interface org.elasticsearch.index.cache.field.data.FieldDataCache
 
sizeInBytes() - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
sizeInBytes(String) - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
sizeInBytes() - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
sizeInBytes(String) - Method in class org.elasticsearch.index.cache.field.data.support.AbstractConcurrentMapFieldDataCache
 
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.engine.Segment
 
sizeInBytes() - Method in class org.elasticsearch.index.field.data.FieldData
 
sizeInBytes() - Method in class org.elasticsearch.index.store.StoreStats
 
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
 
skip(long) - Method in class org.elasticsearch.common.io.FastByteArrayInputStream
Skips n bytes of input from this input stream.
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(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.ByteBufferBytesReference
 
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
 
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
 
SMALL_THRESH - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This constant is accessible by subclasses for historical purposes.
smallBufferSizeInBytes - Variable in class org.apache.lucene.store.bytebuffer.PlainByteBufferAllocator
 
smartFieldMappers(String) - Method in class org.elasticsearch.index.query.QueryParseContext
 
smartFieldMappers(String) - Method in class org.elasticsearch.search.internal.SearchContext
 
smartName(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
Tries to find first based on DocumentFieldMappers.fullName(String), then by DocumentFieldMappers.indexName(String), and last by DocumentFieldMappers.name(String).
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.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.search.internal.SearchContext
 
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(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(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 JSON 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
 
SnappyCompressedIndexInput - Class in org.elasticsearch.common.compress.snappy
 
SnappyCompressedIndexInput(IndexInput, SnappyCompressorContext) - Constructor for class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexInput
 
SnappyCompressedIndexOutput - Class in org.elasticsearch.common.compress.snappy
 
SnappyCompressedIndexOutput(IndexOutput, SnappyCompressorContext) - Constructor for class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexOutput
 
SnappyCompressedStreamInput - Class in org.elasticsearch.common.compress.snappy
 
SnappyCompressedStreamInput(StreamInput, SnappyCompressorContext) - Constructor for class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamInput
 
SnappyCompressedStreamOutput - Class in org.elasticsearch.common.compress.snappy
 
SnappyCompressedStreamOutput(StreamOutput, SnappyCompressorContext) - Constructor for class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamOutput
 
SnappyCompressor - Class in org.elasticsearch.common.compress.snappy
 
SnappyCompressor() - Constructor for class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
SnappyCompressorContext - Class in org.elasticsearch.common.compress.snappy
 
SnappyCompressorContext(int, int) - Constructor for class org.elasticsearch.common.compress.snappy.SnappyCompressorContext
 
snapshot(boolean) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
Should the status include recovery information.
snapshot() - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
 
snapshot() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
Returns a snapshot of the index (for the last commit point).
snapshot(Engine.SnapshotHandler<T>) - Method in interface org.elasticsearch.index.engine.Engine
 
snapshot(SnapshotIndexCommit, Translog.Snapshot) - Method in interface org.elasticsearch.index.engine.Engine.SnapshotHandler
 
snapshot(Engine.SnapshotHandler<T>) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
snapshot(IndexShardGateway.Snapshot) - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
snapshot(IndexShardGateway.Snapshot) - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
Snapshots the given shard into the gateway.
snapshot(String) - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
Snapshots the given shard into the gateway.
snapshot(IndexShardGateway.Snapshot) - Method in class org.elasticsearch.index.gateway.local.LocalIndexShardGateway
 
snapshot(IndexShardGateway.Snapshot) - Method in class org.elasticsearch.index.gateway.none.NoneIndexShardGateway
 
snapshot(Engine.SnapshotHandler<T>) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
snapshot(Engine.SnapshotHandler<T>) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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 - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
 
snapshot - Variable in class org.elasticsearch.Version
 
snapshot() - Method in class org.elasticsearch.Version
 
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.
SnapshotFailedEngineException - Exception in org.elasticsearch.index.engine
 
SnapshotFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.SnapshotFailedEngineException
 
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
 
snapshotIterator() - Method in class jsr166e.extra.ReadMostlyVector
Returns an iterator operating over a snapshot copy of the elements of this collection created upon construction of the iterator.
snapshotOnClose() - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
 
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.index.deletionpolicy.SnapshotDeletionPolicy
Snapshots all the current commits in the index.
snapshotStatus() - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
 
SnapshotStatus - Class in org.elasticsearch.index.gateway
 
SnapshotStatus() - Constructor for class org.elasticsearch.index.gateway.SnapshotStatus
 
SnapshotStatus.Index - Class in org.elasticsearch.index.gateway
 
SnapshotStatus.Index() - Constructor for class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
SnapshotStatus.Stage - Enum in org.elasticsearch.index.gateway
 
SnapshotStatus.Translog - Class in org.elasticsearch.index.gateway
 
SnapshotStatus.Translog() - Constructor for class org.elasticsearch.index.gateway.SnapshotStatus.Translog
 
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
 
SoftFieldDataCache - Class in org.elasticsearch.index.cache.field.data.soft
 
SoftFieldDataCache(Index, Settings) - Constructor for class org.elasticsearch.index.cache.field.data.soft.SoftFieldDataCache
 
SOLARIS - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on SunOS.
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.SearchContext
 
sort() - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
sortDocs(Collection<? extends QuerySearchResultProvider>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
sortedShardList - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
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
 
sortStringArray(String[]) - Static method in class org.elasticsearch.common.Strings
Turn given source String array into sorted array.
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(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
 
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(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.explain.ExplainRequest
 
source(ExplainSourceBuilder) - 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.get.GetResponse
The source of the document if exists.
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(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.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(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() - Method in class org.elasticsearch.action.search.type.ParsedScrollId
 
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.Create
 
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.Index
 
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
 
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() - Method in class org.elasticsearch.index.mapper.SourceToParse
 
source() - Method in class org.elasticsearch.index.percolator.PercolatorExecutor.SourceRequest
 
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 - Variable in class org.elasticsearch.index.translog.Translog.Source
 
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.InternalSearchHit
 
source() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
source(BytesReference) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
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.get.GetResponse
The source of the document (As a map).
sourceAsMap() - Method in class org.elasticsearch.action.index.IndexRequest
 
sourceAsMap() - Method in class org.elasticsearch.cluster.metadata.MappingMetaData
Converts the serialized compressed form of the mappings into a parsed map.
sourceAsMap() - Method in class org.elasticsearch.index.get.GetResult
The source of the document (As a map).
sourceAsMap() - 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).
sourceAsString() - Method in class org.elasticsearch.action.get.GetResponse
The source of the document (as a string).
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).
SourceFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
SourceFieldMapper() - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
SourceFieldMapper(String, boolean, String, Boolean, long, String[], String[]) - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
SourceFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
SourceFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Builder
 
SourceFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
SourceFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
SourceFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
SourceFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.SourceFieldMapper.TypeParser
 
SourceFieldSelector - Class in org.elasticsearch.index.mapper.internal
An optimized field selector that loads just the uid.
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.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.action.get.GetResponse
Returns bytes reference, also un compress the source if needed.
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() - Method in interface org.elasticsearch.search.SearchHit
Returns bytes reference, also un compress the source if needed.
SourceScoreOrderFragmentsBuilder - Class in org.elasticsearch.search.highlight.vectorhighlight
 
SourceScoreOrderFragmentsBuilder(FieldMapper, SearchContext, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.highlight.vectorhighlight.SourceScoreOrderFragmentsBuilder
 
SourceSimpleFragmentsBuilder - Class in org.elasticsearch.search.highlight.vectorhighlight
 
SourceSimpleFragmentsBuilder(FieldMapper, SearchContext, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.highlight.vectorhighlight.SourceSimpleFragmentsBuilder
 
sourceToParse() - Method in class org.elasticsearch.index.mapper.ParseContext
 
SourceToParse - Class in org.elasticsearch.index.mapper
 
SourceToParse(XContentParser) - Constructor for class org.elasticsearch.index.mapper.SourceToParse
 
SourceToParse(BytesReference) - Constructor for class org.elasticsearch.index.mapper.SourceToParse
 
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
 
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
 
SPATIAL4J_AVAILABLE - Static variable in class org.elasticsearch.common.geo.ShapesAvailability
 
SPATIAL_CONTEXT - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
SpatialPrefixTree - Class in org.elasticsearch.common.lucene.spatial.prefix.tree
A Spatial Prefix Tree, or Trie, which decomposes shapes into prefixed strings at variable lengths corresponding to variable precision.
SpatialPrefixTree(SpatialContext, int) - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
SpatialStrategy - Class in org.elasticsearch.common.lucene.spatial
Abstraction of the logic used to index and filter Shapes.
SpatialStrategy(FieldMapper.Names, SpatialPrefixTree, double) - Constructor for class org.elasticsearch.common.lucene.spatial.SpatialStrategy
Creates a new SpatialStrategy that will index and Filter using the given field
spatialStrategy() - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
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.discovery.DiscoveryModule
 
spawnModules() - Method in class org.elasticsearch.gateway.GatewayModule
 
spawnModules() - Method in class org.elasticsearch.http.HttpServerModule
 
spawnModules() - Method in class org.elasticsearch.index.engine.EngineModule
 
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.river.RiverModule
 
spawnModules() - Method in class org.elasticsearch.search.SearchModule
 
spawnModules() - Method in class org.elasticsearch.search.TransportSearchModule
 
spawnModules() - Method in class org.elasticsearch.transport.TransportModule
 
split(String, String) - Static method in class org.elasticsearch.common.Strings
Split a String at the first occurrence of the delimiter.
splitArrayElementsIntoProperties(String[], String) - Static method in class org.elasticsearch.common.Strings
Take an array Strings and split each element based on the given 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.
splitIndices(String) - Static method in class org.elasticsearch.rest.action.support.RestActions
 
splitNodes(String) - Static method in class org.elasticsearch.rest.action.support.RestActions
 
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(String, char) - Static method in class org.elasticsearch.common.Strings
 
splitStringToSet(String, char) - Static method in class org.elasticsearch.common.Strings
 
splitTypes(String) - Static method in class org.elasticsearch.rest.action.support.RestActions
 
splitWS(String, boolean) - Static method in class org.elasticsearch.common.Strings
 
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
 
StackTraceElements - Class in org.elasticsearch.common.inject.internal
Creates stack trace elements for members.
StackTraceElements() - Constructor for class org.elasticsearch.common.inject.internal.StackTraceElements
 
stage() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
stage() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
stage() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
Stage - Enum in org.elasticsearch.common.inject
The stage we're running in.
stage() - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
stage() - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
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
 
StandardHtmlStripAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
StandardHtmlStripAnalyzerProvider(Index, Settings, 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.replication.TransportShardReplicationOperationAction.AsyncShardOperationAction
 
start(boolean) - 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).
start() - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
start() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
 
start() - Method in interface org.elasticsearch.common.component.LifecycleComponent
 
start() - Method in class org.elasticsearch.common.StopWatch
Start an unnamed task.
start(String) - Method in class org.elasticsearch.common.StopWatch
Start a named task.
start(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
start() - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
 
start() - Method in interface org.elasticsearch.index.engine.Engine
Starts the Engine.
start() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
start() - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
start(String) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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
 
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
 
started() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
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
 
StartedRerouteAllocation(AllocationDeciders, RoutingNodes, DiscoveryNodes, List<? extends ShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.allocation.StartedRerouteAllocation
 
startedShards() - Method in class org.elasticsearch.cluster.routing.allocation.StartedRerouteAllocation
 
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.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
startRecovery(StartRecoveryRequest, InternalIndexShard, 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>) - Constructor for class org.elasticsearch.indices.recovery.StartRecoveryRequest
Start recovery request.
startsWithIgnoreCase(String, String) - Static method in class org.elasticsearch.common.Strings
Test if the given String starts with the specified prefix, ignoring upper/lower case.
startTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
startTime() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
startTime() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
startTime - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
startTime(long) - Method in class org.elasticsearch.index.engine.Engine.Create
 
startTime() - Method in class org.elasticsearch.index.engine.Engine.Create
Returns operation start time in nanoseconds.
startTime(long) - Method in class org.elasticsearch.index.engine.Engine.Delete
 
startTime() - Method in class org.elasticsearch.index.engine.Engine.Delete
Returns operation start time in nanoseconds.
startTime(long) - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
startTime() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
Returns operation start time in nanoseconds.
startTime(long) - Method in class org.elasticsearch.index.engine.Engine.Index
 
startTime() - Method in class org.elasticsearch.index.engine.Engine.Index
Returns operation start time in nanoseconds.
startTime() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
startTime(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
startTime() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Start
 
startTime(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Start
 
startTime() - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
startTime(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
startTime() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Translog
 
startTime(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Translog
 
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.indices.recovery.RecoveryStatus
 
startTime() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
startTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector.LastGc
 
state() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
 
state() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The shard state (index/local state).
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(ClusterState) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
state(IndexMetaData.State) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
state() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
state(IndexMetaData.State) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Request
 
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() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
state() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
state() - Method in class org.elasticsearch.river.cluster.RiverClusterChangedEvent
 
state(RiverClusterState) - Method in class org.elasticsearch.river.cluster.RiverClusterState.Builder
 
STATE_NOT_RECOVERED_BLOCK - Static variable in class org.elasticsearch.gateway.GatewayService
 
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
 
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
 
StatisticalFacetCollector - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFacetCollector(String, String, SearchContext) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector
 
StatisticalFacetCollector.StatsProc - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFacetCollector.StatsProc() - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector.StatsProc
 
StatisticalFacetProcessor - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFacetProcessor
 
StatisticalFieldsFacetCollector - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFieldsFacetCollector(String, String[], SearchContext) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector
 
StatisticalFieldsFacetCollector.StatsProc - Class in org.elasticsearch.search.facet.statistical
 
StatisticalFieldsFacetCollector.StatsProc() - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector.StatsProc
 
statisticalScriptFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
StatisticalScriptFacetBuilder - Class in org.elasticsearch.search.facet.statistical
 
StatisticalScriptFacetBuilder(String) - Constructor for class org.elasticsearch.search.facet.statistical.StatisticalScriptFacetBuilder
 
stats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
 
stats(IndicesStatsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices stats.
stats(IndicesStatsRequest, ActionListener<IndicesStats>) - Method in interface org.elasticsearch.client.IndicesAdminClient
Indices stats.
stats(IndicesStatsRequest) - Method in class org.elasticsearch.client.support.AbstractIndicesAdminClient
 
stats(IndicesStatsRequest, ActionListener<IndicesStats>) - 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.IndexCache
 
stats() - Method in class org.elasticsearch.index.get.ShardGetService
 
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 interface org.elasticsearch.index.merge.scheduler.MergeSchedulerProvider
 
stats() - Method in class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
 
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.warmer.ShardIndexWarmerService
 
stats(boolean) - Method in interface org.elasticsearch.indices.IndicesService
Returns the node stats indices stats.
stats(boolean) - Method in class org.elasticsearch.indices.InternalIndicesService
 
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.fs.SigarFsProbe
 
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(boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.node.service.NodeService
 
stats(String...) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
The stats groups this request will be aggregated under.
stats() - Method in class org.elasticsearch.threadpool.ThreadPool
 
stats() - Method in class org.elasticsearch.transport.TransportService
 
StatsGroupsParseElement - Class in org.elasticsearch.index.search.stats
 
StatsGroupsParseElement() - Constructor for class org.elasticsearch.index.search.stats.StatsGroupsParseElement
 
status() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
status() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
status() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
status() - Method in class org.elasticsearch.action.search.SearchResponse
 
status() - Method in class org.elasticsearch.action.search.ShardSearchFailure
 
status() - Method in exception org.elasticsearch.action.UnavailableShardsException
 
status(IndicesStatusRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
The status of one or more indices.
status(IndicesStatusRequest, ActionListener<IndicesStatusResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
The status of one or more indices.
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 exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
 
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.VersionConflictEngineException
 
status() - Method in exception org.elasticsearch.index.mapper.MapperParsingException
 
status() - Method in exception org.elasticsearch.index.mapper.MergeMappingException
 
status() - Method in exception org.elasticsearch.index.mapper.StrictDynamicMappingException
 
status() - Method in exception org.elasticsearch.index.query.QueryParsingException
 
status() - Method in exception org.elasticsearch.indices.IndexAlreadyExistsException
 
status() - Method in exception org.elasticsearch.indices.IndexMissingException
 
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 exception org.elasticsearch.indices.TypeMissingException
 
status() - Method in class org.elasticsearch.rest.BytesRestResponse
 
status() - Method in interface org.elasticsearch.rest.RestResponse
 
status() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
status() - Method in class org.elasticsearch.rest.XContentRestResponse
 
status() - Method in exception org.elasticsearch.search.SearchParseException
 
status() - Method in exception org.elasticsearch.search.warmer.IndexWarmerMissingException
 
statusIsCompress(byte) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
statusIsError(byte) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
statusIsRequest(byte) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
statusSetCompress(byte) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
statusSetError(byte) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
statusSetRequest(byte) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
statusSetResponse(byte) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
stdDeviation() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
stdDeviation() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
Standard deviation of the values.
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
 
stop() - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
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
 
stop() - Method in class org.elasticsearch.node.internal.InternalNode
 
stop() - Method in interface org.elasticsearch.node.Node
Stops the node.
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
 
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
Set the set of stopwords.
stopWords(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
Set the set of stopwords.
store() - Method 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.gateway.blobstore.BlobStoreIndexShardGateway
 
store - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
STORE - Static variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
store - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
store() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
STORE - Static variable in class org.elasticsearch.index.mapper.core.BinaryFieldMapper.Defaults
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.Builder
 
store() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Builder
 
STORE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper.Defaults
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Builder
 
STORE - Static variable in class org.elasticsearch.index.mapper.internal.BoostFieldMapper.Defaults
 
STORE - Static variable in class org.elasticsearch.index.mapper.internal.IdFieldMapper.Defaults
 
STORE - Static variable in class org.elasticsearch.index.mapper.internal.IndexFieldMapper.Defaults
 
STORE - Static variable in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper.Defaults
 
store - Variable in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper.Builder
 
STORE - Static variable in class org.elasticsearch.index.mapper.internal.SourceFieldMapper.Defaults
 
STORE - Static variable in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
 
STORE - Static variable in class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
STORE - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
 
store() - Method in interface org.elasticsearch.index.service.IndexService
 
store() - Method in class org.elasticsearch.index.service.InternalIndexService
 
store() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
Store - Class in org.elasticsearch.index.store
 
Store(ShardId, Settings, IndexStore, IndexSettingsService, DirectoryService) - Constructor for class org.elasticsearch.index.store.Store
 
store() - Method in class org.elasticsearch.indices.NodeIndicesStats
 
stored() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
stored() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
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, long, String) - Constructor for class org.elasticsearch.index.store.StoreFileMetaData
 
StoreFileMetaData(String, long, long, String, Directory) - Constructor for class org.elasticsearch.index.store.StoreFileMetaData
 
storeFilesMetaData() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
 
StoreManagement - Class in org.elasticsearch.index.store
 
StoreManagement(Store) - Constructor for class org.elasticsearch.index.store.StoreManagement
 
StoreModule - Class in org.elasticsearch.index.store
 
StoreModule(Settings, IndexStore) - 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
 
storeSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
Returns the full store size in bytes, of both primaries and replicas.
storeSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
Returns the full store size in bytes, of both primaries and replicas.
storeSize() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The current size of the shard index storage.
storeStats() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
storeStats() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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
 
stream() - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
stream() - Method in class org.elasticsearch.index.translog.fs.FsChannelSnapshot
 
stream() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
Returns a stream of this snapshot.
stream(String) - Static method in class org.elasticsearch.search.facet.InternalFacet.Streams
 
Streamable - Interface in org.elasticsearch.common.io.stream
 
Streamables - Class in org.elasticsearch.common.io.stream
 
Streamables() - Constructor for class org.elasticsearch.common.io.stream.Streamables
 
streamContext() - Static method in class org.elasticsearch.search.internal.InternalSearchHits
 
streamInput() - Method in class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
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(StreamInput) - Method in interface org.elasticsearch.common.compress.Compressor
 
streamInput(StreamInput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressor
 
streamInput(StreamInput) - Method in class org.elasticsearch.common.compress.snappy.UnavailableSnappyCompressor
 
streamInput(StreamInput) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressor
 
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(StreamOutput) - Method in class org.elasticsearch.common.compress.snappy.UnavailableSnappyCompressor
 
streamOutput(StreamOutput) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressor
 
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
 
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.bounded.InternalBoundedCountHistogramFacet
 
streamType() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
streamType() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
streamType() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
streamType() - Method in interface 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.bytes.InternalByteTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
streamType() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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
 
StrictDynamicMappingException - Exception in org.elasticsearch.index.mapper
 
StrictDynamicMappingException(String, String) - Constructor for exception org.elasticsearch.index.mapper.StrictDynamicMappingException
 
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 - Static variable in class org.elasticsearch.index.field.data.FieldDataType.DefaultTypes
 
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
A string builder that can be used to construct complex names for example.
StringDocFieldData - Class in org.elasticsearch.index.field.data.strings
 
StringDocFieldData(StringFieldData) - Constructor for class org.elasticsearch.index.field.data.strings.StringDocFieldData
 
stringField(String) - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
StringFieldData - Class in org.elasticsearch.index.field.data.strings
 
StringFieldData(String, String[]) - Constructor for class org.elasticsearch.index.field.data.strings.StringFieldData
 
StringFieldDataType - Class in org.elasticsearch.index.field.data.strings
 
StringFieldDataType() - Constructor for class org.elasticsearch.index.field.data.strings.StringFieldDataType
 
StringFieldMapper - Class in org.elasticsearch.index.mapper.core
 
StringFieldMapper(FieldMapper.Names, Field.Index, Field.Store, Field.TermVector, float, boolean, FieldInfo.IndexOptions, String, NamedAnalyzer, NamedAnalyzer) - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper
 
StringFieldMapper(FieldMapper.Names, Field.Index, Field.Store, Field.TermVector, float, boolean, FieldInfo.IndexOptions, String, NamedAnalyzer, NamedAnalyzer, NamedAnalyzer, int, int) - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper
 
StringFieldMapper.Builder - Class in org.elasticsearch.index.mapper.core
 
StringFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.Builder
 
StringFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.core
 
StringFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.Defaults
 
StringFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.core
 
StringFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.core.StringFieldMapper.TypeParser
 
StringFieldsFunctionDataComparator - Class in org.elasticsearch.index.field.function.sort
 
StringFieldsFunctionDataComparator(int, SearchScript) - Constructor for class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
StringIdentityHashingStrategy - Class in org.elasticsearch.common.trove
A string based hash code with identity equality.
StringIdentityHashingStrategy() - Constructor for class org.elasticsearch.common.trove.StringIdentityHashingStrategy
 
StringOrdValFieldDataComparator - Class in org.elasticsearch.index.field.data.strings
 
StringOrdValFieldDataComparator(int, String, int, boolean, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
StringRestResponse - Class in org.elasticsearch.rest
 
StringRestResponse(RestStatus) - Constructor for class org.elasticsearch.rest.StringRestResponse
 
StringRestResponse(RestStatus, String) - Constructor for class org.elasticsearch.rest.StringRestResponse
 
Strings - Class in org.elasticsearch.common.inject.internal
String utilities.
Strings - Class in org.elasticsearch.common
 
StringStreamable - Class in org.elasticsearch.common.io.stream
 
StringStreamable() - Constructor for class org.elasticsearch.common.io.stream.StringStreamable
 
StringStreamable(String) - Constructor for class org.elasticsearch.common.io.stream.StringStreamable
 
StringText - Class in org.elasticsearch.common.text
A String only representation of the text.
StringText(String) - Constructor for class org.elasticsearch.common.text.StringText
 
StringValFieldDataComparator - Class in org.elasticsearch.index.field.data.strings
 
StringValFieldDataComparator(int, String, FieldDataCache) - Constructor for class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
stringValue() - Method in class org.elasticsearch.common.lucene.all.AllField
 
stringValue() - Method in class org.elasticsearch.common.lucene.uid.UidField
 
stringValue(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
stringValue() - Method in class org.elasticsearch.index.field.data.DocFieldData
 
stringValue(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
stringValue(int) - Method in class org.elasticsearch.index.field.data.FieldData
 
stringValue(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
stringValue(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
stringValue(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
stringValue(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
stringValue(int) - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
stringValue() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper.CustomNumericField
 
stringValue(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
stripFilenameExtension(String) - Static method in class org.elasticsearch.common.Strings
Strip the filename extension from the given path, e.g.
subAndCheck(int, int) - Static method in class org.elasticsearch.common.math.MathUtils
Subtract two integers, checking for overflow.
subAndCheck(long, long) - Static method in class org.elasticsearch.common.math.MathUtils
Subtract two long integers, checking for overflow.
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).
subList(int, int) - Method in class jsr166e.extra.ReadMostlyVector
 
submit(ForkJoinTask<T>) - Method in class jsr166y.ForkJoinPool
Submits a ForkJoinTask for execution.
submit(Callable<T>) - Method in class jsr166y.ForkJoinPool
 
submit(Runnable, T) - Method in class jsr166y.ForkJoinPool
 
submit(Runnable) - Method in class jsr166y.ForkJoinPool
 
submitRequest(DiscoveryNode, String, Streamable, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
 
submitRequest(DiscoveryNode, String, Streamable, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
 
submitStateUpdateTask(String, ClusterStateUpdateTask) - Method in interface org.elasticsearch.cluster.ClusterService
Submits a task that will update the cluster state.
submitStateUpdateTask(String, ClusterStateUpdateTask) - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
submitStateUpdateTask(String, RiverClusterStateUpdateTask) - Method in class org.elasticsearch.river.cluster.RiverClusterService
 
subReaders() - Method in class org.apache.lucene.index.ExtendedIndexSearcher
 
subSequence(int, int) - Method in class org.elasticsearch.common.io.FastStringReader
 
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.
SUBWORD_DELIM - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
successfulShards() - Method in class org.elasticsearch.action.delete.index.IndexDeleteResponse
The successful number of shards the delete by query was executed on.
successfulShards() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
The successful number of shards the delete by query was executed on.
successfulShards() - Method in class org.elasticsearch.action.search.SearchResponse
The successful number of shards the search was executed on.
successfulShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationResponse
The successful shards this request was executed on.
successulOps - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
SUFFIX - Static variable in class org.elasticsearch.common.lucene.LoggerInfoStream
 
suffixContent() - Method in class org.elasticsearch.rest.AbstractRestResponse
 
suffixContent() - Method in interface org.elasticsearch.rest.RestResponse
 
suffixContent() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
suffixContent() - Method in class org.elasticsearch.rest.XContentRestResponse
 
suffixContentLength() - Method in class org.elasticsearch.rest.AbstractRestResponse
 
suffixContentLength() - Method in interface org.elasticsearch.rest.RestResponse
 
suffixContentLength() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
suffixContentLength() - Method in class org.elasticsearch.rest.XContentRestResponse
 
suggestIndexGateway() - Method in class org.elasticsearch.gateway.fs.FsGateway
 
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
 
suggestUseCompoundFile() - Method in class org.elasticsearch.index.store.Store
Returns true by default.
sum() - Method in class jsr166e.DoubleAdder
Returns the current sum.
sum() - Method in class jsr166e.LongAdder
Returns the current sum.
sum(K) - Method in class jsr166e.LongAdderTable
Returns the sum associated with the given key, or zero if the key does not currently exist in the table.
sum() - Method in class org.elasticsearch.common.metrics.MeanMetric
 
sumAll() - Method in class jsr166e.LongAdderTable
Returns the sum totalled across all keys.
SUMMARY - Static variable in class org.elasticsearch.monitor.dump.summary.SummaryDumpContributor
 
SummaryDumpContributor - Class in org.elasticsearch.monitor.dump.summary
 
SummaryDumpContributor(String, Settings) - Constructor for class org.elasticsearch.monitor.dump.summary.SummaryDumpContributor
 
sumOfSquares() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
sumOfSquares() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The sum of squares of the values.
sumOfSquares() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector.StatsProc
 
sumOfSquares() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector.StatsProc
 
sumScores - Variable in class org.elasticsearch.index.search.child.TopChildrenQuery.ParentDoc
 
sumThenReset() - Method in class jsr166e.DoubleAdder
Equivalent in effect to DoubleAdder.sum() followed by DoubleAdder.reset().
sumThenReset() - Method in class jsr166e.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().
sumThenReset(K) - Method in class jsr166e.LongAdderTable
Resets the sum associated with the given key to zero if the key exists in the table.
sumThenResetAll() - Method in class jsr166e.LongAdderTable
Totals, then resets, the sums associated with all keys.
supertypeOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
Returns a type that represents an unknown supertype of bound.
suspendEncoding() - Method in class org.elasticsearch.common.Base64.OutputStream
Suspends encoding of the stream.
swap() - Method in class org.elasticsearch.monitor.os.OsInfo
 
swap() - Method in class org.elasticsearch.monitor.os.OsStats
 
SwedishAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
SwedishAnalyzerProvider(Index, Settings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SwedishAnalyzerProvider
 
SwitchDirectory - Class in org.elasticsearch.common.lucene.store
A Directory instance that switches files between two other Directory instances.
SwitchDirectory(Set<String>, Directory, Directory, boolean) - Constructor for class org.elasticsearch.common.lucene.store.SwitchDirectory
 
switchDoc(Document) - Method in class org.elasticsearch.index.mapper.ParseContext
 
sync(Collection<String>) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
sync(Collection<String>) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
sync(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
sync(Collection<String>) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
sync(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
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.
syncFile(File) - Static method in class org.elasticsearch.common.io.FileSystemUtils
 
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
 
syncWriteBlob(ImmutableBlobContainer, String, InputStream, long) - Static method in class org.elasticsearch.common.blobstore.support.BlobStores
 
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

tabify(int, String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
 
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 jsr166y.LinkedTransferQueue
 
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
 
target() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
targetNode() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
 
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.
tcp() - Method in class org.elasticsearch.monitor.network.NetworkStats
 
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
 
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
 
templates() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
term() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
term(String) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
term(String, String) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
term(String) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
term(String) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
term(String, String) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
term(String) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
term() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet.ByteEntry
 
term() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
term() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet.FloatEntry
 
term() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet.IntEntry
 
term() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet.LongEntry
 
term() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
term() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet.ShortEntry
 
term() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.StringEntry
 
term() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet.Entry
 
term() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
term() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
term() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
term() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
TERM_FACTORY - Static variable in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
TERM_FACTORY - Static variable in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
TERM_VECTOR - Static variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Defaults
 
termAsNumber() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet.ByteEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet.DoubleEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet.FloatEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet.IntEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet.LongEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet.LongEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet.ShortEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet.StringEntry
 
termAsNumber() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet.Entry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
termAsNumber() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
termAsNumber() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
TermFilter - Class in org.elasticsearch.common.lucene.search
A simple filter for a specific term.
TermFilter(Term) - Constructor for class org.elasticsearch.common.lucene.search.TermFilter
 
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
 
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
 
TermQueryPrefixTreeStrategy - Class in org.elasticsearch.common.lucene.spatial.prefix
Implementation of SpatialStrategy that uses TermQuerys / TermFilters to query and filter for Shapes related to other Shapes.
TermQueryPrefixTreeStrategy(FieldMapper.Names, SpatialPrefixTree, double) - Constructor for class org.elasticsearch.common.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
Creates a new TermQueryPrefixTreeStrategy
terms() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
termsAndFreqs(Term[], int[]) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
TermsByteFacetCollector - Class in org.elasticsearch.search.facet.terms.bytes
 
TermsByteFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector
 
TermsByteFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.bytes
 
TermsByteFacetCollector.AggregatorValueProc(TByteIntHashMap, Set<String>, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.AggregatorValueProc
 
TermsByteFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.bytes
 
TermsByteFacetCollector.StaticAggregatorValueProc(TByteIntHashMap) - Constructor for class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.StaticAggregatorValueProc
 
TermsByteOrdinalsFacetCollector - Class in org.elasticsearch.search.facet.terms.bytes
 
TermsByteOrdinalsFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>) - Constructor for class org.elasticsearch.search.facet.terms.bytes.TermsByteOrdinalsFacetCollector
 
TermsByteOrdinalsFacetCollector.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.bytes
 
TermsByteOrdinalsFacetCollector.AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.bytes.TermsByteOrdinalsFacetCollector.AggregatorPriorityQueue
 
TermsByteOrdinalsFacetCollector.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.bytes
 
TermsByteOrdinalsFacetCollector.ReaderAggregator(ByteFieldData) - Constructor for class org.elasticsearch.search.facet.terms.bytes.TermsByteOrdinalsFacetCollector.ReaderAggregator
 
TermsDoubleFacetCollector - Class in org.elasticsearch.search.facet.terms.doubles
 
TermsDoubleFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector
 
TermsDoubleFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.doubles
 
TermsDoubleFacetCollector.AggregatorValueProc(TDoubleIntHashMap, Set<String>, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.AggregatorValueProc
 
TermsDoubleFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.doubles
 
TermsDoubleFacetCollector.StaticAggregatorValueProc(TDoubleIntHashMap) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.StaticAggregatorValueProc
 
TermsDoubleOrdinalsFacetCollector - Class in org.elasticsearch.search.facet.terms.doubles
 
TermsDoubleOrdinalsFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector
 
TermsDoubleOrdinalsFacetCollector.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.doubles
 
TermsDoubleOrdinalsFacetCollector.AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector.AggregatorPriorityQueue
 
TermsDoubleOrdinalsFacetCollector.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.doubles
 
TermsDoubleOrdinalsFacetCollector.ReaderAggregator(DoubleFieldData) - Constructor for class org.elasticsearch.search.facet.terms.doubles.TermsDoubleOrdinalsFacetCollector.ReaderAggregator
 
termsFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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.
TermsFacetProcessor - Class in org.elasticsearch.search.facet.terms
 
TermsFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.terms.TermsFacetProcessor
 
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
 
TermsFloatFacetCollector - Class in org.elasticsearch.search.facet.terms.floats
 
TermsFloatFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector
 
TermsFloatFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.floats
 
TermsFloatFacetCollector.AggregatorValueProc(TFloatIntHashMap, Set<String>, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.AggregatorValueProc
 
TermsFloatFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.floats
 
TermsFloatFacetCollector.StaticAggregatorValueProc(TFloatIntHashMap) - Constructor for class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.StaticAggregatorValueProc
 
TermsFloatOrdinalsFacetCollector - Class in org.elasticsearch.search.facet.terms.floats
 
TermsFloatOrdinalsFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>) - Constructor for class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector
 
TermsFloatOrdinalsFacetCollector.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.floats
 
TermsFloatOrdinalsFacetCollector.AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector.AggregatorPriorityQueue
 
TermsFloatOrdinalsFacetCollector.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.floats
 
TermsFloatOrdinalsFacetCollector.ReaderAggregator(FloatFieldData) - Constructor for class org.elasticsearch.search.facet.terms.floats.TermsFloatOrdinalsFacetCollector.ReaderAggregator
 
TermsIntFacetCollector - Class in org.elasticsearch.search.facet.terms.ints
 
TermsIntFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector
 
TermsIntFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.ints
 
TermsIntFacetCollector.AggregatorValueProc(TIntIntHashMap, Set<String>, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.AggregatorValueProc
 
TermsIntFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.ints
 
TermsIntFacetCollector.StaticAggregatorValueProc(TIntIntHashMap) - Constructor for class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.StaticAggregatorValueProc
 
TermsIntOrdinalsFacetCollector - Class in org.elasticsearch.search.facet.terms.ints
 
TermsIntOrdinalsFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>) - Constructor for class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector
 
TermsIntOrdinalsFacetCollector.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.ints
 
TermsIntOrdinalsFacetCollector.AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector.AggregatorPriorityQueue
 
TermsIntOrdinalsFacetCollector.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.ints
 
TermsIntOrdinalsFacetCollector.ReaderAggregator(IntFieldData) - Constructor for class org.elasticsearch.search.facet.terms.ints.TermsIntOrdinalsFacetCollector.ReaderAggregator
 
TermsIpFacetCollector - Class in org.elasticsearch.search.facet.terms.ip
 
TermsIpFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector
 
TermsIpFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.ip
 
TermsIpFacetCollector.AggregatorValueProc(TLongIntHashMap, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.AggregatorValueProc
 
TermsIpFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.ip
 
TermsIpFacetCollector.StaticAggregatorValueProc(TLongIntHashMap) - Constructor for class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.StaticAggregatorValueProc
 
TermsIpOrdinalsFacetCollector - Class in org.elasticsearch.search.facet.terms.ip
 
TermsIpOrdinalsFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>) - Constructor for class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector
 
TermsIpOrdinalsFacetCollector.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.ip
 
TermsIpOrdinalsFacetCollector.AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector.AggregatorPriorityQueue
 
TermsIpOrdinalsFacetCollector.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.ip
 
TermsIpOrdinalsFacetCollector.ReaderAggregator(LongFieldData) - Constructor for class org.elasticsearch.search.facet.terms.ip.TermsIpOrdinalsFacetCollector.ReaderAggregator
 
TermsLongFacetCollector - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLongFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector
 
TermsLongFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLongFacetCollector.AggregatorValueProc(TLongIntHashMap, Set<String>, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.AggregatorValueProc
 
TermsLongFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLongFacetCollector.StaticAggregatorValueProc(TLongIntHashMap) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.StaticAggregatorValueProc
 
TermsLongOrdinalsFacetCollector - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLongOrdinalsFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector
 
TermsLongOrdinalsFacetCollector.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLongOrdinalsFacetCollector.AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector.AggregatorPriorityQueue
 
TermsLongOrdinalsFacetCollector.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.longs
 
TermsLongOrdinalsFacetCollector.ReaderAggregator(LongFieldData) - Constructor for class org.elasticsearch.search.facet.terms.longs.TermsLongOrdinalsFacetCollector.ReaderAggregator
 
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.
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.
TermsQueryParser - Class in org.elasticsearch.index.query
"terms" : { "field_name" : [ "value1", "value2" ] "minimum_match" : 1 }
TermsQueryParser() - Constructor for class org.elasticsearch.index.query.TermsQueryParser
 
TermsShortFacetCollector - Class in org.elasticsearch.search.facet.terms.shorts
 
TermsShortFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector
 
TermsShortFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.shorts
 
TermsShortFacetCollector.AggregatorValueProc(TShortIntHashMap, Set<String>, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.AggregatorValueProc
 
TermsShortFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.shorts
 
TermsShortFacetCollector.StaticAggregatorValueProc(TShortIntHashMap) - Constructor for class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.StaticAggregatorValueProc
 
TermsShortOrdinalsFacetCollector - Class in org.elasticsearch.search.facet.terms.shorts
 
TermsShortOrdinalsFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>) - Constructor for class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector
 
TermsShortOrdinalsFacetCollector.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.shorts
 
TermsShortOrdinalsFacetCollector.AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector.AggregatorPriorityQueue
 
TermsShortOrdinalsFacetCollector.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.shorts
 
TermsShortOrdinalsFacetCollector.ReaderAggregator(ShortFieldData) - Constructor for class org.elasticsearch.search.facet.terms.shorts.TermsShortOrdinalsFacetCollector.ReaderAggregator
 
TermsStatsDoubleFacetCollector - Class in org.elasticsearch.search.facet.termsstats.doubles
 
TermsStatsDoubleFacetCollector(String, String, String, int, TermsStatsFacet.ComparatorType, SearchContext, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector
 
TermsStatsDoubleFacetCollector.Aggregator - Class in org.elasticsearch.search.facet.termsstats.doubles
 
TermsStatsDoubleFacetCollector.Aggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector.Aggregator
 
TermsStatsDoubleFacetCollector.Aggregator.ValueAggregator - Class in org.elasticsearch.search.facet.termsstats.doubles
 
TermsStatsDoubleFacetCollector.Aggregator.ValueAggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector.Aggregator.ValueAggregator
 
TermsStatsDoubleFacetCollector.ScriptAggregator - Class in org.elasticsearch.search.facet.termsstats.doubles
 
TermsStatsDoubleFacetCollector.ScriptAggregator(SearchScript) - Constructor for class org.elasticsearch.search.facet.termsstats.doubles.TermsStatsDoubleFacetCollector.ScriptAggregator
 
termsStatsFacet(String) - Static method in class org.elasticsearch.search.facet.FacetBuilders
 
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.
TermsStatsFacetProcessor - Class in org.elasticsearch.search.facet.termsstats
 
TermsStatsFacetProcessor(Settings) - Constructor for class org.elasticsearch.search.facet.termsstats.TermsStatsFacetProcessor
 
TermsStatsLongFacetCollector - Class in org.elasticsearch.search.facet.termsstats.longs
 
TermsStatsLongFacetCollector(String, String, String, int, TermsStatsFacet.ComparatorType, SearchContext, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector
 
TermsStatsLongFacetCollector.Aggregator - Class in org.elasticsearch.search.facet.termsstats.longs
 
TermsStatsLongFacetCollector.Aggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector.Aggregator
 
TermsStatsLongFacetCollector.Aggregator.ValueAggregator - Class in org.elasticsearch.search.facet.termsstats.longs
 
TermsStatsLongFacetCollector.Aggregator.ValueAggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector.Aggregator.ValueAggregator
 
TermsStatsLongFacetCollector.ScriptAggregator - Class in org.elasticsearch.search.facet.termsstats.longs
 
TermsStatsLongFacetCollector.ScriptAggregator(SearchScript) - Constructor for class org.elasticsearch.search.facet.termsstats.longs.TermsStatsLongFacetCollector.ScriptAggregator
 
TermsStatsStringFacetCollector - Class in org.elasticsearch.search.facet.termsstats.strings
 
TermsStatsStringFacetCollector(String, String, String, int, TermsStatsFacet.ComparatorType, SearchContext, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector
 
TermsStatsStringFacetCollector.Aggregator - Class in org.elasticsearch.search.facet.termsstats.strings
 
TermsStatsStringFacetCollector.Aggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector.Aggregator
 
TermsStatsStringFacetCollector.Aggregator.ValueAggregator - Class in org.elasticsearch.search.facet.termsstats.strings
 
TermsStatsStringFacetCollector.Aggregator.ValueAggregator() - Constructor for class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector.Aggregator.ValueAggregator
 
TermsStatsStringFacetCollector.ScriptAggregator - Class in org.elasticsearch.search.facet.termsstats.strings
 
TermsStatsStringFacetCollector.ScriptAggregator(SearchScript) - Constructor for class org.elasticsearch.search.facet.termsstats.strings.TermsStatsStringFacetCollector.ScriptAggregator
 
TermsStringFacetCollector - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, Pattern, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector
 
TermsStringFacetCollector.AggregatorValueProc - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringFacetCollector.AggregatorValueProc(TObjectIntHashMap<String>, ImmutableSet<String>, Pattern, SearchScript) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.AggregatorValueProc
 
TermsStringFacetCollector.StaticAggregatorValueProc - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringFacetCollector.StaticAggregatorValueProc(TObjectIntHashMap<String>) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.StaticAggregatorValueProc
 
TermsStringOrdinalsFacetCollector - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringOrdinalsFacetCollector(String, String, int, TermsFacet.ComparatorType, boolean, SearchContext, ImmutableSet<String>, Pattern) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector
 
TermsStringOrdinalsFacetCollector.AggregatorPriorityQueue - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringOrdinalsFacetCollector.AggregatorPriorityQueue(int) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector.AggregatorPriorityQueue
 
TermsStringOrdinalsFacetCollector.ReaderAggregator - Class in org.elasticsearch.search.facet.terms.strings
 
TermsStringOrdinalsFacetCollector.ReaderAggregator(StringFieldData) - Constructor for class org.elasticsearch.search.facet.terms.strings.TermsStringOrdinalsFacetCollector.ReaderAggregator
 
termVector - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
termVector(Field.TermVector) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.Builder
 
termVector(Field.TermVector) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper.OpenBuilder
 
termVector - Variable in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
termVector() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
termVector(Field.TermVector) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper.Builder
 
termVector() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
termVector(Field.TermVector) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper.Builder
 
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(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated. use QueryBuilders.textQuery(String, Object) instead
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
textPhrasePrefix(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated. use QueryBuilders.textPhrasePrefixQuery(String, Object) instead
textPhrasePrefixQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated. Use QueryBuilders.matchPhrasePrefixQuery(String, Object)
textPhraseQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated. Use QueryBuilders.matchPhraseQuery(String, Object)
textQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
Deprecated. Use QueryBuilders.matchQuery(String, Object)
ThaiAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ThaiAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ThaiAnalyzerProvider
 
THREAD_DUMP - Static variable in class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
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.
ThreadBarrier.BarrierTimer() - Constructor for class org.elasticsearch.common.util.concurrent.ThreadBarrier.BarrierTimer
 
ThreadDumpContributor - Class in org.elasticsearch.monitor.dump.thread
 
ThreadDumpContributor(String, Settings) - Constructor for class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
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
 
ThreadLocalRandom - Class in jsr166y
A random number generator isolated to the current thread.
ThreadLocals - Class in org.elasticsearch.common.util.concurrent
 
ThreadLocals() - Constructor for class org.elasticsearch.common.util.concurrent.ThreadLocals
 
ThreadLocals.CleanableValue<T> - Class in org.elasticsearch.common.util.concurrent
 
ThreadLocals.CleanableValue(T) - Constructor for class org.elasticsearch.common.util.concurrent.ThreadLocals.CleanableValue
 
threadName(Settings, String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
 
threadPool() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
 
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.admin.cluster.node.stats.NodeStats
Thread Pool level statistics.
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.internal.InternalClient
 
threadPool() - Method in interface org.elasticsearch.client.internal.InternalClusterAdminClient
 
threadPool() - Method in interface org.elasticsearch.client.internal.InternalIndicesAdminClient
 
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.index.gateway.blobstore.BlobStoreIndexShardGateway
 
ThreadPool - Class in org.elasticsearch.threadpool
 
ThreadPool() - Constructor for class org.elasticsearch.threadpool.ThreadPool
 
ThreadPool(Settings) - Constructor for class org.elasticsearch.threadpool.ThreadPool
 
ThreadPool.Info - Class in org.elasticsearch.threadpool
 
ThreadPool.Info(String, String) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
 
ThreadPool.Info(String, String, int) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
 
ThreadPool.Info(String, String, int, int, TimeValue, SizeValue) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
 
ThreadPool.Names - Class in org.elasticsearch.threadpool
 
ThreadPool.Names() - Constructor for class org.elasticsearch.threadpool.ThreadPool.Names
 
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
 
ThreadPoolStats.Stats(String, int, int, int, long) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
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
 
threads() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
 
ThreadSafeInputStreamIndexInput - Class in org.elasticsearch.common.lucene.store
 
ThreadSafeInputStreamIndexInput(IndexInput, long) - Constructor for class org.elasticsearch.common.lucene.store.ThreadSafeInputStreamIndexInput
 
throttleTime() - Method in class org.elasticsearch.index.store.StoreStats
 
throttleTimeInNanos() - Method in interface org.elasticsearch.index.store.DirectoryService
 
throttleTimeInNanos() - Method in class org.elasticsearch.index.store.fs.FsDirectoryService
 
throttleTimeInNanos() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectoryService
 
throttleTimeInNanos() - Method in class org.elasticsearch.index.store.ram.RamDirectoryService
 
ThrottlingAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
 
ThrottlingAllocationDecider(Settings, NodeSettingsService) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
 
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
 
throwConnectException(boolean) - Method in class org.elasticsearch.transport.TransportService
Set to true to indicate that a ConnectTransportException should be thrown when sending a message (otherwise, it will be passed to the response handler).
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.QueryParserSettings
 
tieBreaker(float) - Method in class org.apache.lucene.queryParser.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(Integer) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
 
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.
TieredMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
TieredMergePolicyProvider(Store, IndexSettingsService) - Constructor for class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider
 
TieredMergePolicyProvider.CustomTieredMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
TieredMergePolicyProvider.CustomTieredMergePolicyProvider(TieredMergePolicyProvider) - Constructor for class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.CustomTieredMergePolicyProvider
 
TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider(TieredMergePolicyProvider) - Constructor for class org.elasticsearch.index.merge.policy.TieredMergePolicyProvider.EnableMergeTieredMergePolicyProvider
 
time() - Method in class org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus
 
time() - Method in class org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus
 
time() - Method in class org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus
 
time() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
time(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
time() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Start
 
time(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Start
 
time() - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
time(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
time() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Translog
 
time(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Translog
 
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.get.GetStats
 
time() - Method in class org.elasticsearch.indices.recovery.RecoveryStatus
 
time() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The time bucket start (in milliseconds).
time() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
time() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
TIME_UNIT - Static variable in class org.elasticsearch.index.mapper.core.DateFieldMapper.Defaults
 
timedOut() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
true if the waitForXXX has timeout out and did not match.
timedOut() - Method in class org.elasticsearch.action.search.SearchResponse
Has the search operation timed out.
timedOut() - Method in class org.elasticsearch.search.internal.InternalSearchResponse
 
timeInMillis() - Method in class org.elasticsearch.index.get.GetStats
 
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(TimeValue) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
Timeout to wait till the alias operations get acknowledged of all current cluster nodes.
timeout(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
Timeout to wait till the alias operations get acknowledged of all current cluster nodes.
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
timeout(String) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
Timeout to wait for the index creation to be acknowledged by current cluster nodes.
timeout(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
Timeout to wait for the index creation 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(TimeValue) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
Timeout to wait till the put mapping gets acknowledged of all current cluster nodes.
timeout(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
Timeout to wait till the put mapping gets acknowledged of all current cluster nodes.
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
timeout(String) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
Timeout to wait for the index template deletion to be acknowledged by current cluster nodes.
timeout(String) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
Timeout to wait for the index template deletion to be acknowledged by current cluster nodes.
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
Timeout to wait till the put mapping gets acknowledged of all current cluster nodes.
timeout(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
Timeout to wait till the put mapping gets acknowledged of all current cluster nodes.
timeout(TimeValue) - Method in class org.elasticsearch.action.delete.DeleteRequest
A timeout to wait if the index operation can't be performed immediately.
timeout(TimeValue) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
A timeout to wait if the delete by query operation can't be performed immediately.
timeout(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
A timeout to wait if the delete by query operation can't be performed immediately.
timeout(TimeValue) - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.index.IndexRequest
A timeout to wait if the index operation can't be performed immediately.
timeout(String) - Method in class org.elasticsearch.action.index.IndexRequest
A timeout to wait if the index operation can't be performed immediately.
timeout() - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
timeout - Variable in class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
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 - Variable in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
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.update.UpdateRequest
A timeout to wait if the index operation can't be performed immediately.
timeout(String) - Method in class org.elasticsearch.action.update.UpdateRequest
A timeout to wait if the index operation can't be performed immediately.
timeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataCreateIndexService.Request
 
timeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataDeleteIndexService.Request
 
timeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService.PutRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataStateIndexService.Request
 
timeout(TimeValue) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
An optional timeout to control how long search is allowed to take.
timeout(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
An optional timeout to control how long search is allowed to take.
timeout() - Method in class org.elasticsearch.transport.TransportRequestOptions
 
TimeoutClusterStateListener - Interface in org.elasticsearch.cluster
An exception to cluster state listener that allows for timeouts and for post added notifications.
timeoutInMillis() - Method in class org.elasticsearch.search.internal.SearchContext
 
timeoutInMillis(long) - Method in class org.elasticsearch.search.internal.SearchContext
 
TimeoutParseElement - Class in org.elasticsearch.search.query
 
TimeoutParseElement() - Constructor for class org.elasticsearch.search.query.TimeoutParseElement
 
timestamp() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
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.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() - Method in exception org.elasticsearch.index.AlreadyExpiredException
 
timestamp() - Method in class org.elasticsearch.index.engine.Engine.Create
 
timestamp() - Method in class org.elasticsearch.index.engine.Engine.Index
 
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.dump.AbstractDump
 
timestamp() - Method in interface org.elasticsearch.monitor.dump.Dump
 
timestamp() - Method in class org.elasticsearch.monitor.fs.FsStats
 
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() - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
TimestampFieldMapper(Field.Store, Field.Index, boolean, String, FormatDateTimeFormatter, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
TimestampFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
TimestampFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Builder
 
TimestampFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
TimestampFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.Defaults
 
TimestampFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
TimestampFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.TimestampFieldMapper.TypeParser
 
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
 
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
 
TimeZoneRounding - Class in org.elasticsearch.common.joda
 
TimeZoneRounding() - Constructor for class org.elasticsearch.common.joda.TimeZoneRounding
 
TimeZoneRounding.Builder - Class in org.elasticsearch.common.joda
 
TimeZoneRounding.Builder(DateTimeField) - Constructor for class org.elasticsearch.common.joda.TimeZoneRounding.Builder
 
TimeZoneRounding.Builder(TimeValue) - Constructor for class org.elasticsearch.common.joda.TimeZoneRounding.Builder
 
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
The to part of the filter query.
to(int) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
to(long) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
to(float) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
The to part of the filter query.
to(double) - Method in class org.elasticsearch.index.query.NumericRangeFilterBuilder
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() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
to() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
toArray() - Method in class jsr166e.extra.ReadMostlyVector
 
toArray(T[]) - Method in class jsr166e.extra.ReadMostlyVector
 
toArray() - Method in class jsr166y.ConcurrentLinkedDeque
Returns an array containing all of the elements in this deque, in proper sequence (from first to last element).
toArray(T[]) - Method in class jsr166y.ConcurrentLinkedDeque
Returns an array containing all of the elements in this deque, in proper sequence (from first to last element); the runtime type of the returned array is that of the specified array.
toArray() - Method in class org.elasticsearch.common.blobstore.BlobPath
 
toAsString() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
toBytes(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
 
toBytes() - Method in class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
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(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
 
toBytesArray() - Method in class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
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
 
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.ByteBufferBytesReference
 
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
 
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
 
toDigit(char, int) - Static method in class org.elasticsearch.common.Hex
 
toException() - Method in class org.elasticsearch.common.inject.internal.Errors
 
toGB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
 
toGiga(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
 
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
 
toJTSGeometry(Shape) - Static method in class org.elasticsearch.common.geo.ShapeBuilder
Converts the given Shape into the JTS Geometry representation.
toKB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
 
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
 
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
 
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.
tokens() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse
 
tokenStream(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
tokenStream(String, Reader) - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
 
tokenStream(String, Reader) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
 
tokenStream(String, Reader) - Method in class org.elasticsearch.index.analysis.NumericAnalyzer
 
tokenStreamValue() - Method in class org.elasticsearch.common.lucene.all.AllField
 
tokenStreamValue() - Method in class org.elasticsearch.common.lucene.uid.UidField
 
tokenStreamValue() - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper.CustomByteNumericField
 
tokenStreamValue() - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper.CustomDoubleNumericField
 
tokenStreamValue() - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper.CustomFloatNumericField
 
tokenStreamValue() - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper.CustomIntegerNumericField
 
tokenStreamValue() - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper.CustomLongNumericField
 
tokenStreamValue() - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper.CustomShortNumericField
 
toKilo(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
 
toKilometers(double) - Method in enum org.elasticsearch.common.unit.DistanceUnit
 
toLanguageTag(Locale) - Static method in class org.elasticsearch.common.Strings
Determine the RFC 3066 compliant language tag, as used for the HTTP "Accept-Language" header.
toMB(long) - Method in enum org.elasticsearch.common.unit.ByteSizeUnit
 
toMega(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
 
toMiles(double) - Method in enum org.elasticsearch.common.unit.DistanceUnit
 
took() - Method in class org.elasticsearch.action.bulk.BulkResponse
How long the bulk execution took.
took() - Method in class org.elasticsearch.action.search.SearchResponse
How long the search took.
tookInMillis() - Method in class org.elasticsearch.action.bulk.BulkResponse
How long the bulk execution took in milliseconds.
tookInMillis() - Method in class org.elasticsearch.action.search.SearchResponse
How long the search took in milliseconds.
tooManyConstructors(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
 
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
 
TopChildrenQuery(Query, String, String, String, TopChildrenQuery.ScoreType, int, int) - Constructor for class org.elasticsearch.index.search.child.TopChildrenQuery
 
TopChildrenQuery.ParentDoc - Class in org.elasticsearch.index.search.child
 
TopChildrenQuery.ParentDoc() - Constructor for class org.elasticsearch.index.search.child.TopChildrenQuery.ParentDoc
 
TopChildrenQuery.ScoreType - Enum in org.elasticsearch.index.search.child
 
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() - Method in class org.elasticsearch.search.query.QuerySearchResult
 
topDocs(TopDocs) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
topLeft(double, double) - Method in class org.elasticsearch.common.geo.ShapeBuilder.RectangleBuilder
Sets the top left point of the Rectangle
topLeft(double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
Adds top left point.
topLeft(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxFilterBuilder
 
topLeft() - Method in interface org.elasticsearch.index.search.geo.GeoDistance.DistanceBoundingCheck
 
topLeft() - Method in class org.elasticsearch.index.search.geo.GeoDistance.Meridian180DistanceBoundingCheck
 
topLeft() - Method in class org.elasticsearch.index.search.geo.GeoDistance.SimpleDistanceBoundingCheck
 
topLeft() - Method in class org.elasticsearch.index.search.geo.InMemoryGeoBoundingBoxFilter
 
topLevelDocId() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
topLevelReader() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
 
toPolygon() - Method in class org.elasticsearch.common.geo.ShapeBuilder.PolygonBuilder
Creates the raw Polygon
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
 
toSingles(long) - Method in enum org.elasticsearch.common.unit.SizeUnit
 
toString() - Method in class jsr166e.ConcurrentHashMapV8
Returns a string representation of this map.
toString() - Method in class jsr166e.DoubleAdder
Returns the String representation of the DoubleAdder.sum().
toString() - Method in class jsr166e.DoubleMaxUpdater
Returns the String representation of the DoubleMaxUpdater.max().
toString() - Method in class jsr166e.extra.AtomicDouble
Returns the String representation of the current value.
toString() - Method in class jsr166e.extra.AtomicDoubleArray
Returns the String representation of the current values of array.
toString() - Method in class jsr166e.extra.ReadMostlyVector
 
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() - Method in class jsr166e.SequenceLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in class jsr166y.ForkJoinPool
Returns a string identifying this pool, as well as its state, including indications of run state, parallelism level, and worker and task counts.
toString() - Method in class jsr166y.Phaser
Returns a string identifying this phaser, as well as its state.
toString() - Method in class org.apache.lucene.index.memory.CustomMemoryIndex
Returns a String representation of the index data for debugging purposes.
toString() - Method in class org.apache.lucene.search.PublicTermsFilter
 
toString() - Method in class org.apache.lucene.search.XTermsFilter
 
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.get.GetRequest
 
toString() - Method in class org.elasticsearch.action.index.IndexRequest
 
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.support.DefaultShardOperationFailedException
 
toString() - Method in class org.elasticsearch.cluster.block.ClusterBlock
 
toString() - Method in class org.elasticsearch.cluster.ClusterName
 
toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
toString() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
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.component.Lifecycle
 
toString() - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
toString() - Method in class org.elasticsearch.common.compress.CompressedString
 
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.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.FastByteArrayOutputStream
Converts the buffer's contents into a string decoding bytes using the platform's default character set.
toString(String) - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Converts the buffer's contents into a string by decoding the bytes using the specified charsetName.
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.lab.LongsLAB.Allocation
 
toString() - Method in class org.elasticsearch.common.lucene.all.AllEntries
 
toString() - Method in class org.elasticsearch.common.lucene.all.AllTokenStream
 
toString() - Method in class org.elasticsearch.common.lucene.search.AndFilter
 
toString() - Method in class org.elasticsearch.common.lucene.search.function.BoostScoreFunction
 
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.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() - Method in class org.elasticsearch.common.lucene.search.NotDeletedFilter
 
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.TermFilter
 
toString() - Method in class org.elasticsearch.common.lucene.search.XBooleanFilter
Prints a user-readable version of this query.
toString() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.Node
 
toString() - Method in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
toString() - Method in class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
toString() - Method in class org.elasticsearch.common.lucene.store.ChecksumIndexOutput
 
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(double) - 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.SizeValue
 
toString() - Method in class org.elasticsearch.common.unit.TimeValue
 
toString() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
toString() - Method in class org.elasticsearch.common.UUID
Returns a String object representing this UUID.
toString() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
toString() - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
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.Engine.Flush
 
toString() - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
toString() - Method in class org.elasticsearch.index.engine.Engine.Refresh
 
toString() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexGateway
 
toString() - Method in class org.elasticsearch.index.gateway.blobstore.BlobStoreIndexShardGateway
 
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.mapper.internal.SourceFieldSelector
 
toString() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
toString() - Method in class org.elasticsearch.index.mapper.selector.AllButSourceFieldSelector
 
toString() - Method in class org.elasticsearch.index.mapper.selector.FieldMappersFieldSelector
 
toString() - Method in class org.elasticsearch.index.mapper.selector.UidAndRoutingFieldSelector
 
toString() - Method in class org.elasticsearch.index.mapper.selector.UidAndSourceFieldSelector
 
toString() - Method in class org.elasticsearch.index.mapper.selector.UidFieldSelector
 
toString() - Method in class org.elasticsearch.index.mapper.Uid
 
toString() - Method in class org.elasticsearch.index.query.BaseQueryBuilder
 
toString() - Method in class org.elasticsearch.index.query.CustomScoreQueryParser.ScriptScoreFunction
 
toString() - Method in class org.elasticsearch.index.query.ScriptFilterParser.ScriptFilter
 
toString() - Method in class org.elasticsearch.index.search.child.HasChildFilter
 
toString(String) - Method in class org.elasticsearch.index.search.child.TopChildrenQuery
 
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() - Method in class org.elasticsearch.index.search.geo.Point
 
toString(String) - Method in class org.elasticsearch.index.search.nested.BlockJoinQuery
 
toString(String) - Method in class org.elasticsearch.index.search.nested.IncludeAllChildrenQuery
 
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.UidFilter
 
toString() - Method in class org.elasticsearch.index.shard.ShardId
 
toString() - Method in class org.elasticsearch.index.store.StoreFileMetaData
 
toString() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
toString() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
toString() - Method in class org.elasticsearch.search.highlight.HighlightField
 
toString() - Method in class org.elasticsearch.search.SearchShardTarget
 
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.
toStringArray(Enumeration<String>) - Static method in class org.elasticsearch.common.Strings
Copy the given Enumeration 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.action.admin.indices.stats.IndexShardStats
 
total() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
 
total() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
total() - Method in class org.elasticsearch.index.flush.FlushStats
The total number of flush executed.
total() - Method in class org.elasticsearch.index.indexing.IndexingStats
 
total() - Method in class org.elasticsearch.index.merge.MergeStats
The total number of merges executed.
total() - Method in class org.elasticsearch.index.refresh.RefreshStats
The total number of refresh executed.
total() - Method in class org.elasticsearch.index.search.stats.SearchStats
 
total() - Method in class org.elasticsearch.index.warmer.WarmerStats
The total number of warmer executed.
total() - Method in class org.elasticsearch.monitor.fs.FsStats.Info
 
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 interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The sum / total of the value field that fall within this key "interval".
total() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
total() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
total() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
total() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
total() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
total() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The sum / total of the value field that fall within this key "interval".
total() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
total() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
total() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
total() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
total() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The total (sum) of values.
total() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetCollector.StatsProc
 
total() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFieldsFacetCollector.StatsProc
 
total() - Method in class org.elasticsearch.search.facet.terms.bytes.TermsByteFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.terms.doubles.TermsDoubleFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.terms.floats.TermsFloatFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.terms.ints.TermsIntFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.terms.ip.TermsIpFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.terms.longs.TermsLongFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.terms.shorts.TermsShortFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.terms.strings.FieldsTermsStringFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.terms.strings.TermsStringFacetCollector.StaticAggregatorValueProc
 
total() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
total() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
total() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
total() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
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
 
totalCount() - Method in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet.Entry
The total count of values aggregated to compute the total.
totalCount() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet.CountEntry
 
totalCount() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet.FullEntry
 
totalCount() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacet.Entry
 
totalCount() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet.CountEntry
 
totalCount() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet.FullEntry
 
totalCount() - Method in interface org.elasticsearch.search.facet.histogram.HistogramFacet.Entry
The total count of values aggregated to compute the total.
totalCount() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet.CountEntry
 
totalCount() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet.FullEntry
 
totalCount() - Method in class org.elasticsearch.search.facet.range.RangeFacet.Entry
 
totalCount() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
totalCount() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
totalCount() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
totalCount() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
totalCount() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
totalCount() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
totalCount() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
totalCount() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
totalCount() - Method in interface org.elasticsearch.search.facet.terms.TermsFacet
The total count of terms.
totalCount() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet.DoubleEntry
 
totalCount() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet.LongEntry
 
totalCount() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet.StringEntry
 
totalCount() - Method in interface org.elasticsearch.search.facet.termsstats.TermsStatsFacet.Entry
 
totalFilesSize() - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
 
totalHits() - Method in class org.elasticsearch.search.count.CountSearchResult
 
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
 
totalMergeNumDocs() - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
totalMerges() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
totalMerges() - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
totalMergeSizeInBytes() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
totalMergeSizeInBytes() - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
totalMergeTime() - Method in class org.apache.lucene.index.TrackingConcurrentMergeScheduler
 
totalMergeTime() - Method in class org.apache.lucene.index.TrackingSerialMergeScheduler
 
totalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
totalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
totalNumDocs() - Method in class org.elasticsearch.index.merge.MergeStats
 
totalOpen() - Method in class org.elasticsearch.http.HttpStats
 
totalShards() - Method in class org.elasticsearch.action.delete.index.IndexDeleteResponse
The total number of shards the delete by query was executed on.
totalShards() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryResponse
The total number of shards the delete by query was executed on.
totalShards() - Method in class org.elasticsearch.action.search.SearchResponse
The total number of shards the search was executed on.
totalShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationResponse
The total shards this request ran against.
totalSize() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
totalSize() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
totalSize() - Method in class org.elasticsearch.index.gateway.SnapshotStatus.Index
 
totalSize() - Method in class org.elasticsearch.index.merge.MergeStats
 
totalSizeInBytes() - Method in class org.elasticsearch.index.merge.MergeStats
 
totalSizeInBytes() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
totalSizeWith1ForEmpty() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
totalSockets() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
totalTime() - Method in class org.elasticsearch.common.StopWatch
Return the total time for all tasks.
totalTime() - Method in class org.elasticsearch.index.flush.FlushStats
The total time merges have been executed.
totalTime() - Method in class org.elasticsearch.index.merge.MergeStats
The total time merges have been executed.
totalTime() - Method in class org.elasticsearch.index.refresh.RefreshStats
The total time merges have been executed.
totalTime() - Method in class org.elasticsearch.index.warmer.WarmerStats
The total time warmer have been executed.
totalTimeInMillis() - Method in class org.elasticsearch.index.flush.FlushStats
The total time merges have been executed (in milliseconds).
totalTimeInMillis() - Method in class org.elasticsearch.index.merge.MergeStats
The total time merges have been executed (in milliseconds).
totalTimeInMillis() - Method in class org.elasticsearch.index.refresh.RefreshStats
The total time merges have been executed (in milliseconds).
totalTimeInMillis() - Method in class org.elasticsearch.index.warmer.WarmerStats
The total time warmer have been executed (in milliseconds).
totalVirtual() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
touchFile(String) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferDirectory
 
touchFile(String) - Method in class org.elasticsearch.common.compress.CompressedDirectory
 
touchFile(String) - Method in class org.elasticsearch.common.lucene.store.SwitchDirectory
 
toUnderscoreCase(String) - Static method in class org.elasticsearch.common.Strings
 
toUnderscoreCase(String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
 
toUtf8() - Method in class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
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
 
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.stats.NodesStatsResponse
 
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.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.IndicesStats
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
toXContent(XContentBuilder, ToXContent.Params, SettingsFilter) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.explain.ExplainSourceBuilder
 
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.search.MultiSearchResponse
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponse
 
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 interface org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ToXContent - Interface in org.elasticsearch.common.xcontent
An interface allowing to transfer an object to "XContent" using an XContentBuilder.
toXContent(XContentBuilder, ToXContent.Params) - Method in interface org.elasticsearch.common.xcontent.ToXContent
 
toXContent(XContentBuilder, ToXContent.Params) - Method in 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.CacheStats
 
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
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldMapper
 
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.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.multifield.MultiFieldMapper
 
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.query.BaseFilterBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BaseQueryBuilder
 
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(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.store.StoreStats
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.warmer.WarmerStats
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.NodeIndicesStats
 
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
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.process.ProcessInfo
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.process.ProcessStats
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.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.bounded.InternalBoundedCountHistogramFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
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.unbounded.InternalCountHistogramFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.histogram.unbounded.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.bytes.InternalByteTermsFacet
 
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.floats.InternalFloatTermsFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
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.shorts.InternalShortTermsFacet
 
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.highlight.HighlightBuilder
 
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.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(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.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.MapParams - Class in org.elasticsearch.common.xcontent
 
ToXContent.MapParams(Map<String, String>) - Constructor for class org.elasticsearch.common.xcontent.ToXContent.MapParams
 
ToXContent.Params - Interface in org.elasticsearch.common.xcontent
 
toXContentEmbedded(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.get.GetResult
 
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
 
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
 
TrackingMergeScheduler - Class in org.apache.lucene.index
 
TrackingMergeScheduler() - Constructor for class org.apache.lucene.index.TrackingMergeScheduler
 
TrackingSerialMergeScheduler - Class in org.apache.lucene.index
 
TrackingSerialMergeScheduler(ESLogger) - Constructor for class org.apache.lucene.index.TrackingSerialMergeScheduler
 
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.SearchContext
 
trackScores() - Method in class org.elasticsearch.search.internal.SearchContext
 
TrackScoresParseElement - Class in org.elasticsearch.search.sort
 
TrackScoresParseElement() - Constructor for class org.elasticsearch.search.sort.TrackScoresParseElement
 
transfer(E) - Method in class jsr166y.LinkedTransferQueue
Transfers the element to a consumer, waiting if necessary to do so.
transfer(E) - Method in interface jsr166y.TransferQueue
Transfers the element to a consumer, waiting if necessary to do so.
TransferQueue<E> - Interface in jsr166y
A BlockingQueue in which producers may wait for consumers to receive elements.
transientSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
transientSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
transientSettings(String) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
transientSettings(Map) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
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
 
translog() - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
translog() - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
translog() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
Translog - Interface in org.elasticsearch.index.translog
 
Translog.Create - Class in org.elasticsearch.index.translog
 
Translog.Create() - Constructor for class org.elasticsearch.index.translog.Translog.Create
 
Translog.Create(Engine.Create) - Constructor for class org.elasticsearch.index.translog.Translog.Create
 
Translog.Create(String, String, byte[]) - Constructor for class org.elasticsearch.index.translog.Translog.Create
 
Translog.Delete - Class in org.elasticsearch.index.translog
 
Translog.Delete() - Constructor for class org.elasticsearch.index.translog.Translog.Delete
 
Translog.Delete(Engine.Delete) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
 
Translog.Delete(Term) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
 
Translog.DeleteByQuery - Class in org.elasticsearch.index.translog
 
Translog.DeleteByQuery() - Constructor for class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
Translog.DeleteByQuery(Engine.DeleteByQuery) - Constructor for class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
Translog.DeleteByQuery(BytesReference, String[], String...) - Constructor for class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
Translog.Index - Class in org.elasticsearch.index.translog
 
Translog.Index() - Constructor for class org.elasticsearch.index.translog.Translog.Index
 
Translog.Index(Engine.Index) - Constructor for class org.elasticsearch.index.translog.Translog.Index
 
Translog.Index(String, String, byte[]) - Constructor for class org.elasticsearch.index.translog.Translog.Index
 
Translog.Location - Class in org.elasticsearch.index.translog
 
Translog.Location(long, long, int) - Constructor for class org.elasticsearch.index.translog.Translog.Location
 
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.Source(BytesReference, String, String, long, long) - Constructor for class org.elasticsearch.index.translog.Translog.Source
 
TRANSLOG_ID_KEY - Static variable in interface org.elasticsearch.index.translog.Translog
 
TRANSLOG_OPS - Static variable in class org.elasticsearch.indices.recovery.RecoveryTarget.Actions
 
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.action.admin.indices.status.ShardStatus
The transaction log id.
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
 
TranslogModule.TranslogSettings() - Constructor for class org.elasticsearch.index.translog.TranslogModule.TranslogSettings
 
translogOperations() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
translogOperations() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
translogOperations() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
The number of transaction operations in the transaction log.
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
 
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.
translogSnapshot() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
TranslogStreams - Class in org.elasticsearch.index.translog
 
TranslogStreams() - Constructor for class org.elasticsearch.index.translog.TranslogStreams
 
transport() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
 
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() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
Transport - Interface in org.elasticsearch.transport
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.exists.TransportIndicesExistsAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.settings.TransportUpdateSettingsAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.warmer.delete.TransportDeleteWarmerAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
 
transportAction() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
 
transportAction() - Method in class org.elasticsearch.action.count.TransportCountAction
 
transportAction() - Method in class org.elasticsearch.action.delete.index.TransportIndexDeleteAction
 
transportAction() - Method in class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
transportAction() - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
transportAction() - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
transportAction() - Method in class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
transportAction() - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
transportAction() - Method in class org.elasticsearch.action.explain.TransportExplainAction
 
transportAction() - Method in class org.elasticsearch.action.get.TransportGetAction
 
transportAction() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
 
transportAction() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
transportAction() - Method in class org.elasticsearch.action.percolate.TransportPercolateAction
 
transportAction() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
transportAction() - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
transportAction() - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
transportAction() - Method in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
transportAction() - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
transportAction() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
transportAction() - Method in class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
transportAction() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
transportAction() - Method in class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
TransportAction<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support
 
TransportAction(Settings, ThreadPool) - Constructor for class org.elasticsearch.action.support.TransportAction
 
transportAction() - Method in class org.elasticsearch.action.update.TransportUpdateAction
 
transportAction() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
transportAction() - Method in class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
transportAction() - Method in class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
transportAction() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
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
 
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
 
TransportAnalyzeAction - Class in org.elasticsearch.action.admin.indices.analyze
 
TransportAnalyzeAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, IndicesAnalysisService) - 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, ThreadPool, ClusterService, TransportService) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
TransportBulkAction - Class in org.elasticsearch.action.bulk
 
TransportBulkAction(Settings, ThreadPool, TransportService, ClusterService, TransportShardBulkAction, TransportCreateIndexAction) - 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) - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
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) - Constructor for class org.elasticsearch.client.transport.TransportClientNodesService
 
TransportClientNodesService.NodeCallback<T> - Interface in org.elasticsearch.client.transport
 
TransportClientNodesService.NodeListenerCallback<Response> - Interface in org.elasticsearch.client.transport
 
TransportClientNodesService.RetryListener<Response> - Class in org.elasticsearch.client.transport
 
TransportClientNodesService.RetryListener(TransportClientNodesService.NodeListenerCallback<Response>, ActionListener<Response>, ImmutableList<DiscoveryNode>, int) - Constructor for class org.elasticsearch.client.transport.TransportClientNodesService.RetryListener
 
TransportCloseIndexAction - Class in org.elasticsearch.action.admin.indices.close
Delete index action.
TransportCloseIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataStateIndexService) - 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) - Constructor for class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
TransportClusterRerouteAction - Class in org.elasticsearch.action.admin.cluster.reroute
 
TransportClusterRerouteAction(Settings, TransportService, ClusterService, ThreadPool, AllocationService) - Constructor for class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
 
TransportClusterStateAction - Class in org.elasticsearch.action.admin.cluster.state
 
TransportClusterStateAction(Settings, TransportService, ClusterService, ThreadPool, ClusterName) - Constructor for class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
TransportClusterUpdateSettingsAction - Class in org.elasticsearch.action.admin.cluster.settings
 
TransportClusterUpdateSettingsAction(Settings, TransportService, ClusterService, ThreadPool, AllocationService) - Constructor for class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
 
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) - 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) - Constructor for class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
TransportDeleteAction - Class in org.elasticsearch.action.delete
Performs the delete operation.
TransportDeleteAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, TransportCreateIndexAction, TransportIndexDeleteAction) - Constructor for class org.elasticsearch.action.delete.TransportDeleteAction
 
TransportDeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
 
TransportDeleteByQueryAction(Settings, ClusterService, TransportService, ThreadPool, TransportIndexDeleteByQueryAction) - 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, TransportDeleteMappingAction) - Constructor for class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
TransportDeleteIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
Delete index action.
TransportDeleteIndexTemplateAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexTemplateService) - 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) - Constructor for class org.elasticsearch.action.admin.indices.mapping.delete.TransportDeleteMappingAction
 
TransportDeleteWarmerAction - Class in org.elasticsearch.action.admin.indices.warmer.delete
Delete index warmer.
TransportDeleteWarmerAction(Settings, TransportService, ClusterService, ThreadPool) - 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
 
TransportExplainAction - Class in org.elasticsearch.action.explain
Explain transport action.
TransportExplainAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ScriptService) - 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) - Constructor for class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
TransportFuture<V> - Interface in org.elasticsearch.transport
 
TransportGatewaySnapshotAction - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
 
TransportGatewaySnapshotAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
TransportGetAction - Class in org.elasticsearch.action.get
Performs the get operation.
TransportGetAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool) - Constructor for class org.elasticsearch.action.get.TransportGetAction
 
TransportIndexAction - Class in org.elasticsearch.action.index
Performs the index operation.
TransportIndexAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, TransportCreateIndexAction, MappingUpdatedAction) - Constructor for class org.elasticsearch.action.index.TransportIndexAction
 
TransportIndexDeleteAction - Class in org.elasticsearch.action.delete.index
 
TransportIndexDeleteAction(Settings, ClusterService, TransportService, ThreadPool, TransportShardDeleteAction) - Constructor for class org.elasticsearch.action.delete.index.TransportIndexDeleteAction
 
TransportIndexDeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
 
TransportIndexDeleteByQueryAction(Settings, ClusterService, TransportService, ThreadPool, TransportShardDeleteByQueryAction) - Constructor for class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
TransportIndexReplicationOperationAction<Request extends IndexReplicationOperationRequest,Response extends ActionResponse,ShardRequest extends ShardReplicationOperationRequest,ShardReplicaRequest extends ActionRequest,ShardResponse extends ActionResponse> - Class in org.elasticsearch.action.support.replication
 
TransportIndexReplicationOperationAction(Settings, TransportService, ClusterService, ThreadPool, TransportShardReplicationOperationAction<ShardRequest, ShardReplicaRequest, ShardResponse>) - Constructor for class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
TransportIndicesAliasesAction - Class in org.elasticsearch.action.admin.indices.alias
 
TransportIndicesAliasesAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexAliasesService) - Constructor for class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
TransportIndicesExistsAction - Class in org.elasticsearch.action.admin.indices.exists
Indices exists action.
TransportIndicesExistsAction(Settings, TransportService, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.action.admin.indices.exists.TransportIndicesExistsAction
 
TransportIndicesReplicationOperationAction<Request extends IndicesReplicationOperationRequest,Response extends ActionResponse,IndexRequest extends IndexReplicationOperationRequest,IndexResponse extends ActionResponse,ShardRequest extends ShardReplicationOperationRequest,ShardReplicaRequest extends ActionRequest,ShardResponse extends ActionResponse> - Class in org.elasticsearch.action.support.replication
 
TransportIndicesReplicationOperationAction(Settings, TransportService, ClusterService, ThreadPool, TransportIndexReplicationOperationAction<IndexRequest, IndexResponse, ShardRequest, ShardReplicaRequest, ShardResponse>) - Constructor for class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
TransportIndicesSegmentsAction - Class in org.elasticsearch.action.admin.indices.segments
 
TransportIndicesSegmentsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
 
TransportIndicesSegmentsAction.IndexShardSegmentRequest - Class in org.elasticsearch.action.admin.indices.segments
 
TransportIndicesStatsAction - Class in org.elasticsearch.action.admin.indices.stats
 
TransportIndicesStatsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
 
TransportIndicesStatsAction.IndexShardStatsRequest - Class in org.elasticsearch.action.admin.indices.stats
 
TransportIndicesStatusAction - Class in org.elasticsearch.action.admin.indices.status
 
TransportIndicesStatusAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, RecoveryTarget) - Constructor for class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
TransportIndicesStatusAction.IndexShardStatusRequest - Class in org.elasticsearch.action.admin.indices.status
 
TransportInfo - Class in org.elasticsearch.transport
 
TransportInfo(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, ThreadPool, ClusterService, TransportService) - Constructor for class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
 
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, TransportService, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
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) - Constructor for class org.elasticsearch.action.mlt.TransportMoreLikeThisAction
 
TransportMultiGetAction - Class in org.elasticsearch.action.get
 
TransportMultiGetAction(Settings, ThreadPool, TransportService, ClusterService, TransportShardMultiGetAction) - Constructor for class org.elasticsearch.action.get.TransportMultiGetAction
 
TransportMultiSearchAction - Class in org.elasticsearch.action.search
 
TransportMultiSearchAction(Settings, ThreadPool, TransportService, ClusterService, TransportSearchAction) - Constructor for class org.elasticsearch.action.search.TransportMultiSearchAction
 
TransportNodesHotThreadsAction - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
 
TransportNodesHotThreadsAction(Settings, ClusterName, ThreadPool, ClusterService, TransportService) - 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) - 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) - Constructor for class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState
 
TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState - Class in org.elasticsearch.gateway.local.state.meta
 
TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState(DiscoveryNode, MetaData) - Constructor for class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState
 
TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState - Class in org.elasticsearch.gateway.local.state.meta
 
TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState(ClusterName, TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState[], FailedNodeException[]) - Constructor for class org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState
 
TransportNodesListGatewayStartedShards - Class in org.elasticsearch.gateway.local.state.shards
 
TransportNodesListGatewayStartedShards(Settings, ClusterName, ThreadPool, ClusterService, TransportService) - Constructor for class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards
 
TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards - Class in org.elasticsearch.gateway.local.state.shards
 
TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards(DiscoveryNode, long) - Constructor for class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards
 
TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards - Class in org.elasticsearch.gateway.local.state.shards
 
TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards(ClusterName, TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards[], FailedNodeException[]) - Constructor for class org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards
 
TransportNodesListShardStoreMetaData - Class in org.elasticsearch.indices.store
 
TransportNodesListShardStoreMetaData(Settings, ClusterName, ThreadPool, ClusterService, TransportService, IndicesService, NodeEnvironment) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
 
TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData - Class in org.elasticsearch.indices.store
 
TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData(ClusterName, TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData[], FailedNodeException[]) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData
 
TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData - Class in org.elasticsearch.indices.store
 
TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData(DiscoveryNode, TransportNodesListShardStoreMetaData.StoreFilesMetaData) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData
 
TransportNodesListShardStoreMetaData.StoreFilesMetaData - Class in org.elasticsearch.indices.store
 
TransportNodesListShardStoreMetaData.StoreFilesMetaData(boolean, ShardId, Map<String, StoreFileMetaData>) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.StoreFilesMetaData
 
TransportNodesOperationAction<Request extends NodesOperationRequest,Response extends NodesOperationResponse,NodeRequest extends NodeOperationRequest,NodeResponse extends NodeOperationResponse> - Class in org.elasticsearch.action.support.nodes
 
TransportNodesOperationAction(Settings, ClusterName, ThreadPool, ClusterService, TransportService) - 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) - 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) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
TransportNodesStatsAction - Class in org.elasticsearch.action.admin.cluster.node.stats
 
TransportNodesStatsAction(Settings, ClusterName, ThreadPool, ClusterService, TransportService, NodeService) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
TransportOpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
Delete index action.
TransportOpenIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataStateIndexService) - 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) - 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
 
TransportPercolateAction - Class in org.elasticsearch.action.percolate
 
TransportPercolateAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.percolate.TransportPercolateAction
 
TransportPutIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
Put index template action.
TransportPutIndexTemplateAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataIndexTemplateService) - 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) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
TransportPutWarmerAction - Class in org.elasticsearch.action.admin.indices.warmer.put
Put warmer action.
TransportPutWarmerAction(Settings, TransportService, ClusterService, ThreadPool, TransportSearchAction) - Constructor for class org.elasticsearch.action.admin.indices.warmer.put.TransportPutWarmerAction
 
TransportRefreshAction - Class in org.elasticsearch.action.admin.indices.refresh
Refresh action.
TransportRefreshAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
TransportRequestHandler<T extends Streamable> - 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
 
TransportResponseHandler<T extends Streamable> - Interface in org.elasticsearch.transport
 
TransportResponseOptions - Class in org.elasticsearch.transport
 
TransportResponseOptions() - Constructor for class org.elasticsearch.transport.TransportResponseOptions
 
TransportSearchAction - Class in org.elasticsearch.action.search
 
TransportSearchAction(Settings, ThreadPool, TransportService, ClusterService, TransportSearchDfsQueryThenFetchAction, TransportSearchQueryThenFetchAction, TransportSearchDfsQueryAndFetchAction, TransportSearchQueryAndFetchAction, TransportSearchScanAction, TransportSearchCountAction) - Constructor for class org.elasticsearch.action.search.TransportSearchAction
 
TransportSearchCache - Class in org.elasticsearch.action.search.type
 
TransportSearchCache() - Constructor for class org.elasticsearch.action.search.type.TransportSearchCache
 
TransportSearchCountAction - Class in org.elasticsearch.action.search.type
 
TransportSearchCountAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchCountAction
 
TransportSearchDfsQueryAndFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchDfsQueryAndFetchAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchDfsQueryAndFetchAction
 
TransportSearchDfsQueryThenFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchDfsQueryThenFetchAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - 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, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchQueryAndFetchAction
 
TransportSearchQueryThenFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchQueryThenFetchAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchQueryThenFetchAction
 
TransportSearchScanAction - Class in org.elasticsearch.action.search.type
 
TransportSearchScanAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchScanAction
 
TransportSearchScrollAction - Class in org.elasticsearch.action.search
 
TransportSearchScrollAction(Settings, ThreadPool, TransportService, TransportSearchScrollQueryThenFetchAction, TransportSearchScrollQueryAndFetchAction, TransportSearchScrollScanAction) - Constructor for class org.elasticsearch.action.search.TransportSearchScrollAction
 
TransportSearchScrollQueryAndFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchScrollQueryAndFetchAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchScrollQueryAndFetchAction
 
TransportSearchScrollQueryThenFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchScrollQueryThenFetchAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchScrollQueryThenFetchAction
 
TransportSearchScrollScanAction - Class in org.elasticsearch.action.search.type
 
TransportSearchScrollScanAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchScrollScanAction
 
TransportSearchTypeAction - Class in org.elasticsearch.action.search.type
 
TransportSearchTypeAction(Settings, ThreadPool, ClusterService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
TransportSearchTypeAction.BaseAsyncAction<FirstResult extends SearchPhaseResult> - Class in org.elasticsearch.action.search.type
 
TransportSearchTypeAction.BaseAsyncAction(SearchRequest, ActionListener<SearchResponse>) - Constructor for class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
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 - 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
 
transportServiceAdapter(TransportServiceAdapter) - Method in class org.elasticsearch.transport.local.LocalTransport
 
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
 
TransportServiceManagement - Class in org.elasticsearch.transport
 
TransportServiceManagement(TransportService) - Constructor for class org.elasticsearch.transport.TransportServiceManagement
 
TransportShardBulkAction - Class in org.elasticsearch.action.bulk
Performs the index operation.
TransportShardBulkAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, MappingUpdatedAction) - Constructor for class org.elasticsearch.action.bulk.TransportShardBulkAction
 
TransportShardDeleteAction - Class in org.elasticsearch.action.delete.index
 
TransportShardDeleteAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction) - Constructor for class org.elasticsearch.action.delete.index.TransportShardDeleteAction
 
TransportShardDeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
 
TransportShardDeleteByQueryAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction) - Constructor for class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
TransportShardMultiGetAction - Class in org.elasticsearch.action.get
 
TransportShardMultiGetAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool) - Constructor for class org.elasticsearch.action.get.TransportShardMultiGetAction
 
TransportShardReplicationOperationAction<Request extends ShardReplicationOperationRequest,ReplicaRequest extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction) - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
TransportShardReplicationOperationAction.AsyncShardOperationAction - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction.PrimaryOperationRequest - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction.PrimaryOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryOperationRequest
 
TransportShardReplicationOperationAction.PrimaryOperationRequest(int, Request) - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryOperationRequest
 
TransportShardReplicationOperationAction.PrimaryResponse<Response,ReplicaRequest> - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction.PrimaryResponse(ReplicaRequest, Response, Object) - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.PrimaryResponse
 
TransportShardReplicationOperationAction.ReplicaOperationRequest - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction.ReplicaOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ReplicaOperationRequest
 
TransportShardReplicationOperationAction.ReplicaOperationRequest(int, ReplicaRequest) - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ReplicaOperationRequest
 
TransportShardSingleOperationAction<Request extends SingleShardOperationRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.shard
 
TransportShardSingleOperationAction(Settings, ThreadPool, ClusterService, TransportService) - Constructor for class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction
 
TransportShardSingleOperationAction.ShardSingleOperationRequest - Class in org.elasticsearch.action.support.single.shard
 
TransportShardSingleOperationAction.ShardSingleOperationRequest(Request, int) - Constructor for class org.elasticsearch.action.support.single.shard.TransportShardSingleOperationAction.ShardSingleOperationRequest
 
TransportSingleCustomOperationAction<Request extends SingleCustomOperationRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.custom
 
TransportSingleCustomOperationAction(Settings, ThreadPool, ClusterService, TransportService) - Constructor for class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction
 
TransportSingleCustomOperationAction.ShardSingleOperationRequest - Class in org.elasticsearch.action.support.single.custom
 
TransportSingleCustomOperationAction.ShardSingleOperationRequest(Request, int) - Constructor for class org.elasticsearch.action.support.single.custom.TransportSingleCustomOperationAction.ShardSingleOperationRequest
 
TransportStats - Class in org.elasticsearch.transport
 
TransportStats(long, long, long, long, long) - Constructor for class org.elasticsearch.transport.TransportStats
 
TransportStreams - Class in org.elasticsearch.transport.support
 
TransportStreams() - Constructor for class org.elasticsearch.transport.support.TransportStreams
 
TransportUpdateAction - Class in org.elasticsearch.action.update
 
TransportUpdateAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, TransportIndexAction, TransportDeleteAction, ScriptService) - Constructor for class org.elasticsearch.action.update.TransportUpdateAction
 
TransportUpdateSettingsAction - Class in org.elasticsearch.action.admin.indices.settings
 
TransportUpdateSettingsAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataUpdateSettingsService) - Constructor for class org.elasticsearch.action.admin.indices.settings.TransportUpdateSettingsAction
 
TransportValidateQueryAction - Class in org.elasticsearch.action.admin.indices.validate.query
 
TransportValidateQueryAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ScriptService) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
 
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.multifield.MultiFieldMapper
 
traverse(ObjectMapperListener) - Method in class org.elasticsearch.index.mapper.multifield.MultiFieldMapper
 
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_LEVELS - Static variable in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Names
 
treeLevels(int) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper.Builder
 
trimAllWhitespace(String) - Static method in class org.elasticsearch.common.Strings
Trim all whitespace from the given String: leading, trailing, and inbetween characters.
trimArrayElements(String[]) - Static method in class org.elasticsearch.common.Strings
Trim the elements of the given String array, calling String.trim() on each of them.
TrimFilter - Class in org.apache.lucene.analysis.miscellaneous
 
TrimFilter(TokenStream, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.TrimFilter
 
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
 
trimToSize() - Method in class jsr166e.extra.ReadMostlyVector
See Vector.trimToSize()
trimTrailingCharacter(String, char) - Static method in class org.elasticsearch.common.Strings
Trim all occurences of the supplied trailing character from the given String.
trimTrailingWhitespace(String) - Static method in class org.elasticsearch.common.Strings
Trim trailing whitespace from the given String.
trimWhitespace(String) - Static method in class org.elasticsearch.common.Strings
Trim leading and trailing whitespace from the given String.
TruncateTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
A token filter that truncates tokens.
TruncateTokenFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.TruncateTokenFilter
 
TruncateTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
TruncateTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.TruncateTokenFilterFactory
 
tryAwaitAvailability(long, TimeUnit) - Method in class jsr166e.SequenceLock
Returns the current sequence number if the lock is, or becomes, available within the specified waiting time.
tryComplete() - Method in class jsr166y.CountedCompleter
If the pending count is nonzero, decrements the count; otherwise invokes CountedCompleter.onCompletion(jsr166y.CountedCompleter) and then similarly tries to complete this task's completer, if one exists, else marks this task as complete.
tryLock() - Method in class jsr166e.SequenceLock
Acquires the lock only if it is not held by another thread at the time of invocation.
tryLock(long, TimeUnit) - Method in class jsr166e.SequenceLock
Acquires the lock if it is not held by another thread within the given waiting time and the current thread has not been interrupted.
tryMlockall() - Static method in class org.elasticsearch.common.jna.Natives
 
tryTransfer(E) - Method in class jsr166y.LinkedTransferQueue
Transfers the element to a waiting consumer immediately, if possible.
tryTransfer(E, long, TimeUnit) - Method in class jsr166y.LinkedTransferQueue
Transfers the element to a consumer if it is possible to do so before the timeout elapses.
tryTransfer(E) - Method in interface jsr166y.TransferQueue
Transfers the element to a waiting consumer immediately, if possible.
tryTransfer(E, long, TimeUnit) - Method in interface jsr166y.TransferQueue
Transfers the element to a consumer if it is possible to do so before the timeout elapses.
tryUnfork() - Method in class jsr166y.ForkJoinTask
Tries to unschedule this task for execution.
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() - Method in exception org.elasticsearch.index.AlreadyExpiredException
 
ttl() - Method in class org.elasticsearch.index.engine.Engine.Create
 
ttl() - Method in class org.elasticsearch.index.engine.Engine.Index
 
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
 
TTLFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
TTLFieldMapper - Class in org.elasticsearch.index.mapper.internal
 
TTLFieldMapper() - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
TTLFieldMapper(Field.Store, Field.Index, boolean, long, boolean) - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
TTLFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
TTLFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Builder
 
TTLFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
TTLFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper.Defaults
 
TTLFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
TTLFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.TTLFieldMapper.TypeParser
 
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_PI - Static variable in class org.elasticsearch.common.math.MathUtils
2 π.
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() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeResponse.AnalyzeToken
 
type() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
The mapping type.
type(String) - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
The type of the mappings to remove.
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.bulk.BulkItemResponse.Failure
The type of the action.
type() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The type of the action.
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.DeleteResponse
The type of the document deleted.
type() - Method in class org.elasticsearch.action.delete.index.IndexDeleteRequest
 
type() - Method in class org.elasticsearch.action.delete.index.ShardDeleteRequest
 
type() - Method in class org.elasticsearch.action.explain.ExplainRequest
 
type(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
 
type - Variable in class org.elasticsearch.action.get.GetRequest
 
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.GetResponse
The type of the document.
type() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
The type of the document.
type() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
 
type() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
The type of the action.
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.index.IndexResponse
The type of the document indexed.
type() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The type of document to load from which the "like" query will rutn 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(String) - Method in class org.elasticsearch.action.percolate.PercolateRequest
 
type() - Method in class org.elasticsearch.action.percolate.PercolateRequest
 
type() - Method in exception org.elasticsearch.action.RoutingMissingException
 
type() - Method in class org.elasticsearch.action.search.type.ParsedScrollId
 
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() - Method in class org.elasticsearch.action.update.UpdateResponse
The type of the document indexed.
type() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
type() - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
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 interface org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
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.compress.snappy.UnavailableSnappyCompressor
 
type() - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressor
 
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 class org.elasticsearch.gateway.fs.FsGateway
 
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 - Static variable in class org.elasticsearch.index.cache.bloom.BloomCacheModule.BloomCacheSettings
 
type() - Method in interface org.elasticsearch.index.cache.field.data.FieldDataCache
 
type() - Method in class org.elasticsearch.index.cache.field.data.none.NoneFieldDataCache
 
type() - Method in class org.elasticsearch.index.cache.field.data.resident.ResidentFieldDataCache
 
type() - Method in class org.elasticsearch.index.cache.field.data.soft.SoftFieldDataCache
 
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(String) - Method in interface org.elasticsearch.index.cache.id.IdReaderCache
 
type(String) - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderCache
 
type() - Method in class org.elasticsearch.index.cache.id.simple.SimpleIdReaderTypeCache
 
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.Create
 
type() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
type() - Method in class org.elasticsearch.index.engine.Engine.Index
 
type() - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
 
type() - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
type() - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
type() - Method in class org.elasticsearch.index.field.data.FieldData
The type of this field data.
type() - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
type() - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
type() - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
type() - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
type() - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
type() - Method in class org.elasticsearch.index.gateway.CommitPoint
 
type() - Method in class org.elasticsearch.index.gateway.fs.FsIndexGateway
 
type() - Method in class org.elasticsearch.index.gateway.fs.FsIndexShardGateway
 
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() - Method in class org.elasticsearch.index.get.GetResult
The type of the document.
type() - Method in class org.elasticsearch.index.mapper.DocumentMapper
 
type() - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
TYPE - Static variable in class org.elasticsearch.index.mapper.geo.GeoPointFieldDataType
 
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
 
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 - Static variable in class org.elasticsearch.index.merge.scheduler.MergeSchedulerModule.MergeSchedulerSettings
 
type() - Method in class org.elasticsearch.index.percolator.PercolatorExecutor.SourceRequest
 
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(MatchQueryBuilder.Type) - 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() - Method in class org.elasticsearch.river.RiverName
 
type(String) - Method in class org.elasticsearch.river.RiversTypesRegistry
 
TYPE - Static variable in interface org.elasticsearch.search.facet.datehistogram.DateHistogramFacet
The type of the filter facet.
type() - Method in class org.elasticsearch.search.facet.datehistogram.InternalCountDateHistogramFacet
 
type() - Method in class org.elasticsearch.search.facet.datehistogram.InternalFullDateHistogramFacet
 
type() - Method in interface org.elasticsearch.search.facet.Facet
The type of the facet.
TYPE - Static variable in interface org.elasticsearch.search.facet.filter.FilterFacet
The type of the filter facet.
type() - Method in class org.elasticsearch.search.facet.filter.InternalFilterFacet
 
TYPE - Static variable in interface org.elasticsearch.search.facet.geodistance.GeoDistanceFacet
The type of the filter facet.
type() - Method in class org.elasticsearch.search.facet.geodistance.InternalGeoDistanceFacet
 
type() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedCountHistogramFacet
 
type() - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
TYPE - Static variable in interface org.elasticsearch.search.facet.histogram.HistogramFacet
The type of the filter facet.
type() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
type() - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
type() - Method in class org.elasticsearch.search.facet.query.InternalQueryFacet
 
TYPE - Static variable in interface org.elasticsearch.search.facet.query.QueryFacet
The type of the filter facet.
type() - Method in class org.elasticsearch.search.facet.range.InternalRangeFacet
 
TYPE - Static variable in interface org.elasticsearch.search.facet.range.RangeFacet
The type of the filter facet.
type() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
TYPE - Static variable in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
The type of the filter facet.
type() - Method in class org.elasticsearch.search.facet.terms.bytes.InternalByteTermsFacet
 
type() - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
type() - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
type() - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
type() - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
type() - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
type() - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
type() - Method in class org.elasticsearch.search.facet.terms.strings.InternalStringTermsFacet
 
TYPE - Static variable in interface org.elasticsearch.search.facet.terms.TermsFacet
The type of the filter facet.
type() - Method in class org.elasticsearch.search.facet.termsstats.doubles.InternalTermsStatsDoubleFacet
 
type() - Method in class org.elasticsearch.search.facet.termsstats.longs.InternalTermsStatsLongFacet
 
type() - Method in class org.elasticsearch.search.facet.termsstats.strings.InternalTermsStatsStringFacet
 
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() - 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.threadpool.ThreadPool.Info
 
type() - Method in class org.elasticsearch.transport.TransportRequestOptions
 
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, Field.Index, Field.Store, Field.TermVector, float, boolean, FieldInfo.IndexOptions) - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
TypeFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
TypeFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Builder
 
TypeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
TypeFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper.Defaults
 
TypeFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
TypeFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.TypeFieldMapper.TypeParser
 
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
 
typeFromUid(String) - Static method in class org.elasticsearch.index.mapper.Uid
 
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(String) - Method in class org.elasticsearch.index.mapper.Mapper.TypeParser.ParserContext
 
TypeParsers - Class in org.elasticsearch.index.mapper.core
 
TypeParsers() - Constructor for class org.elasticsearch.index.mapper.core.TypeParsers
 
typePrefix(String) - Static method in class org.elasticsearch.index.mapper.Uid
 
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(String...) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
The types of documents the query will run against.
types(String...) - Method in class org.elasticsearch.action.count.CountRequest
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.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() - 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 class org.elasticsearch.index.mapper.MapperService
 
types() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
types() - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService
 
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.DateHistogramFacetProcessor
 
types() - Method in interface org.elasticsearch.search.facet.FacetProcessor
 
types() - Method in class org.elasticsearch.search.facet.filter.FilterFacetProcessor
 
types() - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetProcessor
 
types() - Method in class org.elasticsearch.search.facet.histogram.HistogramFacetProcessor
 
types() - Method in class org.elasticsearch.search.facet.query.QueryFacetProcessor
 
types() - Method in class org.elasticsearch.search.facet.range.RangeFacetProcessor
 
types() - Method in class org.elasticsearch.search.facet.statistical.StatisticalFacetProcessor
 
types() - Method in class org.elasticsearch.search.facet.terms.TermsFacetProcessor
 
types() - Method in class org.elasticsearch.search.facet.termsstats.TermsStatsFacetProcessor
 
types() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
types(String[]) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
types() - Method in class org.elasticsearch.search.internal.SearchContext
 
types() - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Entry
 
typeStats() - Method in class org.elasticsearch.index.indexing.IndexingStats
 

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.common.lucene.uid.UidField
 
uid() - Method in class org.elasticsearch.index.engine.Engine.Create
 
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.Index
 
uid() - Static method in class org.elasticsearch.index.mapper.MapperBuilders
 
uid() - Method in class org.elasticsearch.index.mapper.ParseContext
 
uid(String) - 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
 
UidAndRoutingFieldSelector - Class in org.elasticsearch.index.mapper.selector
An optimized field selector that loads just the uid and the routing.
UidAndRoutingFieldSelector() - Constructor for class org.elasticsearch.index.mapper.selector.UidAndRoutingFieldSelector
 
UidAndSourceFieldSelector - Class in org.elasticsearch.index.mapper.selector
An optimized field selector that loads just the uid and the source.
UidAndSourceFieldSelector() - Constructor for class org.elasticsearch.index.mapper.selector.UidAndSourceFieldSelector
 
uidField(String) - Static method in class org.elasticsearch.common.lucene.DocumentBuilder
 
uidField(String, long) - Static method in class org.elasticsearch.common.lucene.DocumentBuilder
 
UidField - Class in org.elasticsearch.common.lucene.uid
 
UidField(String, String, long) - Constructor for class org.elasticsearch.common.lucene.uid.UidField
 
uidField() - Method in class org.elasticsearch.index.engine.Engine.Create
 
uidField() - Method in class org.elasticsearch.index.engine.Engine.Index
 
UidField.DocIdAndVersion - Class in org.elasticsearch.common.lucene.uid
 
UidField.DocIdAndVersion(int, long, IndexReader, int) - Constructor for class org.elasticsearch.common.lucene.uid.UidField.DocIdAndVersion
 
UidField.UidPayloadTokenStream - Class in org.elasticsearch.common.lucene.uid
 
UidField.UidPayloadTokenStream(UidField) - Constructor for class org.elasticsearch.common.lucene.uid.UidField.UidPayloadTokenStream
 
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) - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
UidFieldMapper.Builder - Class in org.elasticsearch.index.mapper.internal
 
UidFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper.Builder
 
UidFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.internal
 
UidFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper.Defaults
 
UidFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.internal
 
UidFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.internal.UidFieldMapper.TypeParser
 
UidFieldSelector - Class in org.elasticsearch.index.mapper.selector
An optimized field selector that loads just the uid.
UidFilter - Class in org.elasticsearch.index.search
 
UidFilter(Collection<String>, List<String>, BloomCache) - Constructor for class org.elasticsearch.index.search.UidFilter
 
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() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
unassignedShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
unassignedShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
UnavailableShardsException - Exception in org.elasticsearch.action
 
UnavailableShardsException(ShardId, String) - Constructor for exception org.elasticsearch.action.UnavailableShardsException
 
UnavailableSnappyCompressor - Class in org.elasticsearch.common.compress.snappy
 
UnavailableSnappyCompressor() - Constructor for class org.elasticsearch.common.compress.snappy.UnavailableSnappyCompressor
 
UnboxedMathUtils - Class in org.elasticsearch.common.math
 
UnboxedMathUtils() - Constructor for class org.elasticsearch.common.math.UnboxedMathUtils
 
uncapitalize(String) - Static method in class org.elasticsearch.common.Strings
Uncapitalize a String, changing the first letter to lower case as per Character.toLowerCase(char).
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
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
 
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
 
uncompress(byte[], int, int) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressor
 
uncompress(byte[], int, int) - Method in class org.elasticsearch.common.compress.snappy.UnavailableSnappyCompressor
 
uncompress(IndexInput, byte[]) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressedIndexInput
 
uncompress(StreamInput, byte[]) - Method in class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressedStreamInput
 
uncompressed - Variable in class org.elasticsearch.common.compress.CompressedIndexInput
 
uncompressed - Variable in class org.elasticsearch.common.compress.CompressedIndexOutput
 
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
 
uncompressedLength - Variable in class org.elasticsearch.common.compress.CompressedIndexOutput
 
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).
underlying() - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
underlying() - Method in class org.elasticsearch.common.lucene.store.BufferedChecksumIndexOutput
 
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(ThreadPool, TransportService, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
UnicastZenPing(Settings, ThreadPool, TransportService, ClusterName, Set<UnicastHostsProvider>) - Constructor for class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
Unicode - Class in org.elasticsearch.common
 
Unicode() - Constructor for class org.elasticsearch.common.Unicode
 
Unicode.UTF16Result - Class in org.elasticsearch.common
 
Unicode.UTF16Result() - Constructor for class org.elasticsearch.common.Unicode.UTF16Result
 
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
 
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.index.search.geo.GeoDistanceDataComparator
 
unit(DistanceUnit) - Method in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetBuilder
The distance unit to use.
unit - Variable in class org.elasticsearch.search.facet.geodistance.GeoDistanceFacetCollector
 
unit(DistanceUnit) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
The distance unit to use.
UNKNOWN_SOURCE - Static variable in class org.elasticsearch.common.inject.internal.SourceProvider
Indicates that the source is unknown.
unlock() - Method in class jsr166e.SequenceLock
Attempts to release this lock.
unlock() - Method in class org.elasticsearch.cluster.metadata.MetaDataService.MdLock
 
UnmodifiableIterator<E> - Class in org.elasticsearch.common.inject.internal
An iterator that does not support UnmodifiableIterator.remove().
UnmodifiableIterator() - Constructor for class org.elasticsearch.common.inject.internal.UnmodifiableIterator
 
unqualify(String) - Static method in class org.elasticsearch.common.Strings
Unqualify a string qualified by a '.' dot character.
unqualify(String, char) - Static method in class org.elasticsearch.common.Strings
Unqualify a string qualified by a separator character.
unregisterGroup(String) - Method in class org.elasticsearch.jmx.JmxService
 
unsafeArray() - Method in class org.elasticsearch.common.trove.ExtTIntArrayList
 
unsafeCharArray() - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Returns the underlying char array.
unsafeFromBytesAsUtf16(byte[]) - Static method in class org.elasticsearch.common.Unicode
 
unsafeFromBytesAsUtf16(byte[], int, int) - Static method in class org.elasticsearch.common.Unicode
 
unsafeFromStringAsUtf8(String) - Static method in class org.elasticsearch.common.Unicode
 
UNSCOPED - Static variable in class org.elasticsearch.common.inject.internal.Scoping
No scoping annotation has been applied.
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(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.mvel.MvelScriptEngineService.MvelExecutableScript
 
unwrap(Object) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService.MvelSearchScript
 
unwrap(Object) - Method in class org.elasticsearch.script.mvel.MvelScriptEngineService
 
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
 
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>) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
Updates the provided changes into the source.
UpdateAction - Class in org.elasticsearch.action.update
 
updatedSettings() - Method in class org.elasticsearch.plugins.PluginsService
 
updateIndexingBufferSize(ByteSizeValue) - Method in interface org.elasticsearch.index.engine.Engine
 
updateIndexingBufferSize(ByteSizeValue) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
updateKeyWithNamedWildcard(String) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
 
updateMapping(String, String, CompressedString, MetaDataMappingService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataMappingService
 
updateNodes(RoutingNodes) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
updateNodes(DiscoveryNodes) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
 
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(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) - Constructor for class org.elasticsearch.action.update.UpdateResponse
 
updateRewriteQuery(Query) - Method in class org.elasticsearch.search.internal.SearchContext
Rewrites the query and updates it.
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(Settings, String[], MetaDataUpdateSettingsService.Listener) - Method in class org.elasticsearch.cluster.metadata.MetaDataUpdateSettingsService
 
UpdateSettingsAction - Class in org.elasticsearch.action.admin.indices.settings
 
UpdateSettingsRequest - Class in org.elasticsearch.action.admin.indices.settings
 
UpdateSettingsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
Constructs a new request to create an index with the specified name and settings.
UpdateSettingsRequest(Settings, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
Constructs a new request to create an index with the specified name and settings.
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
 
UpdateSettingsRequestBuilder(IndicesAdminClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequestBuilder
 
UpdateSettingsResponse - Class in org.elasticsearch.action.admin.indices.settings
A response for a update settings action.
updateStage(RecoveryStatus.Stage) - Method in class org.elasticsearch.index.gateway.RecoveryStatus
 
updateStage(SnapshotStatus.Stage) - Method in class org.elasticsearch.index.gateway.SnapshotStatus
 
updateVersion(long) - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
UPPER - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
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.
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
 
uri() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
uri() - Method in interface org.elasticsearch.rest.RestRequest
The uri of the rest request, with the query string.
URL_SAFE - Static variable in class org.elasticsearch.common.Base64
Encode using Base64-like encoding that is URL- and Filename-safe as described in Section 4 of RFC3548: http://www.faqs.org/rfcs/rfc3548.html.
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.QueryParserSettings
 
useDisMax(boolean) - Method in class org.apache.lucene.queryParser.QueryParserSettings
 
useDisMax(Boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
 
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
 
useFieldQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
useFieldQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
useFieldQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Use the field query created here when matching on numbers.
useFieldQueryWithQueryString() - Method in interface org.elasticsearch.index.mapper.FieldMapper
Should the field query FieldMapper.fieldQuery(String, org.elasticsearch.index.query.QueryParseContext) be used when detecting this field in query string.
useFieldQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
useFieldQueryWithQueryString() - 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...
useFieldQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
usePrettyPrint() - Method in class org.elasticsearch.common.xcontent.json.JsonXContentGenerator
 
usePrettyPrint() - Method in interface org.elasticsearch.common.xcontent.XContentGenerator
 
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.
UTF8 - Static variable in class org.elasticsearch.common.lucene.spatial.prefix.tree.SpatialPrefixTree
 
Utf8RestResponse - Class in org.elasticsearch.rest
An http response that is built on top of UnicodeUtil.UTF8Result.
Utf8RestResponse(RestStatus) - Constructor for class org.elasticsearch.rest.Utf8RestResponse
 
Utf8RestResponse(RestStatus, UnicodeUtil.UTF8Result) - Constructor for class org.elasticsearch.rest.Utf8RestResponse
 
Utf8RestResponse(RestStatus, UnicodeUtil.UTF8Result, UnicodeUtil.UTF8Result, UnicodeUtil.UTF8Result) - Constructor for class org.elasticsearch.rest.Utf8RestResponse
 
utf8StreamWriter() - Static method in class org.elasticsearch.common.io.stream.CachedStreamOutput
 
UTF8StreamWriter - Class in org.elasticsearch.common.io
 
UTF8StreamWriter() - Constructor for class org.elasticsearch.common.io.UTF8StreamWriter
Creates a UTF-8 writer having a byte buffer of moderate capacity (2048).
UTF8StreamWriter(int) - Constructor for class org.elasticsearch.common.io.UTF8StreamWriter
Creates a UTF-8 writer having a byte buffer of specified capacity.
utf8ToString() - Method in class org.elasticsearch.index.cache.filter.support.CacheKeyFilter.Key
 
UTF8toUTF16(byte[], int, int, Unicode.UTF16Result) - Static method in class org.elasticsearch.common.Unicode
Convert UTF8 bytes into UTF16 characters.
UUID - Class in org.elasticsearch.common
A UUID taken from java UUID that simply holds less data.
UUID(long, long) - Constructor for class org.elasticsearch.common.UUID
Constructs a new UUID using the specified data.

V

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_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_Beta1 - Static variable in class org.elasticsearch.Version
 
V_0_20_0_Beta1_ID - Static variable in class org.elasticsearch.Version
 
valid() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
 
valid() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
A boolean denoting whether the query is valid.
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
 
validate() - Method in interface 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.reroute.ClusterRerouteRequest
 
validate() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
 
validate() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
 
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.IndicesExistsRequest
 
validate() - Method in class org.elasticsearch.action.admin.indices.mapping.delete.DeleteMappingRequest
 
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.UpdateSettingsRequest
 
validate() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
 
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.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.index.ShardDeleteRequest
 
validate() - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
validate() - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryRequest
 
validate() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
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.mlt.MoreLikeThisRequest
 
validate() - Method in class org.elasticsearch.action.percolate.PercolateRequest
 
validate() - Method in class org.elasticsearch.action.search.MultiSearchRequest
 
validate() - Method in class org.elasticsearch.action.search.SearchRequest
 
validate() - Method in class org.elasticsearch.action.search.SearchScrollRequest
 
validate() - Method in class org.elasticsearch.action.support.broadcast.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.update.UpdateRequest
 
validate() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
validate(RoutingTableValidation, MetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
validate() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
validate(MetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.AnalyzerMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.SizeFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
validate(ParseContext) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
validate(ParseContext) - Method in interface org.elasticsearch.index.mapper.RootMapper
 
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
 
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
 
validation() - Method in exception org.elasticsearch.cluster.routing.RoutingValidationException
 
validationErrors() - Method in exception org.elasticsearch.action.ActionRequestValidationException
 
validationFailures() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
The validation failures on the cluster level (without index validation failures).
validationFailures() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
validFileName(String) - Static method in class org.elasticsearch.common.Strings
 
validFileNameExcludingAstrix(String) - Static method in class org.elasticsearch.common.Strings
 
value() - Method in enum org.elasticsearch.action.admin.cluster.health.ClusterHealthStatus
 
value() - Method in enum org.elasticsearch.action.admin.indices.status.GatewayRecoveryStatus.Stage
 
value() - Method in enum org.elasticsearch.action.admin.indices.status.GatewaySnapshotStatus.Stage
 
value() - Method in enum org.elasticsearch.action.admin.indices.status.PeerRecoveryStatus.Stage
 
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.routing.ShardRoutingState
 
value() - Method in class org.elasticsearch.common.unit.Percent
 
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(BytesReference) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
value(Text) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
value(Map<String, Object>) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
value(Iterable) - Method in class org.elasticsearch.common.xcontent.XContentBuilder
 
value() - Method in class org.elasticsearch.index.cache.filter.support.FilterCacheValue
 
value(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldDataMissingComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldDataMissingComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldDataMissingComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldDataMissingComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldDataMissingComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldDataMissingComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.strings.MultiValueStringFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.strings.SingleValueStringFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
value(int) - Method in class org.elasticsearch.index.field.data.strings.StringOrdValFieldDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.data.strings.StringValFieldDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.function.sort.DoubleFieldsFunctionDataComparator
 
value(int) - Method in class org.elasticsearch.index.field.function.sort.StringFieldsFunctionDataComparator
 
value() - Method in class org.elasticsearch.index.get.GetField
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
value(Fieldable) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the actual value of the field.
value(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
value(int) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
value(int) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
value(int) - Method in class org.elasticsearch.index.search.geo.GeoDistanceDataComparator
 
value() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
 
value() - Method in interface org.elasticsearch.search.SearchHitField
The first value of the hit.
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
valueAsString(Fieldable) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the actual value of the field as string.
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
ValueDateHistogramFacetCollector - Class in org.elasticsearch.search.facet.datehistogram
A histogram facet collector that uses different fields for the key and the value.
ValueDateHistogramFacetCollector(String, String, String, TimeZoneRounding, DateHistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetCollector
 
ValueDateHistogramFacetCollector.DateHistogramProc - Class in org.elasticsearch.search.facet.datehistogram
 
ValueDateHistogramFacetCollector.DateHistogramProc(TimeZoneRounding) - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetCollector.DateHistogramProc
 
ValueDateHistogramFacetCollector.DateHistogramProc.ValueAggregator - Class in org.elasticsearch.search.facet.datehistogram
 
ValueDateHistogramFacetCollector.DateHistogramProc.ValueAggregator() - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueDateHistogramFacetCollector.DateHistogramProc.ValueAggregator
 
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
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.core.AbstractFieldMapper
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
Dates should return as a string, delegates to DateFieldMapper.valueAsString(org.apache.lucene.document.Fieldable).
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.core.NumberFieldMapper
Override the default behavior (to return the string, and return the actual Number instance).
valueForSearch(Fieldable) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the value that will be used as a result for search.
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.TimestampFieldMapper
Override the default behavior to return a timestamp
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
valueForSearch(long) - Method in class org.elasticsearch.index.mapper.internal.TTLFieldMapper
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
IPs should return as a string, delegates to IpFieldMapper.valueAsString(org.apache.lucene.document.Fieldable).
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.BinaryFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.BooleanFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.ByteFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.DateFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.DoubleFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.FloatFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.IntegerFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.LongFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.ShortFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.core.StringFieldMapper
 
valueFromString(String) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.geo.GeoShapeFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.AllFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.BoostFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.IdFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.IndexFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.ParentFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.RoutingFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.SourceFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.TypeFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.internal.UidFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.ip.IpFieldMapper
 
ValueGeoDistanceFacetCollector - Class in org.elasticsearch.search.facet.geodistance
 
ValueGeoDistanceFacetCollector(String, String, double, double, DistanceUnit, GeoDistance, GeoDistanceFacet.Entry[], SearchContext, String) - Constructor for class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetCollector
 
ValueGeoDistanceFacetCollector.Aggregator - Class in org.elasticsearch.search.facet.geodistance
 
ValueGeoDistanceFacetCollector.Aggregator(GeoDistance.FixedSourceDistance, GeoDistanceFacet.Entry[]) - Constructor for class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetCollector.Aggregator
 
ValueGeoDistanceFacetCollector.ValueAggregator - Class in org.elasticsearch.search.facet.geodistance
 
ValueGeoDistanceFacetCollector.ValueAggregator() - Constructor for class org.elasticsearch.search.facet.geodistance.ValueGeoDistanceFacetCollector.ValueAggregator
 
ValueHistogramFacetCollector - Class in org.elasticsearch.search.facet.histogram.unbounded
A histogram facet collector that uses different fields for the key and the value.
ValueHistogramFacetCollector(String, String, String, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.ValueHistogramFacetCollector
 
ValueHistogramFacetCollector.HistogramProc - Class in org.elasticsearch.search.facet.histogram.unbounded
 
ValueHistogramFacetCollector.HistogramProc(long) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.ValueHistogramFacetCollector.HistogramProc
 
ValueHistogramFacetCollector.HistogramProc.ValueAggregator - Class in org.elasticsearch.search.facet.histogram.unbounded
 
ValueHistogramFacetCollector.HistogramProc.ValueAggregator() - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.ValueHistogramFacetCollector.HistogramProc.ValueAggregator
 
valueOf(String) - Static method in enum org.apache.lucene.store.bytebuffer.ByteBufferAllocator.Type
Returns the enum constant of this type with the specified name.
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.indices.status.GatewayRecoveryStatus.Stage
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
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
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.SearchOperationThreading
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.broadcast.BroadcastOperationThreading
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.action.support.IgnoreIndices
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.ThreadingModel
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.cluster.block.ClusterBlockLevel
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.routing.allocation.decider.AllocationDecider.Decision
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.ShardRoutingState
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.ShapeRelation
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.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.network.NetworkUtils.StackType
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.SizeUnit
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.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.gateway.CommitPoint.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.gateway.RecoveryStatus.Stage
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.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.query.FieldQueryBuilder.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.QueryStringQueryBuilder.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.search.child.TopChildrenQuery.ScoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.search.geo.GeoDistance
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.nested.BlockJoinQuery.ScoreMode
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.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.recovery.RecoveryStatus.Stage
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.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.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.InternalSearchHits.StreamContext.ShardTargetType
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.transport.TransportRequestOptions.Type
Returns the enum constant of this type with the specified name.
values() - Method in class jsr166e.ConcurrentHashMapV8
Returns a Collection view of the values contained in this map.
values() - Static method in enum org.apache.lucene.store.bytebuffer.ByteBufferAllocator.Type
Returns an array containing the constants of this enum type, in the order they are declared.
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.indices.status.GatewayRecoveryStatus.Stage
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
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
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.SearchOperationThreading
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.broadcast.BroadcastOperationThreading
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.IgnoreIndices
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.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.WriteConsistencyLevel
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.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.routing.allocation.decider.AllocationDecider.Decision
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.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.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.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.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.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.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.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.SizeUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.elasticsearch.common.util.concurrent.ConcurrentHashMapLong
 
values() - Static method in enum org.elasticsearch.common.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.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 - Variable in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
values() - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.bytes.ByteFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.bytes.MultiValueByteFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.bytes.SingleValueByteFieldData
 
values - Variable in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
values() - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.doubles.DoubleFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.doubles.MultiValueDoubleFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.doubles.SingleValueDoubleFieldData
 
values - Variable in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
values() - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.floats.FloatFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.floats.MultiValueFloatFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.floats.SingleValueFloatFieldData
 
values - Variable in class org.elasticsearch.index.field.data.ints.IntFieldData
 
values() - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.ints.IntFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.ints.MultiValueIntFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.ints.SingleValueIntFieldData
 
values - Variable in class org.elasticsearch.index.field.data.longs.LongFieldData
 
values() - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.longs.LongFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.longs.MultiValueLongFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.longs.SingleValueLongFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.shorts.MultiValueShortFieldData
 
values - Variable in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
values() - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.shorts.ShortFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.shorts.SingleValueShortFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.strings.MultiValueStringFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.strings.SingleValueStringFieldData
 
values - Variable in class org.elasticsearch.index.field.data.strings.StringFieldData
 
values() - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
values(int) - Method in class org.elasticsearch.index.field.data.strings.StringFieldData
 
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.RecoveryStatus.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.gateway.SnapshotStatus.Stage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.elasticsearch.index.get.GetField
 
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(int) - Method in class org.elasticsearch.index.mapper.geo.GeoPointFieldData
 
values(int) - Method in class org.elasticsearch.index.mapper.geo.MultiValueGeoPointFieldData
 
values(int) - Method in class org.elasticsearch.index.mapper.geo.SingleValueGeoPointFieldData
 
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.query.FieldQueryBuilder.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.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.search.child.TopChildrenQuery.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.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.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.nested.BlockJoinQuery.ScoreMode
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.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.recovery.RecoveryStatus.Stage
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.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.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() - 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() - 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() - 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.transport.TransportRequestOptions.Type
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.ValueScriptDateHistogramFacetCollector.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.
ValueScriptDateHistogramFacetCollector - Class in org.elasticsearch.search.facet.datehistogram
A histogram facet collector that uses the same field as the key as well as the value.
ValueScriptDateHistogramFacetCollector(String, String, String, String, Map<String, Object>, TimeZoneRounding, DateHistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetCollector
 
ValueScriptDateHistogramFacetCollector.DateHistogramProc - Class in org.elasticsearch.search.facet.datehistogram
 
ValueScriptDateHistogramFacetCollector.DateHistogramProc(TimeZoneRounding, SearchScript) - Constructor for class org.elasticsearch.search.facet.datehistogram.ValueScriptDateHistogramFacetCollector.DateHistogramProc
 
ValueScriptHistogramFacetCollector - Class in org.elasticsearch.search.facet.histogram.unbounded
A histogram facet collector that uses the same field as the key as well as the value.
ValueScriptHistogramFacetCollector(String, String, String, String, Map<String, Object>, long, HistogramFacet.ComparatorType, SearchContext) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.ValueScriptHistogramFacetCollector
 
ValueScriptHistogramFacetCollector.HistogramProc - Class in org.elasticsearch.search.facet.histogram.unbounded
 
ValueScriptHistogramFacetCollector.HistogramProc(long, SearchScript) - Constructor for class org.elasticsearch.search.facet.histogram.unbounded.ValueScriptHistogramFacetCollector.HistogramProc
 
variance() - Method in class org.elasticsearch.search.facet.statistical.InternalStatisticalFacet
 
variance() - Method in interface org.elasticsearch.search.facet.statistical.StatisticalFacet
Variance of the values.
vendor() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
version() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
The version of the action.
version(long) - Method in class org.elasticsearch.action.delete.DeleteRequest
Sets the version, which will cause the delete operation to only be performed if a matching version exists and no changes happened on the doc since then.
version() - Method in class org.elasticsearch.action.delete.DeleteRequest
 
version() - Method in class org.elasticsearch.action.delete.DeleteResponse
The version of the delete operation.
version() - Method in class org.elasticsearch.action.delete.index.IndexDeleteRequest
 
version(long) - Method in class org.elasticsearch.action.delete.index.ShardDeleteRequest
 
version() - Method in class org.elasticsearch.action.delete.index.ShardDeleteRequest
 
version() - Method in class org.elasticsearch.action.delete.index.ShardDeleteResponse
 
version() - Method in class org.elasticsearch.action.get.GetResponse
The version of the doc.
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() - Method in class org.elasticsearch.action.index.IndexResponse
Returns the version of the doc indexed.
version() - Method in class org.elasticsearch.action.update.UpdateResponse
Returns the version of the doc indexed.
version() - Method in class org.elasticsearch.cluster.action.index.NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse
 
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
 
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.UidField.DocIdAndVersion
 
version() - Method in class org.elasticsearch.common.lucene.uid.UidField
 
version(long) - Method in class org.elasticsearch.common.lucene.uid.UidField
 
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 - Variable in class org.elasticsearch.index.analysis.AbstractTokenizerFactory
 
version() - Method in class org.elasticsearch.index.engine.Engine.Create
 
version(long) - Method in class org.elasticsearch.index.engine.Engine.Create
 
version(long) - Method in class org.elasticsearch.index.engine.Engine.Delete
 
version() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
version() - Method in class org.elasticsearch.index.engine.Engine.GetResult
 
version(long) - Method in class org.elasticsearch.index.engine.Engine.Index
 
version() - Method in class org.elasticsearch.index.engine.Engine.Index
 
version() - Method in class org.elasticsearch.index.gateway.CommitPoint
 
version() - Method in class org.elasticsearch.index.gateway.RecoveryStatus.Index
 
version() - Method in class org.elasticsearch.index.get.GetResult
The version of the doc.
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.monitor.jvm.JvmInfo
 
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(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 interface org.elasticsearch.search.SearchHit
The version of the hit.
Version - Class in org.elasticsearch
 
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
 
VersionParseElement - Class in org.elasticsearch.search.fetch.version
 
VersionParseElement() - Constructor for class org.elasticsearch.search.fetch.version.VersionParseElement
 
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.index.IndexRequest
Sets the versioning type.
versionType() - Method in class org.elasticsearch.action.index.IndexRequest
 
versionType() - Method in class org.elasticsearch.index.engine.Engine.Create
 
versionType(VersionType) - Method in class org.elasticsearch.index.engine.Engine.Create
 
versionType(VersionType) - Method in class org.elasticsearch.index.engine.Engine.Delete
 
versionType() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
versionType(VersionType) - Method in class org.elasticsearch.index.engine.Engine.Index
 
versionType() - Method in class org.elasticsearch.index.engine.Engine.Index
 
VersionType - Enum in org.elasticsearch.index
 
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
 
voidProviderMethod() - Method in class org.elasticsearch.common.inject.internal.Errors
 
VoidStreamable - Class in org.elasticsearch.common.io.stream
 
VoidStreamable() - Constructor for class org.elasticsearch.common.io.stream.VoidStreamable
 
VoidTransportResponseHandler - Class in org.elasticsearch.transport
 
VoidTransportResponseHandler(String) - Constructor for class org.elasticsearch.transport.VoidTransportResponseHandler
 

W

WAIT_FOR_MERGE - Static variable in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest.Defaults
 
waitForActiveShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForGreenStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
waitForMerge() - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should the call block until the optimize completes.
waitForMerge(boolean) - Method in class org.elasticsearch.action.admin.indices.optimize.OptimizeRequest
Should the call block until the optimize completes.
waitForMerge() - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
waitForMerge(boolean) - Method in class org.elasticsearch.index.engine.Engine.Optimize
 
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.
waitForOperations() - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
 
waitForOperations(boolean) - Method in class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
 
waitForOperations() - Method in class org.elasticsearch.index.engine.Engine.Refresh
 
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
 
warm(IndexShard, IndexMetaData, IndicesWarmer.WarmerContext) - Method in interface org.elasticsearch.indices.warmer.IndicesWarmer.Listener
 
warm(IndicesWarmer.WarmerContext) - Method in class org.elasticsearch.indices.warmer.InternalIndicesWarmer
 
warmer() - Method 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
 
warmerService() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
warmerService() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
warmerStats() - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
warmerStats() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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
 
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
 
weakCompareAndSet(double, double) - Method in class jsr166e.extra.AtomicDouble
Atomically sets the value to the given updated value if the current value is bitwise equal to the expected value.
weakCompareAndSet(int, double, double) - Method in class jsr166e.extra.AtomicDoubleArray
Atomically sets the element at position i to the given updated value if the current value is bitwise equal to the expected value.
weigh(WeightedFilterCache.FilterCacheKey, DocSet) - Method in class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheValueWeigher
 
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.FilterCacheKey(String, Object, Object) - Constructor for class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheKey
 
WeightedFilterCache.FilterCacheValueWeigher - Class in org.elasticsearch.index.cache.filter.weighted
 
WeightedFilterCache.FilterCacheValueWeigher() - Constructor for class org.elasticsearch.index.cache.filter.weighted.WeightedFilterCache.FilterCacheValueWeigher
 
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
 
WINDOWS - Static variable in class org.elasticsearch.common.os.OsUtils
True iff running on Windows.
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().
withCompress(boolean) - Method in class org.elasticsearch.transport.TransportRequestOptions
 
withCompress(boolean) - Method in class org.elasticsearch.transport.TransportResponseOptions
 
withHighType() - Method in class org.elasticsearch.transport.TransportRequestOptions
A request that requires very low latency.
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
 
withLowType() - Method in class org.elasticsearch.transport.TransportRequestOptions
Batch oriented (big payload) based requests use this one.
withMedType() - Method in class org.elasticsearch.transport.TransportRequestOptions
The typical requests flows go through this one.
withPartialValue(Object) - Method in exception org.elasticsearch.common.inject.ConfigurationException
Returns a copy of this configuration exception with the specified partial value.
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
 
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
 
WordDelimiterFilter - Class in org.apache.lucene.analysis.miscellaneous
Splits words into subwords and performs optional transformations on subword groups.
WordDelimiterFilter(TokenStream, byte[], int, int, int, int, int, int, int, int, int, CharArraySet) - Constructor for class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
WordDelimiterFilter(TokenStream, int, int, int, int, int, int, int, int, int, CharArraySet) - Constructor for class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
 
WordDelimiterIterator - Class in org.apache.lucene.analysis.miscellaneous
A BreakIterator-like API for iterating over subwords in text, according to WordDelimiterFilter rules.
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
 
WORK_FACTOR - Static variable in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
This constant is accessible by subclasses for historical purposes.
workFile() - Method in class org.elasticsearch.env.Environment
The work location.
workWithClusterFile() - Method in class org.elasticsearch.env.Environment
The work location with the cluster name as a sub directory.
wrappedOut() - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
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
 
write(int) - Method in class org.elasticsearch.common.Base64.OutputStream
Writes the byte to the output stream after converting to/from Base64 notation.
write(byte[], int, int) - Method in class org.elasticsearch.common.Base64.OutputStream
Calls Base64.OutputStream.write(int) repeatedly until len bytes are written.
write(int) - Method in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
 
write(byte[], int, int) - Method in class org.elasticsearch.common.compress.bzip2.CBZip2OutputStream
 
write(int) - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
write(int) - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Writes the specified byte to this byte array output stream.
write(byte[], int, int) - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Writes len bytes from the specified byte array starting at offset off to this byte array output stream.
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(MetaData) - Method in class org.elasticsearch.gateway.blobstore.BlobStoreGateway
 
write(MetaData) - Method in class org.elasticsearch.gateway.shared.SharedStorageGateway
 
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
 
writeBlob(String, InputStream, long, ImmutableBlobContainer.WriterListener) - Method in class org.elasticsearch.common.blobstore.fs.FsImmutableBlobContainer
 
writeBlob(String, InputStream, long) - Method in class org.elasticsearch.common.blobstore.fs.FsImmutableBlobContainer
 
writeBlob(String, InputStream, long, ImmutableBlobContainer.WriterListener) - Method in interface org.elasticsearch.common.blobstore.ImmutableBlobContainer
 
writeBlob(String, InputStream, long) - Method in interface org.elasticsearch.common.blobstore.ImmutableBlobContainer
 
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
 
writeByte(byte) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.OpenBufferedIndexOutput
Writes a single byte.
writeByte(byte) - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
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.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.ChecksumIndexOutput
 
writeByte(byte) - Method in class org.elasticsearch.common.lucene.store.NullIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.bytebuffer.ByteBufferIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.OpenBufferedIndexOutput
Writes an array of bytes.
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
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.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.ChecksumIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.NullIndexOutput
 
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.
writeChecksum(String, String) - Method in class org.elasticsearch.index.store.Store
 
writeChecksums() - Method in class org.elasticsearch.index.store.Store
 
writeChecksums(Map<String, String>) - Method in class org.elasticsearch.index.store.Store
 
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).
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
 
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
 
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
 
writeFloat(float) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeFloat(float) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeGenericValue(Object) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeHeader(IndexOutput) - Method in class org.elasticsearch.common.compress.CompressedIndexOutput
 
writeHeader(StreamOutput) - Method in class org.elasticsearch.common.compress.CompressedStreamOutput
 
writeHeader(IndexOutput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedIndexOutput
 
writeHeader(StreamOutput) - Method in class org.elasticsearch.common.compress.lzf.LZFCompressedStreamOutput
 
writeHeader(IndexOutput) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressedIndexOutput
 
writeHeader(StreamOutput) - Method in class org.elasticsearch.common.compress.snappy.SnappyCompressedStreamOutput
 
writeHeader(byte[], int, int, long, byte) - Static method in class org.elasticsearch.transport.support.TransportStreams
 
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.
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.
writeMap(StreamOutput, Map<String, Object>) - Static method in class org.elasticsearch.common.io.stream.Streamables
 
writeMap(Map<String, Object>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeMap(XContentGenerator, Map<String, Object>) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapConverter
 
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
 
writeOptionalString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
writeOptionalUTF(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Deprecated. 
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, BytesReference, 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, 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, BytesReference, 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
 
writeSettingsToStream(Settings, StreamOutput) - Static method in class org.elasticsearch.common.settings.ImmutableSettings
 
writeShort(short) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
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
 
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
 
writeText(Text) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeText(Text) - Method in class org.elasticsearch.common.io.stream.StreamOutput
 
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.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.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.state.ClusterStateRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
 
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.IndicesExistsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.IndicesExistsResponse
 
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.gateway.snapshot.GatewaySnapshotResponse
 
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.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.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.segments.TransportIndicesSegmentsAction.IndexShardSegmentRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.UpdateSettingsResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction.IndexShardStatsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction.IndexShardStatusRequest
 
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.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.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.index.IndexDeleteRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.index.IndexDeleteResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.index.ShardDeleteRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.index.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.IndexDeleteByQueryRequest
 
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.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.mlt.MoreLikeThisRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.PercolateRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.percolate.PercolateResponse
 
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.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.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.PrimaryOperationRequest
 
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.support.single.shard.TransportShardSingleOperationAction.ShardSingleOperationRequest
 
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.NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
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 interface org.elasticsearch.cluster.metadata.MetaData.Custom.Factory
 
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(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(RoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.ByteBufferBytesReference
 
writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.BytesArray
 
writeTo(OutputStream) - Method in interface org.elasticsearch.common.bytes.BytesReference
Writes the bytes directly to the output stream.
writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.ChannelBufferBytesReference
 
writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.HashedBytesArray
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.compress.CompressedString
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.io.BooleanStreamable
 
writeTo(OutputStream) - Method in class org.elasticsearch.common.io.FastByteArrayOutputStream
Writes the complete contents of this byte array output stream to the specified output stream argument, as if by calling the output stream's write method using out.write(buf, 0, count).
writeTo(Writer) - Method in class org.elasticsearch.common.io.FastCharArrayWriter
Writes the contents of the buffer to another character stream.
writeTo(StreamOutput) - Method in class org.elasticsearch.common.io.stream.LongStreamable
 
writeTo(StreamOutput) - Method in interface org.elasticsearch.common.io.stream.Streamable
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.io.stream.StringStreamable
 
writeTo(StreamOutput) - Method in class org.elasticsearch.common.io.stream.VoidStreamable
 
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(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.CacheStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.Segment
 
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.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.StoreFileMetaData
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.StoreStats
 
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.warmer.WarmerStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.indices.NodeIndicesStats
 
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, 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(StreamOutput) - Method in class org.elasticsearch.search.count.CountSearchResult
 
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.bounded.InternalBoundedCountHistogramFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.histogram.bounded.InternalBoundedFullHistogramFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalCountHistogramFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.histogram.unbounded.InternalFullHistogramFacet
 
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.bytes.InternalByteTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.doubles.InternalDoubleTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.floats.InternalFloatTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.ints.InternalIntTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.ip.InternalIpTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.longs.InternalLongTermsFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facet.terms.shorts.InternalShortTermsFacet
 
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.FetchSearchRequest
 
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.highlight.HighlightField
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
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.InternalSearchRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchResponse
 
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(IndexWarmersMetaData, StreamOutput) - Method in class org.elasticsearch.search.warmer.IndexWarmersMetaData.Factory
 
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.TransportInfo
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportStats
 
writeTopDocs(StreamOutput, TopDocs, int) - Static method in class org.elasticsearch.common.lucene.Lucene
 
writeToThin(StreamOutput) - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
Does not write 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
 
writeUTF(String) - Method in class org.elasticsearch.common.io.stream.AdapterStreamOutput
 
writeUTF(String) - Method in class org.elasticsearch.common.io.stream.HandlesStreamOutput
Deprecated. 
writeUTF(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
Deprecated. use StreamOutput.writeString(String)
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(Version, StreamOutput) - Static method in class org.elasticsearch.Version
 
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.

X

XBooleanFilter - Class in org.elasticsearch.common.lucene.search
 
XBooleanFilter() - Constructor for class org.elasticsearch.common.lucene.search.XBooleanFilter
 
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(XContent, OutputStream, Object) - 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
 
XContentGenerator - Interface in org.elasticsearch.common.xcontent
 
XContentHelper - Class in org.elasticsearch.common.xcontent
 
XContentHelper() - Constructor for class org.elasticsearch.common.xcontent.XContentHelper
 
XContentMapConverter - Class in org.elasticsearch.common.xcontent.support
 
XContentMapConverter() - Constructor for class org.elasticsearch.common.xcontent.support.XContentMapConverter
 
XContentMapConverter.MapFactory - Interface in org.elasticsearch.common.xcontent.support
 
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
 
XContentParser.NumberType - Enum in org.elasticsearch.common.xcontent
 
XContentParser.Token - Enum in org.elasticsearch.common.xcontent
 
XContentRestResponse - Class in org.elasticsearch.rest
 
XContentRestResponse(RestRequest, RestStatus, XContentBuilder) - Constructor for class org.elasticsearch.rest.XContentRestResponse
 
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
 
XContentThrowableRestResponse - Class in org.elasticsearch.rest
 
XContentThrowableRestResponse(RestRequest, Throwable) - Constructor for class org.elasticsearch.rest.XContentThrowableRestResponse
 
XContentThrowableRestResponse(RestRequest, RestStatus, Throwable) - Constructor for class org.elasticsearch.rest.XContentThrowableRestResponse
 
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.
XerialSnappy - Class in org.elasticsearch.common.compress.snappy.xerial
 
XerialSnappy() - Constructor for class org.elasticsearch.common.compress.snappy.xerial.XerialSnappy
 
XerialSnappyCompressedIndexInput - Class in org.elasticsearch.common.compress.snappy.xerial
 
XerialSnappyCompressedIndexInput(IndexInput, SnappyCompressorContext) - Constructor for class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressedIndexInput
 
XerialSnappyCompressedIndexOutput - Class in org.elasticsearch.common.compress.snappy.xerial
 
XerialSnappyCompressedIndexOutput(IndexOutput, SnappyCompressorContext) - Constructor for class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressedIndexOutput
 
XerialSnappyCompressedStreamInput - Class in org.elasticsearch.common.compress.snappy.xerial
 
XerialSnappyCompressedStreamInput(StreamInput, SnappyCompressorContext) - Constructor for class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressedStreamInput
 
XerialSnappyCompressedStreamOutput - Class in org.elasticsearch.common.compress.snappy.xerial
 
XerialSnappyCompressedStreamOutput(StreamOutput, SnappyCompressorContext) - Constructor for class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressedStreamOutput
 
XerialSnappyCompressor - Class in org.elasticsearch.common.compress.snappy.xerial
 
XerialSnappyCompressor() - Constructor for class org.elasticsearch.common.compress.snappy.xerial.XerialSnappyCompressor
 
XIndexWriter - Class in org.apache.lucene.index
 
XIndexWriter(Directory, IndexWriterConfig, ESLogger, BloomCache) - Constructor for class org.apache.lucene.index.XIndexWriter
 
XIndexWriter.XBufferedDeletesStream - Interface in org.apache.lucene.index
 
XMMapFSDirectory - Class in org.apache.lucene.store
 
XMMapFSDirectory(File, LockFactory, StoreRateLimiting.Provider, StoreRateLimiting.Listener) - Constructor for class org.apache.lucene.store.XMMapFSDirectory
 
XNIOFSDirectory - Class in org.apache.lucene.store
 
XNIOFSDirectory(File, LockFactory, StoreRateLimiting.Provider, StoreRateLimiting.Listener) - Constructor for class org.apache.lucene.store.XNIOFSDirectory
 
XRejectedExecutionHandler - Interface in org.elasticsearch.common.util.concurrent
 
XScoreOrderFragmentsBuilder - Class in org.apache.lucene.search.vectorhighlight
An implementation of FragmentsBuilder that outputs score-order fragments.
XScoreOrderFragmentsBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.XScoreOrderFragmentsBuilder
a constructor.
XScoreOrderFragmentsBuilder(String[], String[]) - Constructor for class org.apache.lucene.search.vectorhighlight.XScoreOrderFragmentsBuilder
a constructor.
XScoreOrderFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.XScoreOrderFragmentsBuilder
 
XScoreOrderFragmentsBuilder(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.XScoreOrderFragmentsBuilder
 
XScoreOrderFragmentsBuilder.ScoreComparator - Class in org.apache.lucene.search.vectorhighlight
 
XScoreOrderFragmentsBuilder.ScoreComparator() - Constructor for class org.apache.lucene.search.vectorhighlight.XScoreOrderFragmentsBuilder.ScoreComparator
 
XSimpleFragmentsBuilder - Class in org.apache.lucene.search.vectorhighlight
A simple implementation of FragmentsBuilder.
XSimpleFragmentsBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.XSimpleFragmentsBuilder
a constructor.
XSimpleFragmentsBuilder(String[], String[]) - Constructor for class org.apache.lucene.search.vectorhighlight.XSimpleFragmentsBuilder
a constructor.
XSimpleFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.XSimpleFragmentsBuilder
 
XSimpleFragmentsBuilder(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.XSimpleFragmentsBuilder
 
XSimpleFSDirectory - Class in org.apache.lucene.store
 
XSimpleFSDirectory(File, LockFactory, StoreRateLimiting.Provider, StoreRateLimiting.Listener) - Constructor for class org.apache.lucene.store.XSimpleFSDirectory
 
XTermsFilter - Class in org.apache.lucene.search
Similar to TermsFilter but stores the terms in an array for better memory usage when cached, and also uses bulk read
XTermsFilter(Term) - Constructor for class org.apache.lucene.search.XTermsFilter
 
XTermsFilter(Term[]) - Constructor for class org.apache.lucene.search.XTermsFilter
 

Y

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
 

Z

ZenDiscovery - Class in org.elasticsearch.discovery.zen
 
ZenDiscovery(Settings, ClusterName, ThreadPool, TransportService, ClusterService, NodeSettingsService, DiscoveryNodeService, ZenPingService) - 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.PingListener - Interface in org.elasticsearch.discovery.zen.ping
 
ZenPing.PingResponse - Class in org.elasticsearch.discovery.zen.ping
 
ZenPing.PingResponse(DiscoveryNode, DiscoveryNode, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
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, Set<UnicastHostsProvider>) - Constructor for class org.elasticsearch.discovery.zen.ping.ZenPingService
 

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-2012. All Rights Reserved.